[jira] [Created] (IGNITE-12793) Deadlock in the System Pool on Metadata processing

2020-03-17 Thread Sergey Kosarev (Jira)
Sergey Kosarev created IGNITE-12793:
---

 Summary: Deadlock in the System Pool on Metadata processing
 Key: IGNITE-12793
 URL: https://issues.apache.org/jira/browse/IGNITE-12793
 Project: Ignite
  Issue Type: Bug
Affects Versions: 2.7.6
Reporter: Sergey Kosarev






--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Created] (IGNITE-12549) Scan query/iterator on a replicated cache may get wrong results

2020-01-16 Thread Sergey Kosarev (Jira)
Sergey Kosarev created IGNITE-12549:
---

 Summary: Scan query/iterator on a replicated cache may get wrong 
results
 Key: IGNITE-12549
 URL: https://issues.apache.org/jira/browse/IGNITE-12549
 Project: Ignite
  Issue Type: Bug
  Components: cache
Affects Versions: 2.7.6
Reporter: Sergey Kosarev


Case 1
1.  start server node 1
2  create and fill replicated cache with RebalanceMode.Async (as by default)
3  start servr node 2 
3 immediately execute scan query  on the replicated cache((or just iterate the 
cache)) on the node 2
It can get empty or partial results. (if rebalance on node 2 is finished)

Case 2
1.  start server node 1
2  create and fill replicated cache with RebalanceMode.Async (as by default)
3 start client node 2
3  start server node 3 
3 immediately execute scan query  on the replicated cache((or just iterate the 
cache)) on the client node 2
It can get empty or partial results. (if rebalance on node 2 is not finished 
and query is mapped on the node 2)

It looks like problem in the 
org.apache.ignite.internal.processors.cache.query.GridCacheQueryAdapter#nodes()

case REPLICATED:
if (prj != null || part != null)
return nodes(cctx, prj, part);

if (cctx.affinityNode())
return *Collections.singletonList(cctx.localNode())*;

Collection affNodes = nodes(cctx, null, null);

return affNodes.isEmpty() ? affNodes : 
*Collections.singletonList(F.rand(affNodes))*;

case PARTITIONED:
return nodes(cctx, prj, part);

 





--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Created] (IGNITE-11909) Cache.invokeAll() returns a map with BinaryObjects as keys

2019-06-10 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-11909:
---

 Summary: Cache.invokeAll() returns a map with BinaryObjects as keys
 Key: IGNITE-11909
 URL: https://issues.apache.org/jira/browse/IGNITE-11909
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev


Preconditions:
1) AtomicityMode.Transactional
2) Key is custom object. (i.e MyKey)

cache.returnAll returns should return Map>, but 
keys 
processed on remote node(s) are not unwrapped and return as BinaryObject, so we 
can gat a map with mixed keys:

{code}
key.class = BinaryObjectImpl, key = 
org.apache.ignite.examples.datagrid.CacheEntryProcessorExample2$MyKey 
[idHash=151593342, hash=31459296, i=2]
key.class = MyKey, key = MyKey{i=7}
key.class = BinaryObjectImpl, key = 
org.apache.ignite.examples.datagrid.CacheEntryProcessorExample2$MyKey 
[idHash=405215542, hash=31638042, i=8]
key.class = MyKey, key = MyKey{i=1}
key.class = BinaryObjectImpl, key = 
org.apache.ignite.examples.datagrid.CacheEntryProcessorExample2$MyKey 
[idHash=1617838096, hash=31548669, i=5]
key.class = MyKey, key = MyKey{i=0}
key.class = BinaryObjectImpl, key = 
org.apache.ignite.examples.datagrid.CacheEntryProcessorExample2$MyKey 
[idHash=138776324, hash=31578460, i=6]
key.class = MyKey, key = MyKey{i=9}
key.class = MyKey, key = MyKey{i=4}
{code}

Reproducer is attached.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-11044) CacheMetricsEntitiesCountTest.testEnitiesCount fails in MVCC Suite on master

2019-01-23 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-11044:
---

 Summary: CacheMetricsEntitiesCountTest.testEnitiesCount fails in 
MVCC Suite on master
 Key: IGNITE-11044
 URL: https://issues.apache.org/jira/browse/IGNITE-11044
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-11036) IgniteTcpCommunicationHandshakeWaitTest/IgniteTcpCommunicationHandshakeWaitSslTest fail in master

2019-01-22 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-11036:
---

 Summary: 
IgniteTcpCommunicationHandshakeWaitTest/IgniteTcpCommunicationHandshakeWaitSslTest
 fail in master 
 Key: IGNITE-11036
 URL: https://issues.apache.org/jira/browse/IGNITE-11036
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev
Assignee: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-10659) Possible deadlock causing by metadata request in grid-timeout-worker

2018-12-12 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-10659:
---

 Summary: Possible deadlock causing by metadata request  in 
grid-timeout-worker
 Key: IGNITE-10659
 URL: https://issues.apache.org/jira/browse/IGNITE-10659
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev


It looks like IGNITE-9840 fixes not all the cases.
We have similar problem on a sever node:

{code}
Thread [name="grid-timeout-worker-#119%DPL_GRID%DplGridNodeName%", id=235, 
state=WAITING, blockCnt=2, waitCnt=664073]
at sun.misc.Unsafe.park(Native Method)
at java.util.concurrent.locks.LockSupport.park(LockSupport.java:304)
at 
o.a.i.i.util.future.GridFutureAdapter.get0(GridFutureAdapter.java:178)
at o.a.i.i.util.future.GridFutureAdapter.get(GridFutureAdapter.java:141)
at 
o.a.i.i.processors.cache.binary.CacheObjectBinaryProcessorImpl.metadata0(CacheObjectBinaryProcessorImpl.java:592)
at 
o.a.i.i.processors.cache.binary.CacheObjectBinaryProcessorImpl.metadata(CacheObjectBinaryProcessorImpl.java:550)
at 
o.a.i.i.processors.cache.binary.CacheObjectBinaryProcessorImpl$1.metadata(CacheObjectBinaryProcessorImpl.java:200)
at o.a.i.i.binary.BinaryContext.metadata(BinaryContext.java:1266)
at o.a.i.i.binary.BinaryUtils.type(BinaryUtils.java:2425)
at o.a.i.i.binary.BinaryObjectImpl.rawType(BinaryObjectImpl.java:302)
at 
o.a.i.i.binary.BinaryObjectExImpl.toString(BinaryObjectExImpl.java:208)
at 
o.a.i.i.binary.BinaryObjectExImpl.appendValue(BinaryObjectExImpl.java:286)
at 
o.a.i.i.binary.BinaryObjectExImpl.toString(BinaryObjectExImpl.java:235)
at 
o.a.i.i.binary.BinaryObjectExImpl.toString(BinaryObjectExImpl.java:187)
at o.a.i.i.binary.BinaryObjectImpl.toString(BinaryObjectImpl.java:920)
at java.lang.String.valueOf(String.java:2994)
at java.lang.StringBuilder.append(StringBuilder.java:131)
at 
o.a.i.i.processors.cache.transactions.TxEntryValueHolder.toString(TxEntryValueHolder.java:161)
at java.lang.String.valueOf(String.java:2994)
at o.a.i.i.util.GridStringBuilder.a(GridStringBuilder.java:101)
at o.a.i.i.util.tostring.SBLimitedLength.a(SBLimitedLength.java:100)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:849)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toStringImpl0(GridToStringBuilder.java:1067)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toStringImpl(GridToStringBuilder.java:994)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:754)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:722)
at 
o.a.i.i.processors.cache.transactions.IgniteTxEntry.toString(IgniteTxEntry.java:1273)
at java.lang.String.valueOf(String.java:2994)
at o.a.i.i.util.GridStringBuilder.a(GridStringBuilder.java:101)
at o.a.i.i.util.tostring.SBLimitedLength.a(SBLimitedLength.java:100)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:849)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:807)
at 
o.a.i.i.util.tostring.GridToStringBuilder.addCollection(GridToStringBuilder.java:900)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:845)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:807)
at 
o.a.i.i.util.tostring.GridToStringBuilder.appendVals(GridToStringBuilder.java:1662)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toStringImpl0(GridToStringBuilder.java:1070)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toStringImpl(GridToStringBuilder.java:994)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:754)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:722)
at 
o.a.i.i.processors.cache.transactions.IgniteTxStateImpl.toString(IgniteTxStateImpl.java:491)
at java.lang.String.valueOf(String.java:2994)
at o.a.i.i.util.GridStringBuilder.a(GridStringBuilder.java:101)
at o.a.i.i.util.tostring.SBLimitedLength.a(SBLimitedLength.java:100)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:849)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toStringImpl0(GridToStringBuilder.java:1067)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toStringImpl(GridToStringBuilder.java:994)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:703)
at 
o.a.i.i.util.tostring.GridToStringBuilder.toString(GridToStringBuilder.java:662)
at 
o.a.i.i.processors.cache.transactions.IgniteTxLocalAdapter.toString(IgniteTxLocalAdapter.java:1621)
at 

[jira] [Created] (IGNITE-10589) Multiple server node failure after a client node stopping

2018-12-07 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-10589:
---

 Summary: Multiple server node failure after a client node stopping
 Key: IGNITE-10589
 URL: https://issues.apache.org/jira/browse/IGNITE-10589
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev


after stopping a client
we see  topology change and pme finish on the coordinator, 
and at soon on another nodes we still don't see new topology, but have 
Critical error resulting nodes failure




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-10499) Stopping ignite node when a transaction on this node in process of commit(rollback) may cause hang up

2018-11-30 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-10499:
---

 Summary: Stopping ignite node when a transaction on this node in 
process of commit(rollback) may cause hang up
 Key: IGNITE-10499
 URL: https://issues.apache.org/jira/browse/IGNITE-10499
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev



1 start a node
2 start workload (transactions ) on this node
3 stop node

problem that checkpointReadLock throws IgniteException - unchecked - so it does 
not catched anywhere
and brokes commit process GridNearTxLocal#finishFutfinishFutrure stays 
unfinished and
*morover it don't lsten prepareFut.*
 
stacktrace to follow
{code}
018-11-30 20:37:56,508][ERROR][tx-load-thread-4][IgniteTxAdapter] Prepare error
class org.apache.ignite.IgniteException: Failed to perform cache update: node 
is stopping.
at 
org.apache.ignite.internal.processors.cache.persistence.GridCacheDatabaseSharedManager.checkpointReadLock(GridCacheDatabaseSharedManager.java:1501)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxPrepareFuture.onEntriesLocked(GridDhtTxPrepareFuture.java:371)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxPrepareFuture.prepare0(GridDhtTxPrepareFuture.java:1295)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxPrepareFuture.mapIfLocked(GridDhtTxPrepareFuture.java:710)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxPrepareFuture.prepare(GridDhtTxPrepareFuture.java:1100)
at 
org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxLocal.prepareAsyncLocal(GridNearTxLocal.java:4064)
at 
org.apache.ignite.internal.processors.cache.transactions.IgniteTxHandler.prepareColocatedTx(IgniteTxHandler.java:292)
at 
org.apache.ignite.internal.processors.cache.distributed.near.GridNearPessimisticTxPrepareFuture.prepareLocal(GridNearPessimisticTxPrepareFuture.java:258)
at 
org.apache.ignite.internal.processors.cache.distributed.near.GridNearPessimisticTxPrepareFuture.preparePessimistic(GridNearPessimisticTxPrepareFuture.java:384)
at 
org.apache.ignite.internal.processors.cache.distributed.near.GridNearPessimisticTxPrepareFuture.prepare(GridNearPessimisticTxPrepareFuture.java:188)
at 
org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxLocal.prepareNearTxLocal(GridNearTxLocal.java:3709)
at 
org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxLocal.commitNearTxLocalAsync(GridNearTxLocal.java:3761)
at 
org.apache.ignite.internal.processors.cache.GridCacheAdapter.commitTxAsync(GridCacheAdapter.java:4214)
at 
org.apache.ignite.internal.processors.cache.GridCacheSharedContext.commitTxAsync(GridCacheSharedContext.java:1034)
at 
org.apache.ignite.internal.processors.cache.transactions.TransactionProxyImpl.commit(TransactionProxyImpl.java:297)
at 
org.gridgain.grid.internal.processors.cache.database.txdr.AbstractReplicationTest.lambda$startTxLoad$2(AbstractReplicationTest.java:694)
at 
org.apache.ignite.testframework.GridTestUtils$7.call(GridTestUtils.java:1300)
at 
org.apache.ignite.testframework.GridTestThread.run(GridTestThread.java:84)
Caused by: class org.apache.ignite.internal.NodeStoppingException: Failed to 
perform cache update: node is stopping.
{code}

so after commit caused Exception 
we are going to close as transaction Autoclosable
and wait forever on
{code}
org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxLocal#close(boolean)
in rollbackNearTxLocalAsync(clearThreadMap, false).get();
{code}
and we are locked GridKernalGateway#readLock 

and so ignite.stop thread hangs on trying to acquire GridKernalGateway#writeLock




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-9739) Critical exception in transaction processing in case we have nodes out of baseline and non-persisted cache

2018-09-28 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-9739:
--

 Summary: Critical exception in transaction processing in case we 
have nodes out of baseline and non-persisted cache
 Key: IGNITE-9739
 URL: https://issues.apache.org/jira/browse/IGNITE-9739
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev



Activation finished 
{code}
2018-09-20 20:47:05.169 [INFO 
][sys-#307%DPL_GRID%DplGridNodeName%][o.g.g.i.p.c.d.GridSnapshotAwareClusterStateProcessorImpl]
 Successfully performed final activation steps 
[nodeId=382437eb-fd8a-4f92-acd5-d9ea562c8557, client=false, 
topVer=AffinityTopologyVersion [topVer=160, minorTopVer=1]]
{code}

but we have nodes not in base line
{code}
2018-09-20 20:45:36.116 [INFO 
][sys-#305%DPL_GRID%DplGridNodeName%][o.g.g.i.p.c.d.GridSnapshotAwareClusterStateProcessorImpl]
 Local node is not included in Baseline Topology and will not be used for 
persistent data storage. Use control.(sh|bat) script or IgniteCluster interface 
to include the node to Baseline Topology.
{code}

And we have cache in the data region with persistanceEnabled=false
{code}
2018-09-20 20:49:01.825 [INFO 
][exchange-worker-#154%DPL_GRID%DplGridNodeName%][o.a.i.i.p.cache.GridCacheProcessor]
 Started cache [name=DPL_PUBLISHED_CACHES_REGISTRY$, *id=869481129*, group=SY
STEM_CACHEGROUP_PUBLISHED_REGISTRY, memoryPolicyName=not-persisted, 
mode=PARTITIONED, atomicity=TRANSACTIONAL, backups=3]
{code}

Transaction on this cache leads to critical error causing nodes by faulure 
handler:
{code}
2018-09-20 20:50:24.275 
[ERROR][sys-stripe-41-#42%DPL_GRID%DplGridNodeName%][o.a.i.i.p.cache.GridCacheIoManager]
 Failed processing message [senderId=62e986f0-62b5-4ec8-8cc7-27b74d345235, 
msg=GridDhtTxPrepareRequest [nearNodeId=814af7c4-2de5-4511-b1ea-065b91eaa774, 
futId=520e308f561-255fdea5-a996-4102-a120-afa380c54570, miniId=1, 
topVer=AffinityTopologyVersion [topVer=160, minorTopVer=2], 
invalidateNearEntries={}, nearWrites=null, owned=null, 
nearXidVer=GridCacheVersion [topVer=148944365, order=1537511036821, 
nodeOrder=132], subjId=814af7c4-2de5-4511-b1ea-065b91eaa774, taskNameHash=0, 
preloadKeys=null, skipCompletedVers=false, 
super=GridDistributedTxPrepareRequest [threadId=58, concurrency=PESSIMISTIC, 
isolation=READ_COMMITTED, writeVer=GridCacheVersion [topVer=148944365, 
order=1537511036824, nodeOrder=7], timeout=299970, reads=null, writes=ArrayList 
[

IgniteTxEntry [key=KeyCacheObjectImpl [part=27254, 
val=com.sbt.api.entities.out.IPublishedDocType, hasValBytes=true], 
*cacheId=869481129*,
txKey=IgniteTxKey [key=KeyCacheObjectImpl [part=27254, 
val=com.sbt.api.entities.out.IPublishedDocType, hasValBytes=true], 
*cacheId=869481129*], val=[op=CREATE, 
val=com.sbt.dpl.gridgain.PublishedRegistry$PublishedCacheTuple 
[idHash=811765531, hash=1522508040, 
cacheName=com.sbt.gbk.entities.DocType_DPL_union-module,indexes=ArrayList 
{com.sbt.dpl.gridgain.newModel.base.indexes.PublishedIndexType
[idHash=1583970836, hash=363194492, isSoftReference=false, 
unselectiveBuckets=4096, fieldNames=ArrayList {isDeleted},
moduleName=union-module
, cachedUnselectives=1, selectors=ArrayList {isDeleted}, 
exceptUnselectives=false, primitiveCollection=false, isVersioned=false, 
isComposite=false, isSystemTypeBelongs=false,
name=com.sbt.gbk.entities.DocType_DPL_isDeleted, isIndexedCollection=false, 
isGlobal=false, maxSelective=1000], 
com.sbt.dpl.gridgain.newModel.base.indexes.PublishedIndexType
[idHash=2060926101, hash=1983794578, isSoftReference=false, 
unselectiveBuckets=4096, fieldNames=ArrayList {code},moduleName=union-module, 
cachedUnselectives=1, selectors=ArrayList {code}, exceptUnselectives=false, 
primitiveCollection=false, isVersioned=false, isComposite=false, 
isSystemTypeBelongs=false, name=com.sbt.gbk.entities.DocType_DPL_code, 
isIndexedCollection=false, isGlobal=true, maxSelective=1000]
, com.sbt.dpl.gridgain.newModel.base.indexes.PublishedIndexType
[idHash=1821682714, hash=-1245813786, isSoftReference=false, 
unselectiveBuckets=4096, fieldNames=ArrayList {globalId},
moduleName=union-module, cachedUnselectives=1, selectors=ArrayList 
{globalId}, exceptUnselectives=false, primitiveCollection=false, 
isVersioned=false, isComposite=false, isSystemTypeBelongs=false,
name=com.sbt.gbk.entities.DocType_DPL_globalId, isIndexedCollection=false, 
isGlobal=false, maxSelective=1000]
}, partitionDependencyClassName=null, moduleName=union-module, 
cacheModuleName=union-module]
], prevVal=[op=NOOP, val=null], oldVal=[op=NOOP, val=null], 
entryProcessorsCol=null, ttl=-1, conflictExpireTime=-1, conflictVer=null, 
explicitVer=null, dhtVer=null, filters=CacheEntryPredicate[] [], 
filtersPassed=false, filtersSet=false, entry=GridCacheMapEntry 
[key=KeyCacheObjectImpl [part=27254, 
val=com.sbt.api.entities.out.IPublishedDocType, hasValBytes=true], val=null, 
startVer=1537511036806, ver=GridCacheVersion [topVer=148944365, 

[jira] [Created] (IGNITE-9698) Add tests to control.sh with ssl authentication

2018-09-26 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-9698:
--

 Summary: Add tests to  control.sh with ssl authentication
 Key: IGNITE-9698
 URL: https://issues.apache.org/jira/browse/IGNITE-9698
 Project: Ignite
  Issue Type: Improvement
Reporter: Sergey Kosarev
Assignee: Alexand Polyakov






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-9693) Scale up wal compression workers to increase perormance

2018-09-25 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-9693:
--

 Summary: Scale up wal compression workers to increase perormance
 Key: IGNITE-9693
 URL: https://issues.apache.org/jira/browse/IGNITE-9693
 Project: Ignite
  Issue Type: Improvement
Reporter: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-9296) Stopping node by Failure Handler hangs up

2018-08-16 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-9296:
--

 Summary:  Stopping node by Failure Handler hangs up
 Key: IGNITE-9296
 URL: https://issues.apache.org/jira/browse/IGNITE-9296
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-9135) TcpDiscovery - High Workload in Stable topology

2018-07-30 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-9135:
--

 Summary: TcpDiscovery - High Workload in Stable topology
 Key: IGNITE-9135
 URL: https://issues.apache.org/jira/browse/IGNITE-9135
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev


On High topology (about 200 servers/ 50 clients) we see often  via jmx 
(TcpDiscoverySpiMBean) high MessageWorkerQueueSize peaks (>100) in stable 
cluster topology. Also very high number (about 25) of ProcesedMessages, 
ReceivedMessages for TcpDiscoveryStatusCheckMessage, whereas 
TcpDiscoveryMetricsUpdateMessage is about 11.

it looks like

org.apache.ignite.spi.discovery.tcp.ServerImpl.RingMessageWorker#metricsCheckFreq

value does not depend on topology size

private long metricsCheckFreq = 3 * spi.metricsUpdateFreq + 50;

 

 

 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8954) Rebalance has restarted fully after reassigning missing partitions

2018-07-06 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8954:
--

 Summary: Rebalance has restarted fully after reassigning missing 
partitions
 Key: IGNITE-8954
 URL: https://issues.apache.org/jira/browse/IGNITE-8954
 Project: Ignite
  Issue Type: Bug
Affects Versions: 2.5
Reporter: Sergey Kosarev


*Rebalance finished with missing partitions* :

 
2018-07-06 00:59:16.118[INFO 
][sys-#718%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.d.d.p.GridDhtPartitionDemander]
 Completed (final) rebalancing [fromNode=e1ee8729-8a6f-479e-9f39-614605d3147f, 
cacheOrGroup=CACHEGROUP_PARTICLE_union-module_com.sbt.aep.dpl.dictionaries.SubDiv,
 topology=AffinityTopologyVersion [topVer=344, minorTopVer=1], time=61 ms]
2018-07-06 00:59:16.118[INFO 
][sys-#718%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.d.d.p.GridDhtPartitionDemander]
 Completed rebalance future: RebalanceFuture [grp=CacheGroupContext 
[grp=CACHEGROUP_PARTICLE_union-module_com.sbt.aep.dpl.dictionaries.SubDiv], 
topVer=AffinityTopologyVersion [topVer=344, minorTopVer=1], rebalanceId=453]
2018-07-06 00:59:16.118[INFO 
][sys-#718%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.d.d.p.GridDhtPartitionDemander]
 Reassigning partitions that were missed: [10240, 12291, 11781, 11270, 11783, 
10247, 12295, 12296, 9737, 12810, 11275, 10251, 12303, 11794, 11285, 10774, 
10777, 11292, 10270, 12323, 11812, 10279, 12841, 9769, 10794, 10282, 10283, 
12844, 11827, 9779, 11830, 12856, 10301, 9791, 11840, 12868, 10312, 11336, 
9803, 10834, 11858, 12371, 10328, 11353, 10331, 12891, 12892, 10845, 12384, 
11875, 12905, 10346, 11373, 10862, 9840, 10866, 10355, 10356, 12404, 12405, 
12918, 11895, 11896, 10872, 10360, 11384, 9849, 9850, 11387, 10875, 10368, 
12933, 10376, 10890, 11403, 10893, 12431, 11407, 10384, 12433, 11923, 10900, 
9877, 11413, 9878, 11927, 12952, 10906, 11418, 10394, 11931, 10395, 11419, 
9885, 11934, 10912, 11937, 11425, 11426, 12966, 10412, 12975, 12464, 10929, 
12978, 11954, 10931, 11956, 9910, 10935, 11967, 12992, 10437, 11974, 9928, 
13000, 10440, 12489, 11977, 9931, 10445, 11469, 10960, 10962, 11475, 10968, 
11994, 10459, 13020, 11484, 12509, 10975, 10465, 10468, 9957, 10981, 13039, 
9969, 12018, 11506, 13044, 13047, 11000, 9978, 11516, 12540, 12541, 12542, 
11519, 12032, 11009, 11522, 12037, 12549, 12550, 10503, 12039, 12040, 13066, 
10509, 11533, 12047, 13071, 13073, 12562, 10514, 11026, 12050, 10005, 10518, 
11033, 13081, 11548, 13087, 12064, 13092, 11044, 10021, 12583, 10537, 11561, 
10538, 11564, 10543, 10546, 13106, 10034, 10038, 12088, 11065, 10558, 11070, 
13118, 11075, 12611, 10054, 11078, 12616, 11081, 11082, 10571, 10059, 13135, 
11088, 11602, 12116, 10584, 13145, 11610, 10587, 13149, 12638, 13152, 12128, 
12641, 10081, 12130, 12131, 12643, 10598, 12134, 10086, 13160, 10089, 11626, 
10602, 13166, 10094, 12142, 13167, 10096, 10608, 10610, 10612, 12662, 13175, 
10106, 11131, 12164, 12166, 13190, 10631, 10121, 10128, 12177, 11158, 12185, 
11161, 13210, 10650, 11675, 11166, 12711, 11176, 10152, 11688, 10665, 11691, 
10667, 11181, 12207, 13231, 10673, 12721, 11701, 10166, 10168, 12732, 10685, 
10173, 11709, 1, 12223, 10687, 12737, 11716, 13259, 11211, 12236, 11725, 
12749, 10190, 11728, 10707, 13273, 10201, 12250, 12762, 11741, 13279, 10207, 
11231, 11744, 10208, 10721, 11745, 12260, 12776, 12777, 12270, 13294, 12272, 
10739, 11763, 12276, 10230, 11254, 11767, 9724, 10239, 12799, 12287]
2018-07-06 00:59:16.118[INFO 
][sys-#718%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.d.d.p.GridDhtPartitionDemander]
 [REB] Done as missed 
CACHEGROUP_PARTICLE_union-module_com.sbt.aep.dpl.dictionaries.SubDiv, 
parts=[10059, 10173, 10190, 10279, 1
2131, 12166], dir=[topVer=(344, 1), idx=4, sup=10.124.128.195:47500]
2018-07-06 00:59:16.118[INFO 
][sys-#718%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.d.d.p.GridDhtPartitionDemander]
 [REB] Stop demand 
CACHEGROUP_PARTICLE_union-module_com.sbt.aep.dpl.dictionaries.SubDiv, 
futDone=true, topCh=false,dir=[topVer=(
344, 1), idx=4, sup=10.124.128.195:47500]
 
*And then restarted again:*
 
2018-07-06 00:59:17.657[INFO 
][exchange-worker-#152%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.GridCachePartitionExchangeManager]
 Rebalancing scheduled [order=[ignite-sys-cache, BGP_Locks_auto-transact, 
CACHEGROUP_PARTICLE_union-module_com.sbt.acquiring.processing.entities.dictionaries.PublishedDepTerBank,
 ,CACHEGROUP_PARTICLE_union-module_com.sbt.aep.dpl.dictionaries.SubDiv, 
...]]

2018-07-06 00:59:17.657[INFO 
][exchange-worker-#152%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.GridCachePartitionExchangeManager]
 Rebalancing started [top=null, evt=DISCOVERY_CUSTOM_EVT, 
node=60221959-ecd9-42af-b3b9-99a9b0fdceea]
2018-07-06 00:59:17.657[INFO 
][exchange-worker-#152%DPL_GRID%DplGridNodeName%][o.a.i.i.p.c.d.d.p.GridDhtPartitionDemander]
 Starting rebalancing [grp=ignite-sys-cache, mode=SYNC, 
fromNode=8dabf12b-2872-4b88-be14-6a66b16146e9, nodeConsId=10.124.128.199:47500, 

[jira] [Created] (IGNITE-8894) Provide information about coordinator in control.sh output

2018-06-28 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8894:
--

 Summary: Provide information about coordinator in control.sh output
 Key: IGNITE-8894
 URL: https://issues.apache.org/jira/browse/IGNITE-8894
 Project: Ignite
  Issue Type: Improvement
Reporter: Sergey Kosarev
Assignee: Sergey Kosarev


Information about coordinator can be added in an existing command (i.e. 
--state, --baseline)

either a new command can be introduced.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8815) Ease enabling wal mangement in control.sh

2018-06-18 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8815:
--

 Summary: Ease enabling wal mangement in control.sh 
 Key: IGNITE-8815
 URL: https://issues.apache.org/jira/browse/IGNITE-8815
 Project: Ignite
  Issue Type: Improvement
Affects Versions: 2.6
Reporter: Sergey Kosarev
Assignee: Sergey Kosarev
 Fix For: 2.6


 --wal command was introduce in IGNITE-7912 under option 
-DIGNITE_ENABLE_EXPERIMENTAL_COMMAND=true only.

It'd better add this option into control.sh script as a comment:

# Uncomment to enable --wal command
# JVM_OPTS=“${JVM_OPTS} -DIGNITE_ENABLE_EXPERIMENTAL_COMMAND=true”

 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8696) control.sh utility does not show atomicity mode

2018-06-04 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8696:
--

 Summary: control.sh utility does not show atomicity mode
 Key: IGNITE-8696
 URL: https://issues.apache.org/jira/browse/IGNITE-8696
 Project: Ignite
  Issue Type: Bug
Affects Versions: 2.5
Reporter: Sergey Kosarev
Assignee: Sergey Kosarev
 Fix For: 2.6


In current implementation cache viewer list function:

./control.sh --cache list

does not show atomicity mode for caches. Please add this to the output.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8587) High Contention in GridToStringBuilder.toStringImpl

2018-05-23 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8587:
--

 Summary: High Contention in GridToStringBuilder.toStringImpl  
 Key: IGNITE-8587
 URL: https://issues.apache.org/jira/browse/IGNITE-8587
 Project: Ignite
  Issue Type: Bug
Affects Versions: 2.4
Reporter: Sergey Kosarev
Assignee: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8449) Avoid empty acquiring/releasing checkpointReadLock for stale updates

2018-05-07 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8449:
--

 Summary: Avoid empty acquiring/releasing checkpointReadLock for 
stale updates
 Key: IGNITE-8449
 URL: https://issues.apache.org/jira/browse/IGNITE-8449
 Project: Ignite
  Issue Type: Bug
Reporter: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8387) AssertionError on get() operation from replicated cache

2018-04-25 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8387:
--

 Summary: AssertionError on get() operation from replicated cache
 Key: IGNITE-8387
 URL: https://issues.apache.org/jira/browse/IGNITE-8387
 Project: Ignite
  Issue Type: Bug
  Components: persistence
Reporter: Sergey Kosarev


Multiple Asserrtion errors are found in ignite.log:

{code}
*java.lang.AssertionError: result=true, persistenceEnabled=true, 
partitionState=RENTING, replicated=true*
at 
*org.apache.ignite.internal.processors.cache.GridCacheContext.reserveForFastLocalGet(GridCacheContext.java:2050)*
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridPartitionedSingleGetFuture.mapKeyToNode(GridPartitionedSingleGetFuture.java:337)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridPartitionedSingleGetFuture.map(GridPartitionedSingleGetFuture.java:216)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.GridPartitionedSingleGetFuture.init(GridPartitionedSingleGetFuture.java:208)
at 
org.apache.ignite.internal.processors.cache.distributed.dht.colocated.GridDhtColocatedCache.getAsync(GridDhtColocatedCache.java:246)
at 
org.apache.ignite.internal.processors.cache.GridCacheAdapter.get0(GridCacheAdapter.java:4565)
at 
org.apache.ignite.internal.processors.cache.GridCacheAdapter.get(GridCacheAdapter.java:4546)
at 
org.apache.ignite.internal.processors.cache.GridCacheAdapter.get(GridCacheAdapter.java:1347)
at 
org.apache.ignite.internal.processors.cache.IgniteCacheProxyImpl.get(IgniteCacheProxyImpl.java:828)
at 
org.apache.ignite.internal.processors.cache.GatewayProtectedCacheProxy.get(GatewayProtectedCacheProxy.java:662)
at 
com.sbt.dpl.gridgain.storages.PublishedStorage.getBinaryObject(PublishedStorage.java:290)
at 
com.sbt.dpl.gridgain.storages.PublishedStorage.getBinaryWithConverter(PublishedStorage.java:270)
at 
com.sbt.dpl.gridgain.storages.PublishedStorage.get(PublishedStorage.java:214)
at com.sbt.dpl.gridgain.storages.Storage.get(Storage.java:316)
at com.sbt.dpl.gridgain.storages.Storage.get(Storage.java:50)
at 
com.sbt.dpl.gridgain.storages.PublishedStorage.get(PublishedStorage.java:357)
at com.sbt.dpl.gridgain.GridGainDPL.getDictionary(GridGainDPL.java:195)
at com.sbt.dpl.gridgain.GridGainDPL.getDictionary(GridGainDPL.java:224)
at 
com.sbt.dpl.gridgain.compute.SerialCollectCallable.getPartition(SerialCollectCallable.java:85)
at 
com.sbt.dpl.gridgain.compute.SerialCollectCallable.call(SerialCollectCallable.java:73)
at 
com.sbt.dpl.gridgain.compute.SerialCollectCallable.call(SerialCollectCallable.java:36)
at 
com.sbt.dpl.gridgain.compute.CallableClassLoaderWrapper.call(CallableClassLoaderWrapper.java:90)
at 
org.apache.ignite.internal.processors.closure.GridClosureProcessor$C2.execute(GridClosureProcessor.java:1855)
at 
org.apache.ignite.internal.processors.job.GridJobWorker$2.call(GridJobWorker.java:566)
at 
org.apache.ignite.internal.util.IgniteUtils.wrapThreadLoader(IgniteUtils.java:6625)
at 
org.apache.ignite.internal.processors.job.GridJobWorker.execute0(GridJobWorker.java:560)
at 
org.apache.ignite.internal.processors.job.GridJobWorker.body(GridJobWorker.java:489)
at 
org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)
at 
org.apache.ignite.internal.processors.job.GridJobProcessor.processJobExecuteRequest(GridJobProcessor.java:1189)
at 
org.apache.ignite.internal.processors.job.GridJobProcessor$JobExecutionListener.onMessage(GridJobProcessor.java:1921)
at 
org.apache.ignite.internal.managers.communication.GridIoManager.invokeListener(GridIoManager.java:1555)
at 
org.apache.ignite.internal.managers.communication.GridIoManager.processRegularMessage0(GridIoManager.java:1183)
{code}





--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-8053) Exception during checkpoint concurrent changes in topology

2018-03-27 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-8053:
--

 Summary: Exception during checkpoint concurrent changes in topology
 Key: IGNITE-8053
 URL: https://issues.apache.org/jira/browse/IGNITE-8053
 Project: Ignite
  Issue Type: Bug
  Components: persistence
Affects Versions: 2.4
Reporter: Sergey Kosarev






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-7742) AssertionError in IgniteCacheOffheapManagerImpl when Iterate Cache with expire policy and persistence

2018-02-16 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-7742:
--

 Summary: AssertionError in IgniteCacheOffheapManagerImpl when 
Iterate Cache with expire policy and persistence
 Key: IGNITE-7742
 URL: https://issues.apache.org/jira/browse/IGNITE-7742
 Project: Ignite
  Issue Type: Bug
  Components: persistence
Affects Versions: 2.4
Reporter: Sergey Kosarev


Some assertions were added in IGNITE-6423 

One of them fires here.

We check for 
assert cctx.shared().database().checkpointLockIsHeldByThread();
but we don't have this lock


{code:java}
java.lang.AssertionError
at 
org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl$CacheDataStoreImpl.remove(IgniteCacheOffheapManagerImpl.java:1372)
at 
org.apache.ignite.internal.processors.cache.persistence.GridCacheOffheapManager$GridCacheDataStore.remove(GridCacheOffheapManager.java:1364)
at 
org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManagerImpl.remove(IgniteCacheOffheapManagerImpl.java:370)
at 
org.apache.ignite.internal.processors.cache.GridCacheMapEntry.removeValue(GridCacheMapEntry.java:3602)
at 
org.apache.ignite.internal.processors.cache.GridCacheMapEntry.onExpired(GridCacheMapEntry.java:3355)
at 
org.apache.ignite.internal.processors.cache.GridCacheMapEntry.unswap(GridCacheMapEntry.java:421)
at 
org.apache.ignite.internal.processors.cache.GridCacheMapEntry.unswap(GridCacheMapEntry.java:369)
at 
org.apache.ignite.internal.processors.cache.query.GridCacheQueryManager$ScanQueryIterator.advance(GridCacheQueryManager.java:3043)
at 
org.apache.ignite.internal.processors.cache.query.GridCacheQueryManager$ScanQueryIterator.onHasNext(GridCacheQueryManager.java:2999)
at 
org.apache.ignite.internal.util.GridCloseableIteratorAdapter.hasNextX(GridCloseableIteratorAdapter.java:53)
at 
org.apache.ignite.internal.processors.cache.CacheWeakQueryIteratorsHolder$WeakQueryCloseableIterator.onHasNext(CacheWeakQueryIteratorsHolder.java:308)
at 
org.apache.ignite.internal.util.GridCloseableIteratorAdapter.hasNextX(GridCloseableIteratorAdapter.java:53)
at 
org.apache.ignite.internal.util.lang.GridIteratorAdapter.hasNext(GridIteratorAdapter.java:45)
at 
org.apache.ignite.internal.processors.database.IgniteDbExpireTest.testIterators(IgniteDbExpireTest.java:132)
at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
at 
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
at java.lang.reflect.Method.invoke(Method.java:498)
at junit.framework.TestCase.runTest(TestCase.java:176)
at 
org.apache.ignite.testframework.junits.GridAbstractTest.runTestInternal(GridAbstractTest.java:2001)
at 
org.apache.ignite.testframework.junits.GridAbstractTest.access$000(GridAbstractTest.java:133)
at 
org.apache.ignite.testframework.junits.GridAbstractTest$5.run(GridAbstractTest.java:1916)
at java.lang.Thread.run(Thread.java:748){code}






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-7674) It is possible to create BinaryObject with wrong field type and that can lead to broken Transaction (TransactionHeuristicException)

2018-02-12 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-7674:
--

 Summary: It is possible to create BinaryObject with wrong field 
type and that can lead to broken Transaction (TransactionHeuristicException)
 Key: IGNITE-7674
 URL: https://issues.apache.org/jira/browse/IGNITE-7674
 Project: Ignite
  Issue Type: Bug
  Components: binary, sql
Affects Versions: 2.3
Reporter: Sergey Kosarev


Usuaully if we have any data in a cache, if we try to create BynaryObject with 
the same field name and another type we BinaryObjectException is thrown

Wrong value has been set [typeName=org.apache.ignite.internal.binary.Foo, 
fieldName=intField, fieldType=int, assignedValueType=String]

, but there are cases we can create an inconsistent BinaryObject

suppose we have 

{code:java}
class Foo {
private String strField;

private int intField;

public Foo(String strField, int intField) {
this.intField = intField;
this.strField = strField;
}
}{code}

case 1
{code:java}
binary.builder(Foo.class.getName())
.removeField("intField")
.build()
.toBuilder()
.setField("intField", "String")
.build();{code}

case 2 (if we remove all fields schema flag is cleared )
{code:java}
fooCache.withKeepBinary().get(1)
.toBuilder()
.removeField("intField")
.removeField("strField")
.build()
.toBuilder()
.setField("intField", "String")
.build(){code}

It is especially bad when we have an index on this field and cache is 
transactional.
if we put wrong BinaryObject into the cache, we got 
TransactionHeuristicException on commit and broken transaction (data can be 
comitted or not in some cases)



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (IGNITE-7485) control.sh utility does not support authentication

2018-01-22 Thread Sergey Kosarev (JIRA)
Sergey Kosarev created IGNITE-7485:
--

 Summary: control.sh utility does not support authentication
 Key: IGNITE-7485
 URL: https://issues.apache.org/jira/browse/IGNITE-7485
 Project: Ignite
  Issue Type: Improvement
  Components: general
Reporter: Sergey Kosarev
Assignee: Sergey Kosarev


Currently controls.sh utility does not work if cluster is running under 
authentication.

Error is shown:

Failed to get cluster state.
Authentication error.

 

it is suggested to introduce authentication parameters to the utitlity

--login LOGIN

--password PASSWORD

 

Main Utility class ( CommandHandler )  is located in ignite-core module 
currently. 

 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)