You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2017/08/29 14:38:15 UTC

[01/16] ignite git commit: classnames.properties updated.

Repository: ignite
Updated Branches:
  refs/heads/master 7b28da729 -> 9afd67bac


classnames.properties updated.


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/9afd67ba
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/9afd67ba
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/9afd67ba

Branch: refs/heads/master
Commit: 9afd67bac4e5909402761593c9704b0c167f674c
Parents: f589cc8
Author: Andrey Gura <ag...@apache.org>
Authored: Tue Aug 29 17:15:32 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 modules/core/src/main/resources/META-INF/classnames.properties | 5 +++--
 1 file changed, 3 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/9afd67ba/modules/core/src/main/resources/META-INF/classnames.properties
----------------------------------------------------------------------
diff --git a/modules/core/src/main/resources/META-INF/classnames.properties b/modules/core/src/main/resources/META-INF/classnames.properties
index 947b508..1931a93 100644
--- a/modules/core/src/main/resources/META-INF/classnames.properties
+++ b/modules/core/src/main/resources/META-INF/classnames.properties
@@ -426,9 +426,9 @@ org.apache.ignite.internal.processors.cache.GridCacheAdapter$11
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$12
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$13
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$14
-org.apache.ignite.internal.processors.cache.GridCacheAdapter$15
+org.apache.ignite.internal.processors.cache.GridCacheAdapter$15$1
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$16
-org.apache.ignite.internal.processors.cache.GridCacheAdapter$17$1
+org.apache.ignite.internal.processors.cache.GridCacheAdapter$17
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$2
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$25$1
 org.apache.ignite.internal.processors.cache.GridCacheAdapter$27
@@ -795,6 +795,7 @@ org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPre
 org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloader$2
 org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloaderAssignments
 org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtPartitionCountersMap
+org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtPartitionCountersMap2
 org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtPartitionHistorySuppliersMap
 org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtPartitionsToReloadMap
 org.apache.ignite.internal.processors.cache.distributed.near.CacheVersionedValue


[12/16] ignite git commit: Fixed update sequence.

Posted by ag...@apache.org.
Fixed update sequence.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/78b7e3f0
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/78b7e3f0
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/78b7e3f0

Branch: refs/heads/master
Commit: 78b7e3f04028bf2470ac74ae8649f9e7f9aa692c
Parents: 7ce00b1
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Sat Aug 26 17:21:44 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../dht/GridDhtPartitionTopologyImpl.java       | 33 ++++++++++++++------
 1 file changed, 23 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/78b7e3f0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
index a881130..e0f54b3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
@@ -521,7 +521,7 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                             DiscoveryEvent evt = evts0.get(i);
 
                             if (ExchangeDiscoveryEvents.serverLeftEvent(evt))
-                                removeNode(evt.eventNode().id());
+                                updateSeq = removeNode(evt.eventNode().id(), updateSeq);
                         }
                     }
 
@@ -1379,6 +1379,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             long updateSeq = this.updateSeq.incrementAndGet();
 
+            node2part.newUpdateSequence(updateSeq);
+
             if (readyTopVer.initialized() && readyTopVer.equals(lastTopChangeVer)) {
                 AffinityAssignment  aff = grp.affinity().readyAffinity(readyTopVer);
 
@@ -1535,8 +1537,11 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
             GridDhtPartitionMap cur = node2part.get(parts.nodeId());
 
             if (force) {
-                if (cur != null && cur.topologyVersion().initialized())
+                if (cur != null && cur.topologyVersion().initialized()) {
                     parts.updateSequence(cur.updateSequence(), cur.topologyVersion());
+
+                    this.updateSeq.setIfGreater(cur.updateSequence());
+                }
             }
             else  if (isStaleUpdate(cur, parts)) {
                 U.warn(log, "Stale update for single partition map update (will ignore) [exchId=" + exchId +
@@ -1546,10 +1551,6 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                 return false;
             }
 
-            long updateSeq = this.updateSeq.incrementAndGet();
-
-            node2part.newUpdateSequence(updateSeq);
-
             boolean changed = false;
 
             if (cur == null || !cur.equals(parts))
@@ -1557,6 +1558,10 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             node2part.put(parts.nodeId(), parts);
 
+            this.updateSeq.setIfGreater(parts.updateSequence());
+
+            long updateSeq = this.updateSeq.incrementAndGet();
+
             // During exchange diff is calculated after all messages are received and affinity initialized.
             if (exchId == null && !grp.isReplicated()) {
                 if (readyTopVer.initialized() && readyTopVer.compareTo(diffFromAffinityVer) >= 0) {
@@ -2110,8 +2115,11 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
     /**
      * @param nodeId Node to remove.
+     * @param updateSeq Update sequence.
+     *
+     * @return Update sequence.
      */
-    private void removeNode(UUID nodeId) {
+    private long removeNode(UUID nodeId, long updateSeq) {
         assert nodeId != null;
         assert lock.isWriteLockedByCurrentThread();
 
@@ -2122,11 +2130,14 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
         ClusterNode loc = ctx.localNode();
 
         if (node2part != null) {
-            updateSeq.setIfGreater(node2part.updateSequence());
+            assert updateSeq >= node2part.updateSequence();
 
-            if (loc.equals(oldest) && !node2part.nodeId().equals(loc.id()))
-                node2part = new GridDhtPartitionFullMap(loc.id(), loc.order(), updateSeq.incrementAndGet(),
+            if (loc.equals(oldest) && !node2part.nodeId().equals(loc.id())) {
+                updateSeq++;
+
+                node2part = new GridDhtPartitionFullMap(loc.id(), loc.order(), updateSeq,
                     node2part, false);
+            }
             else
                 node2part = new GridDhtPartitionFullMap(node2part, node2part.updateSequence());
 
@@ -2145,6 +2156,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             consistencyCheck();
         }
+
+        return updateSeq;
     }
 
     /** {@inheritDoc} */


[05/16] ignite git commit: Increased test timeout.

Posted by ag...@apache.org.
Increased test timeout.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/82af72cb
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/82af72cb
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/82af72cb

Branch: refs/heads/master
Commit: 82af72cb9d9f783d1cc500de644bc3dc3120db16
Parents: 0647b03
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Tue Aug 22 16:40:02 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../processors/cache/CacheGroupsMetricsRebalanceTest.java       | 5 +++++
 1 file changed, 5 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/82af72cb/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
index a1a855a..a49ce61 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
@@ -67,6 +67,11 @@ public class CacheGroupsMetricsRebalanceTest extends GridCommonAbstractTest {
     }
 
     /** {@inheritDoc} */
+    @Override protected long getTestTimeout() {
+        return 10 * 60 * 1000;
+    }
+
+    /** {@inheritDoc} */
     @SuppressWarnings("unchecked")
     @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);


[16/16] ignite git commit: GG-12682 Restart cluster during snapshot RESTORE fails

Posted by ag...@apache.org.
GG-12682 Restart cluster during snapshot RESTORE fails

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/9614bc6f
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/9614bc6f
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/9614bc6f

Branch: refs/heads/master
Commit: 9614bc6fac8e26e27d2a71d8ac3b914388637c0c
Parents: 46cfe1b
Author: Eduard Shangareev <es...@gridgain.com>
Authored: Sun Aug 27 17:30:21 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../processors/cache/persistence/file/FilePageStoreManager.java   | 3 +++
 1 file changed, 3 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/9614bc6f/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
index 13bcd2a..d60151a 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
@@ -381,6 +381,9 @@ public class FilePageStoreManager extends GridCacheSharedManagerAdapter implemen
         return new CacheStoreHolder(idxStore, partStores);
     }
 
+    /**
+     * @param cacheWorkDir Cache work directory.
+     */
     private boolean checkAndInitCacheWorkDir(File cacheWorkDir) throws IgniteCheckedException {
         boolean dirExisted = false;
 


[03/16] ignite git commit: GG-12609: Fixed OOM at initiator during LIST

Posted by ag...@apache.org.
GG-12609: Fixed OOM at initiator during LIST

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/7ce00b13
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/7ce00b13
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/7ce00b13

Branch: refs/heads/master
Commit: 7ce00b13bfce1ca76431ba487a2b023952b748dc
Parents: 4564305
Author: Eduard Shangareev <es...@gridgain.com>
Authored: Sat Aug 26 17:01:46 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../tcp/internal/TcpDiscoveryNode.java          | 20 ++++++++++++++++++++
 1 file changed, 20 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/7ce00b13/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/TcpDiscoveryNode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/TcpDiscoveryNode.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/TcpDiscoveryNode.java
index 6882821..b2797a40 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/TcpDiscoveryNode.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/TcpDiscoveryNode.java
@@ -649,4 +649,24 @@ public class TcpDiscoveryNode extends GridMetadataAwareAdapter implements Cluste
     @Override public String toString() {
         return S.toString(TcpDiscoveryNode.class, this, "isClient", isClient());
     }
+
+    /**
+     * IMPORTANT!
+     * Only purpose of this constructor is creating node which contains only necessary data to store on disc
+     * @param node to copy data from
+     */
+    public TcpDiscoveryNode(
+        ClusterNode node
+    ) {
+        this.id = node.id();
+        this.consistentId = node.consistentId();
+        this.addrs = node.addresses();
+        this.hostNames = node.hostNames();
+        this.order = node.order();
+        this.ver = node.version();
+        this.daemon = node.isDaemon();
+        this.clientRouterNodeId = node.isClient() ? node.id() : null;
+
+        attrs = Collections.emptyMap();
+    }
 }


[04/16] ignite git commit: Fixed flaky test.

Posted by ag...@apache.org.
Fixed flaky test.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/0647b034
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/0647b034
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/0647b034

Branch: refs/heads/master
Commit: 0647b034742e0ba8094a8436a37538fcf1b4fa70
Parents: 8169c60
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Tue Aug 22 14:10:10 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../cache/GridCacheAbstractLocalStoreSelfTest.java | 17 ++++++++++++++++-
 1 file changed, 16 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/0647b034/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
index 328cde8..ac3bddb 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
@@ -48,9 +48,12 @@ import org.apache.ignite.configuration.NearCacheConfiguration;
 import org.apache.ignite.events.Event;
 import org.apache.ignite.events.EventType;
 import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
+import org.apache.ignite.internal.IgniteEx;
+import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
 import org.apache.ignite.internal.processors.cache.store.CacheLocalStore;
 import org.apache.ignite.internal.util.lang.GridAbsPredicate;
 import org.apache.ignite.internal.util.typedef.G;
+import org.apache.ignite.internal.util.typedef.internal.CU;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.lang.IgniteBiInClosure;
 import org.apache.ignite.lang.IgniteBiTuple;
@@ -290,7 +293,7 @@ public abstract class GridCacheAbstractLocalStoreSelfTest extends GridCommonAbst
      * @throws Exception If failed.
      */
     public void testBackupRestore() throws Exception {
-        Ignite ignite1 = startGrid(1);
+        final IgniteEx ignite1 = startGrid(1);
         Ignite ignite2 = startGrid(2);
 
         awaitPartitionMapExchange();
@@ -303,6 +306,18 @@ public abstract class GridCacheAbstractLocalStoreSelfTest extends GridCommonAbst
 
         final String name = BACKUP_CACHE_2;
 
+        assertTrue(GridTestUtils.waitForCondition(new GridAbsPredicate() {
+            @Override public boolean apply() {
+                AffinityTopologyVersion topVer = ignite1.context().cache().context().cacheContext(CU.cacheId(name))
+                    .affinity().affinityTopologyVersion();
+
+                return topVer.topologyVersion() == 2 && topVer.minorTopologyVersion() == 1;
+
+//                return ignite1.affinity(name).primaryPartitions(ignite1.cluster().localNode()).length <
+//                    ignite1.affinity(name).partitions();
+            }
+        }, 10_000));
+
         int key1 = -1;
         int key2 = -1;
 


[11/16] ignite git commit: Increment GridDhtPartitionMap update sequence when assign new state on coordinator.

Posted by ag...@apache.org.
Increment GridDhtPartitionMap update sequence when assign new state on coordinator.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/df4969b8
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/df4969b8
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/df4969b8

Branch: refs/heads/master
Commit: df4969b8641886fcc14c3259753ddbbd34cd666e
Parents: f8e7549
Author: sboikov <sb...@gridgain.com>
Authored: Fri Aug 25 17:50:01 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../dht/GridDhtPartitionTopologyImpl.java         | 18 ++++++++++++------
 .../IgnitePdsCacheRebalancingAbstractTest.java    |  2 ++
 2 files changed, 14 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/df4969b8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
index f25ae21..87b3670 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
@@ -1186,7 +1186,9 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
         lock.writeLock().lock();
 
         try {
-            if (stopping || !lastTopChangeVer.initialized())
+            if (stopping || !lastTopChangeVer.initialized() ||
+                // Ignore message not-related to exchange if exchange is in progress.
+                (exchangeVer == null && !lastTopChangeVer.equals(readyTopVer)))
                 return false;
 
             if (incomeCntrMap != null) {
@@ -1909,20 +1911,24 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
             }
 
             for (Map.Entry<UUID, GridDhtPartitionMap> e : node2part.entrySet()) {
-                if (!e.getValue().containsKey(p))
+                GridDhtPartitionMap partMap = e.getValue();
+
+                if (!partMap.containsKey(p))
                     continue;
 
-                if (e.getValue().get(p) == OWNING && !owners.contains(e.getKey())) {
+                if (partMap.get(p) == OWNING && !owners.contains(e.getKey())) {
                     if (haveHistory)
-                        e.getValue().put(p, MOVING);
+                        partMap.put(p, MOVING);
                     else {
-                        e.getValue().put(p, RENTING);
+                        partMap.put(p, RENTING);
 
                         result.add(e.getKey());
                     }
 
+                    partMap.updateSequence(partMap.updateSequence() + 1, partMap.topologyVersion());
+
                     U.warn(log, "Partition has been scheduled for rebalancing due to outdated update counter " +
-                        "[nodeId=" + ctx.localNodeId() + ", cacheOrGroupName=" + grp.cacheOrGroupName() +
+                        "[nodeId=" + e.getKey() + ", cacheOrGroupName=" + grp.cacheOrGroupName() +
                         ", partId=" + p + ", haveHistory=" + haveHistory + "]");
                 }
             }

http://git-wip-us.apache.org/repos/asf/ignite/blob/df4969b8/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
index 91838fc..7b047f8 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
@@ -512,6 +512,8 @@ public abstract class IgnitePdsCacheRebalancingAbstractTest extends GridCommonAb
         Integer val = 0;
 
         for (int i = 0; i < 5; i++) {
+            info("Iteration: " + i);
+
             Integer key = primaryKey(ignite(3).cache(cacheName));
 
             c.put(key, val);


[10/16] ignite git commit: Added test for rebalance after restart.

Posted by ag...@apache.org.
Added test for rebalance after restart.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/f8e75498
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/f8e75498
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/f8e75498

Branch: refs/heads/master
Commit: f8e754980524d15ab9f491381b8af259f1e09bb4
Parents: 2f56406
Author: sboikov <sb...@gridgain.com>
Authored: Fri Aug 25 16:59:02 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../IgnitePdsCacheRebalancingAbstractTest.java  | 37 ++++++++++++++++++++
 1 file changed, 37 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/f8e75498/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
index 2f43951..91838fc 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
@@ -498,6 +498,43 @@ public abstract class IgnitePdsCacheRebalancingAbstractTest extends GridCommonAb
     }
 
     /**
+     * @throws Exception If failed.
+     */
+    public void testForceRebalance() throws Exception {
+        final Ignite ig = startGrids(4);
+
+        ig.active(true);
+
+        awaitPartitionMapExchange();
+
+        IgniteCache<Object, Object> c = ig.cache(cacheName);
+
+        Integer val = 0;
+
+        for (int i = 0; i < 5; i++) {
+            Integer key = primaryKey(ignite(3).cache(cacheName));
+
+            c.put(key, val);
+
+            stopGrid(3);
+
+            val++;
+
+            c.put(key, val);
+
+            assertEquals(val, c.get(key));
+
+            startGrid(3);
+
+            awaitPartitionMapExchange();
+
+            Object val0 = ignite(3).cache(cacheName).get(key);
+
+            assertEquals(val, val0);
+        }
+    }
+
+    /**
      * @throws Exception If failed
      */
     public void testPartitionCounterConsistencyOnUnstableTopology() throws Exception {


[09/16] ignite git commit: Fixed test.

Posted by ag...@apache.org.
Fixed test.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/2f56406b
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/2f56406b
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/2f56406b

Branch: refs/heads/master
Commit: 2f56406b6ca3ab6a321b665a096e7437228c47e6
Parents: 86cfe11
Author: Dmitriy Govorukhin <dg...@gridgain.com>
Authored: Thu Aug 24 15:58:27 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../cluster/GridClusterStateProcessor.java      |  2 +-
 .../IgnitePdsCacheRebalancingAbstractTest.java  |  3 +-
 .../wal/IgniteWalHistoryReservationsTest.java   | 70 +++++++++++++++++---
 3 files changed, 62 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/2f56406b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
index cdfab21..64ee472 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
@@ -430,7 +430,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter {
 
         GridChangeGlobalStateFuture fut = stateChangeFut.get();
 
-        while (fut == null) {
+        while (fut == null || fut.isDone()) {
             fut = new GridChangeGlobalStateFuture(UUID.randomUUID(), activate, ctx);
 
             if (stateChangeFut.compareAndSet(null, fut)) {

http://git-wip-us.apache.org/repos/asf/ignite/blob/2f56406b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
index 9ceb87c..2f43951 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
@@ -558,9 +558,8 @@ public abstract class IgnitePdsCacheRebalancingAbstractTest extends GridCommonAb
                         cntrs.put(part.id(), part.updateCounter());
                 }
 
-                for (int k0 = 0; k0 < k; k0++) {
+                for (int k0 = 0; k0 < k; k0++)
                     assertEquals(String.valueOf(k0), k0, ig0.cache(cacheName).get(k0));
-                }
             }
 
             assertEquals(ig.affinity(cacheName).partitions(), cntrs.size());

http://git-wip-us.apache.org/repos/asf/ignite/blob/2f56406b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalHistoryReservationsTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalHistoryReservationsTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalHistoryReservationsTest.java
index 4bea63f..94045ff 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalHistoryReservationsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalHistoryReservationsTest.java
@@ -22,6 +22,7 @@ import java.util.concurrent.locks.Lock;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.IgniteDataStreamer;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.cache.CacheWriteSynchronizationMode;
 import org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction;
@@ -57,8 +58,14 @@ public class IgniteWalHistoryReservationsTest extends GridCommonAbstractTest {
 
         MemoryConfiguration memCfg = new MemoryConfiguration();
 
-        memCfg.setMemoryPolicies(new MemoryPolicyConfiguration().setInitialSize(200 * 1024 * 1024)
-            .setMaxSize(200 * 1024 * 1024).setName("dfltMemPlc"));
+        long memSize = 200L * 1024L * 1024L;
+
+        memCfg.setMemoryPolicies(
+            new MemoryPolicyConfiguration()
+                .setInitialSize(memSize)
+                .setMaxSize(memSize)
+                .setName("dfltMemPlc")
+        );
 
         memCfg.setDefaultMemoryPolicyName("dfltMemPlc");
 
@@ -110,24 +117,59 @@ public class IgniteWalHistoryReservationsTest extends GridCommonAbstractTest {
 
         ig0.active(true);
 
-        IgniteCache<Object, Object> cache = ig0.cache("cache1");
+        long start = U.currentTimeMillis();
 
-        for (int k = 0; k < entryCnt; k++)
-            cache.put(k, k);
+        log.warning("Start loading");
+
+        try (IgniteDataStreamer<Object, Object> st = ig0.dataStreamer("cache1")){
+            for (int k = 0; k < entryCnt; k++){
+                st.addData(k, k);
+
+                printProgress(k);
+            }
+        }
+
+        log.warning("Finish loading time:" + (U.currentTimeMillis() - start));
 
         forceCheckpoint();
 
-        for (int k = 0; k < entryCnt; k++)
-            cache.put(k, k * 2);
+        start = U.currentTimeMillis();
+
+        log.warning("Start loading");
+
+        try (IgniteDataStreamer<Object, Object> st = ig0.dataStreamer("cache1")) {
+            st.allowOverwrite(true);
+
+            for (int k = 0; k < entryCnt; k++) {
+                st.addData(k, k * 2);
+
+                printProgress(k);
+            }
+        }
+
+        log.warning("Finish loading time:" + (U.currentTimeMillis() - start));
 
         forceCheckpoint();
 
-        for (int k = 0; k < entryCnt; k++)
-            cache.put(k, k);
+        start = U.currentTimeMillis();
+
+        log.warning("Start loading");
+
+        try (IgniteDataStreamer<Object, Object> st = ig0.dataStreamer("cache1")){
+            st.allowOverwrite(true);
+
+            for (int k = 0; k < entryCnt; k++){
+                st.addData(k, k);
+
+                printProgress(k);
+            }
+        }
+
+        log.warning("Finish loading time:" + (U.currentTimeMillis() - start));
 
         forceCheckpoint();
 
-        Lock lock = cache.lock(0);
+        Lock lock = ig0.cache("cache1").lock(0);
 
         lock.lock();
 
@@ -195,6 +237,14 @@ public class IgniteWalHistoryReservationsTest extends GridCommonAbstractTest {
     }
 
     /**
+     *
+     */
+    private void printProgress(int k){
+        if (k % 1000 == 0)
+            log.warning("Keys -> " + k);
+    }
+
+    /**
      * @throws Exception If failed.
      */
     public void testRemovesArePreloadedIfHistoryIsAvailable() throws Exception {


[08/16] ignite git commit: Muted hanging test.

Posted by ag...@apache.org.
Muted hanging test.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/86cfe113
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/86cfe113
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/86cfe113

Branch: refs/heads/master
Commit: 86cfe11382782ad268461318ea5765a5c2965721
Parents: 678fb30
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Wed Aug 23 12:18:44 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../GridCachePartitionEvictionDuringReadThroughSelfTest.java       | 2 ++
 1 file changed, 2 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/86cfe113/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
index 5a9e86a..01316f6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
@@ -84,6 +84,8 @@ public class GridCachePartitionEvictionDuringReadThroughSelfTest extends GridCom
      * @throws Exception if failed.
      */
     public void testPartitionRent() throws Exception {
+        fail("https://issues.apache.org/jira/browse/IGNITE-5759");
+
         startGrid(DATA_READ_GRID_IDX);
 
         final AtomicBoolean done = new AtomicBoolean();


[15/16] ignite git commit: gg-12688 : Fixed updateSequence in ClientTopology.

Posted by ag...@apache.org.
gg-12688 : Fixed updateSequence in ClientTopology.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/f589cc84
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/f589cc84
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/f589cc84

Branch: refs/heads/master
Commit: f589cc847e3f0af8c90b519b26c0818f9cee2822
Parents: c6b7011
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Mon Aug 28 20:31:18 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../dht/GridClientPartitionTopology.java        | 18 +++++---
 .../GridDhtPartitionsExchangeFuture.java        | 15 +++++--
 .../IgnitePdsCacheRebalancingAbstractTest.java  | 44 +++++++++++++++++++-
 3 files changed, 66 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/f589cc84/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridClientPartitionTopology.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridClientPartitionTopology.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridClientPartitionTopology.java
index c8856fd..299394f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridClientPartitionTopology.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridClientPartitionTopology.java
@@ -1092,20 +1092,26 @@ public class GridClientPartitionTopology implements GridDhtPartitionTopology {
 
         try {
             for (Map.Entry<UUID, GridDhtPartitionMap> e : node2part.entrySet()) {
-                if (!e.getValue().containsKey(p))
+                GridDhtPartitionMap partMap = e.getValue();
+
+                if (!partMap.containsKey(p))
                     continue;
 
-                if (e.getValue().get(p) == OWNING && !owners.contains(e.getKey())) {
+                if (partMap.get(p) == OWNING && !owners.contains(e.getKey())) {
                     if (haveHistory)
-                        e.getValue().put(p, MOVING);
+                        partMap.put(p, MOVING);
                     else {
-                        e.getValue().put(p, RENTING);
+                        partMap.put(p, RENTING);
 
                         result.add(e.getKey());
                     }
+
+                    partMap.updateSequence(partMap.updateSequence() + 1, partMap.topologyVersion());
+
+                    U.warn(log, "Partition has been scheduled for rebalancing due to outdated update counter " +
+                        "[nodeId=" + e.getKey() + ", groupId=" + grpId +
+                        ", partId=" + p + ", haveHistory=" + haveHistory + "]");
                 }
-                else if (owners.contains(e.getKey()))
-                    e.getValue().put(p, OWNING);
             }
 
             part2node.put(p, owners);

http://git-wip-us.apache.org/repos/asf/ignite/blob/f589cc84/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
index 299284d..240b5f0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
@@ -2437,11 +2437,20 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
      */
     private void assignPartitionsStates() {
         if (cctx.database().persistenceEnabled()) {
-            for (CacheGroupContext grp : cctx.cache().cacheGroups()) {
-                if (grp.isLocal())
+            for (Map.Entry<Integer, CacheGroupDescriptor> e : cctx.affinity().cacheGroups().entrySet()) {
+                if (e.getValue().config().getCacheMode() == CacheMode.LOCAL)
                     continue;
 
-                assignPartitionStates(grp.topology());
+                GridDhtPartitionTopology top;
+
+                CacheGroupContext grpCtx = cctx.cache().cacheGroup(e.getKey());
+
+                if (grpCtx != null)
+                    top = grpCtx.topology();
+                else
+                    top = cctx.exchange().clientTopology(e.getKey());
+
+                assignPartitionStates(top);
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/ignite/blob/f589cc84/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
index 7b047f8..2d237cb 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheRebalancingAbstractTest.java
@@ -35,6 +35,7 @@ import org.apache.ignite.cache.CacheWriteSynchronizationMode;
 import org.apache.ignite.cache.PartitionLossPolicy;
 import org.apache.ignite.cache.QueryEntity;
 import org.apache.ignite.cache.QueryIndex;
+import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.configuration.MemoryConfiguration;
@@ -46,6 +47,7 @@ import org.apache.ignite.internal.IgniteInternalFuture;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtLocalPartition;
 import org.apache.ignite.internal.util.typedef.G;
 import org.apache.ignite.internal.util.typedef.internal.U;
+import org.apache.ignite.lang.IgnitePredicate;
 import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
@@ -96,7 +98,19 @@ public abstract class IgnitePdsCacheRebalancingAbstractTest extends GridCommonAb
 
         ccfg2.setQueryEntities(Collections.singleton(qryEntity));
 
-        cfg.setCacheConfiguration(ccfg1, ccfg2);
+        // Do not start filtered cache on coordinator.
+        if (gridName.endsWith("0")) {
+            cfg.setCacheConfiguration(ccfg1, ccfg2);
+        }
+        else {
+            CacheConfiguration ccfg3 = cacheConfiguration("filtered");
+            ccfg3.setPartitionLossPolicy(PartitionLossPolicy.READ_ONLY_SAFE);
+            ccfg3.setBackups(1);
+            ccfg3.setWriteSynchronizationMode(CacheWriteSynchronizationMode.FULL_SYNC);
+            ccfg3.setNodeFilter(new CoordinatorNodeFilter());
+
+            cfg.setCacheConfiguration(ccfg1, ccfg2, ccfg3);
+        }
 
         MemoryConfiguration memCfg = new MemoryConfiguration();
 
@@ -501,7 +515,23 @@ public abstract class IgnitePdsCacheRebalancingAbstractTest extends GridCommonAb
      * @throws Exception If failed.
      */
     public void testForceRebalance() throws Exception {
-        final Ignite ig = startGrids(4);
+        testForceRebalance(cacheName);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testForceRebalanceClientTopology() throws Exception {
+        testForceRebalance("filtered");
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    private void testForceRebalance(String cacheName) throws Exception {
+        startGrids(4);
+
+        final Ignite ig = grid(1);
 
         ig.active(true);
 
@@ -653,4 +683,14 @@ public abstract class IgnitePdsCacheRebalancingAbstractTest extends GridCommonAb
                 '}';
         }
     }
+
+    /**
+     *
+     */
+    private static class CoordinatorNodeFilter implements IgnitePredicate<ClusterNode> {
+        /** {@inheritDoc} */
+        @Override public boolean apply(ClusterNode node) {
+            return node.order() > 1;
+        }
+    }
 }


[02/16] ignite git commit: Fixed update sequence.

Posted by ag...@apache.org.
Fixed update sequence.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/c6b70114
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/c6b70114
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/c6b70114

Branch: refs/heads/master
Commit: c6b70114dedd840360b858d11ed9ec3dc9993d12
Parents: 9614bc6
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Mon Aug 28 14:58:50 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../dht/GridDhtPartitionTopologyImpl.java       | 59 +++++++++-----------
 1 file changed, 25 insertions(+), 34 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/c6b70114/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
index e0f54b3..f7f71a1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
@@ -521,7 +521,7 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                             DiscoveryEvent evt = evts0.get(i);
 
                             if (ExchangeDiscoveryEvents.serverLeftEvent(evt))
-                                updateSeq = removeNode(evt.eventNode().id(), updateSeq);
+                                removeNode(evt.eventNode().id());
                         }
                     }
 
@@ -1243,6 +1243,9 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                                 ", curPart=" + mapString(part) +
                                 ", newPart=" + mapString(newPart) + ']');
                         }
+
+                        if (newPart.nodeId().equals(ctx.localNodeId()))
+                            updateSeq.setIfGreater(newPart.updateSequence());
                     }
                     else {
                         // If for some nodes current partition has a newer map,
@@ -1272,6 +1275,12 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                     }
                 }
             }
+            else {
+                GridDhtPartitionMap locNodeMap = partMap.get(ctx.localNodeId());
+
+                if (locNodeMap != null)
+                    updateSeq.setIfGreater(locNodeMap.updateSequence());
+            }
 
             if (!fullMapUpdated) {
                 if (log.isDebugEnabled()) {
@@ -1379,8 +1388,6 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             long updateSeq = this.updateSeq.incrementAndGet();
 
-            node2part.newUpdateSequence(updateSeq);
-
             if (readyTopVer.initialized() && readyTopVer.equals(lastTopChangeVer)) {
                 AffinityAssignment  aff = grp.affinity().readyAffinity(readyTopVer);
 
@@ -1537,11 +1544,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
             GridDhtPartitionMap cur = node2part.get(parts.nodeId());
 
             if (force) {
-                if (cur != null && cur.topologyVersion().initialized()) {
+                if (cur != null && cur.topologyVersion().initialized())
                     parts.updateSequence(cur.updateSequence(), cur.topologyVersion());
-
-                    this.updateSeq.setIfGreater(cur.updateSequence());
-                }
             }
             else  if (isStaleUpdate(cur, parts)) {
                 U.warn(log, "Stale update for single partition map update (will ignore) [exchId=" + exchId +
@@ -1551,6 +1555,10 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                 return false;
             }
 
+            long updateSeq = this.updateSeq.incrementAndGet();
+
+            node2part.newUpdateSequence(updateSeq);
+
             boolean changed = false;
 
             if (cur == null || !cur.equals(parts))
@@ -1558,10 +1566,6 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             node2part.put(parts.nodeId(), parts);
 
-            this.updateSeq.setIfGreater(parts.updateSequence());
-
-            long updateSeq = this.updateSeq.incrementAndGet();
-
             // During exchange diff is calculated after all messages are received and affinity initialized.
             if (exchId == null && !grp.isReplicated()) {
                 if (readyTopVer.initialized() && readyTopVer.compareTo(diffFromAffinityVer) >= 0) {
@@ -1915,14 +1919,6 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                 }
             }
 
-            long seqVal = 0;
-
-            if (updateSeq) {
-                seqVal = this.updateSeq.incrementAndGet();
-
-                node2part = new GridDhtPartitionFullMap(node2part, seqVal);
-            }
-
             for (Map.Entry<UUID, GridDhtPartitionMap> e : node2part.entrySet()) {
                 GridDhtPartitionMap partMap = e.getValue();
 
@@ -1938,14 +1934,19 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                         result.add(e.getKey());
                     }
 
-                    if (updateSeq)
-                        partMap.updateSequence(seqVal, partMap.topologyVersion());
+                    partMap.updateSequence(partMap.updateSequence() + 1, partMap.topologyVersion());
+
+                    if (partMap.nodeId().equals(ctx.localNodeId()))
+                        this.updateSeq.setIfGreater(partMap.updateSequence());
 
                     U.warn(log, "Partition has been scheduled for rebalancing due to outdated update counter " +
                         "[nodeId=" + e.getKey() + ", cacheOrGroupName=" + grp.cacheOrGroupName() +
                         ", partId=" + p + ", haveHistory=" + haveHistory + "]");
                 }
             }
+
+            if (updateSeq)
+                node2part = new GridDhtPartitionFullMap(node2part, this.updateSeq.incrementAndGet());
         }
         finally {
             lock.writeLock().unlock();
@@ -2115,11 +2116,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
     /**
      * @param nodeId Node to remove.
-     * @param updateSeq Update sequence.
-     *
-     * @return Update sequence.
      */
-    private long removeNode(UUID nodeId, long updateSeq) {
+    private void removeNode(UUID nodeId) {
         assert nodeId != null;
         assert lock.isWriteLockedByCurrentThread();
 
@@ -2130,14 +2128,9 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
         ClusterNode loc = ctx.localNode();
 
         if (node2part != null) {
-            assert updateSeq >= node2part.updateSequence();
-
-            if (loc.equals(oldest) && !node2part.nodeId().equals(loc.id())) {
-                updateSeq++;
-
-                node2part = new GridDhtPartitionFullMap(loc.id(), loc.order(), updateSeq,
+            if (loc.equals(oldest) && !node2part.nodeId().equals(loc.id()))
+                node2part = new GridDhtPartitionFullMap(loc.id(), loc.order(), updateSeq.get(),
                     node2part, false);
-            }
             else
                 node2part = new GridDhtPartitionFullMap(node2part, node2part.updateSequence());
 
@@ -2156,8 +2149,6 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             consistencyCheck();
         }
-
-        return updateSeq;
     }
 
     /** {@inheritDoc} */


[13/16] ignite git commit: Fixed update sequence.

Posted by ag...@apache.org.
Fixed update sequence.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/45643050
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/45643050
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/45643050

Branch: refs/heads/master
Commit: 45643050b8f298b87afe7bf1f1ba5de1d3156254
Parents: df4969b
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Fri Aug 25 21:23:19 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../distributed/dht/GridDhtPartitionTopologyImpl.java | 14 ++++++++++----
 1 file changed, 10 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/45643050/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
index 87b3670..a881130 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtPartitionTopologyImpl.java
@@ -1910,6 +1910,14 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                 }
             }
 
+            long seqVal = 0;
+
+            if (updateSeq) {
+                seqVal = this.updateSeq.incrementAndGet();
+
+                node2part = new GridDhtPartitionFullMap(node2part, seqVal);
+            }
+
             for (Map.Entry<UUID, GridDhtPartitionMap> e : node2part.entrySet()) {
                 GridDhtPartitionMap partMap = e.getValue();
 
@@ -1925,16 +1933,14 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                         result.add(e.getKey());
                     }
 
-                    partMap.updateSequence(partMap.updateSequence() + 1, partMap.topologyVersion());
+                    if (updateSeq)
+                        partMap.updateSequence(seqVal, partMap.topologyVersion());
 
                     U.warn(log, "Partition has been scheduled for rebalancing due to outdated update counter " +
                         "[nodeId=" + e.getKey() + ", cacheOrGroupName=" + grp.cacheOrGroupName() +
                         ", partId=" + p + ", haveHistory=" + haveHistory + "]");
                 }
             }
-
-            if (updateSeq)
-                node2part = new GridDhtPartitionFullMap(node2part, this.updateSeq.incrementAndGet());
         }
         finally {
             lock.writeLock().unlock();


[07/16] ignite git commit: IGNITE-6155 added new jvm flag for printing gc date stamps

Posted by ag...@apache.org.
IGNITE-6155 added new jvm flag for printing gc date stamps

(cherry picked from commit 03211d2)
Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/678fb300
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/678fb300
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/678fb300

Branch: refs/heads/master
Commit: 678fb300a893703c05e96c9969b39d3b95e43626
Parents: 82af72c
Author: oleg-ostanin <oo...@gridgain.com>
Authored: Tue Aug 22 16:39:31 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 modules/yardstick/config/benchmark-bin-identity.properties        | 1 +
 modules/yardstick/config/benchmark-cache-load.properties          | 1 +
 modules/yardstick/config/benchmark-client-mode.properties         | 1 +
 modules/yardstick/config/benchmark-failover.properties            | 1 +
 modules/yardstick/config/benchmark-full.properties                | 1 +
 modules/yardstick/config/benchmark-h2.properties                  | 1 +
 modules/yardstick/config/benchmark-multicast.properties           | 1 +
 modules/yardstick/config/benchmark-mysql.properties               | 1 +
 modules/yardstick/config/benchmark-pgsql.properties               | 1 +
 modules/yardstick/config/benchmark-put-indexed-val.properties     | 1 +
 modules/yardstick/config/benchmark-query-put-separated.properties | 1 +
 modules/yardstick/config/benchmark-query.properties               | 1 +
 modules/yardstick/config/benchmark-remote.properties              | 1 +
 modules/yardstick/config/benchmark-sql-dml.properties             | 1 +
 modules/yardstick/config/benchmark-store.properties               | 1 +
 modules/yardstick/config/benchmark.properties                     | 1 +
 16 files changed, 16 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-bin-identity.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-bin-identity.properties b/modules/yardstick/config/benchmark-bin-identity.properties
index d5d18b6..426802f 100644
--- a/modules/yardstick/config/benchmark-bin-identity.properties
+++ b/modules/yardstick/config/benchmark-bin-identity.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-cache-load.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-cache-load.properties b/modules/yardstick/config/benchmark-cache-load.properties
index c055694..f5463da 100644
--- a/modules/yardstick/config/benchmark-cache-load.properties
+++ b/modules/yardstick/config/benchmark-cache-load.properties
@@ -28,6 +28,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-client-mode.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-client-mode.properties b/modules/yardstick/config/benchmark-client-mode.properties
index 923c96a..85e0246 100644
--- a/modules/yardstick/config/benchmark-client-mode.properties
+++ b/modules/yardstick/config/benchmark-client-mode.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 #Ignite version
 ver="RELEASE-"

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-failover.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-failover.properties b/modules/yardstick/config/benchmark-failover.properties
index a1b9d8f..e53792b 100644
--- a/modules/yardstick/config/benchmark-failover.properties
+++ b/modules/yardstick/config/benchmark-failover.properties
@@ -34,6 +34,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-full.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-full.properties b/modules/yardstick/config/benchmark-full.properties
index 96da0a6..59d6fe7 100644
--- a/modules/yardstick/config/benchmark-full.properties
+++ b/modules/yardstick/config/benchmark-full.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-h2.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-h2.properties b/modules/yardstick/config/benchmark-h2.properties
index 6723344..5426071 100644
--- a/modules/yardstick/config/benchmark-h2.properties
+++ b/modules/yardstick/config/benchmark-h2.properties
@@ -28,6 +28,7 @@ JVM_OPTS=${JVM_OPTS}" -DIGNITE_QUIET=false \
   -XX:SurvivorRatio=1024 \
   -XX:+UseCMSInitiatingOccupancyOnly \
   -XX:CMSInitiatingOccupancyFraction=60 \
+  -XX:+PrintGCDateStamps \
 "
 
 H2_PARAMS="-jdbcDrv org.h2.Driver -jdbc jdbc:h2:tcp://127.0.0.1/${SCRIPT_DIR}/../work/h2benchmark -sch ${SCRIPT_DIR}/../config/h2-schema.sql"

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-multicast.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-multicast.properties b/modules/yardstick/config/benchmark-multicast.properties
index 5071a11..cc07921 100644
--- a/modules/yardstick/config/benchmark-multicast.properties
+++ b/modules/yardstick/config/benchmark-multicast.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-mysql.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-mysql.properties b/modules/yardstick/config/benchmark-mysql.properties
index c1fe393..e6dbee2 100644
--- a/modules/yardstick/config/benchmark-mysql.properties
+++ b/modules/yardstick/config/benchmark-mysql.properties
@@ -28,6 +28,7 @@ JVM_OPTS=${JVM_OPTS}" -DIGNITE_QUIET=false \
   -XX:SurvivorRatio=1024 \
   -XX:+UseCMSInitiatingOccupancyOnly \
   -XX:CMSInitiatingOccupancyFraction=60 \
+  -XX:+PrintGCDateStamps \
 "
 
 MYSQL_PARAMS="-jdbcDrv com.mysql.jdbc.Driver -jdbc jdbc:mysql://127.0.0.1/?user=root\\&password=1\\&rewriteBatchedStatements=true -tempDb -sch ${SCRIPT_DIR}/../config/mysql-schema.sql"

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-pgsql.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-pgsql.properties b/modules/yardstick/config/benchmark-pgsql.properties
index 31ad775..3a7ac64 100644
--- a/modules/yardstick/config/benchmark-pgsql.properties
+++ b/modules/yardstick/config/benchmark-pgsql.properties
@@ -28,6 +28,7 @@ JVM_OPTS=${JVM_OPTS}" -DIGNITE_QUIET=false \
   -XX:SurvivorRatio=1024 \
   -XX:+UseCMSInitiatingOccupancyOnly \
   -XX:CMSInitiatingOccupancyFraction=60 \
+  -XX:+PrintGCDateStamps \
 "
 
 # Warning: database must be created and specified in URL explicitly, and there's no other way around as long as driver does not support changing DB in runtime

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-put-indexed-val.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-put-indexed-val.properties b/modules/yardstick/config/benchmark-put-indexed-val.properties
index a2bc956..a8d530b 100644
--- a/modules/yardstick/config/benchmark-put-indexed-val.properties
+++ b/modules/yardstick/config/benchmark-put-indexed-val.properties
@@ -29,6 +29,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-query-put-separated.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query-put-separated.properties b/modules/yardstick/config/benchmark-query-put-separated.properties
index b4437bf..c2684a1 100644
--- a/modules/yardstick/config/benchmark-query-put-separated.properties
+++ b/modules/yardstick/config/benchmark-query-put-separated.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-query.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query.properties b/modules/yardstick/config/benchmark-query.properties
index 2612ec9..ee88beb 100644
--- a/modules/yardstick/config/benchmark-query.properties
+++ b/modules/yardstick/config/benchmark-query.properties
@@ -29,6 +29,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-remote.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-remote.properties b/modules/yardstick/config/benchmark-remote.properties
index 4d671d3..e9fde52 100644
--- a/modules/yardstick/config/benchmark-remote.properties
+++ b/modules/yardstick/config/benchmark-remote.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-sql-dml.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-sql-dml.properties b/modules/yardstick/config/benchmark-sql-dml.properties
index 3bb4107..119d7da 100644
--- a/modules/yardstick/config/benchmark-sql-dml.properties
+++ b/modules/yardstick/config/benchmark-sql-dml.properties
@@ -29,6 +29,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark-store.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-store.properties b/modules/yardstick/config/benchmark-store.properties
index 3146c24..a24e65d 100644
--- a/modules/yardstick/config/benchmark-store.properties
+++ b/modules/yardstick/config/benchmark-store.properties
@@ -33,6 +33,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version

http://git-wip-us.apache.org/repos/asf/ignite/blob/678fb300/modules/yardstick/config/benchmark.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark.properties b/modules/yardstick/config/benchmark.properties
index 2dd51eb..96a11d1 100644
--- a/modules/yardstick/config/benchmark.properties
+++ b/modules/yardstick/config/benchmark.properties
@@ -31,6 +31,7 @@ JVM_OPTS=${JVM_OPTS}" \
 -verbose:gc \
 -XX:+UseParNewGC \
 -XX:+UseConcMarkSweepGC \
+-XX:+PrintGCDateStamps \
 "
 
 #Ignite version


[06/16] ignite git commit: Fixed javadoc format.

Posted by ag...@apache.org.
Fixed javadoc format.

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/8169c60b
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/8169c60b
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/8169c60b

Branch: refs/heads/master
Commit: 8169c60b4db41cd085d3a17f2e76d0ce189a42bd
Parents: 7b28da7
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Tue Aug 22 11:50:35 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../cache/distributed/near/GridNearTxPrepareRequest.java           | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/8169c60b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareRequest.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareRequest.java
index 7deceb5..e352c87 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareRequest.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareRequest.java
@@ -100,7 +100,7 @@ public class GridNearTxPrepareRequest extends GridDistributedTxPrepareRequest {
      * @param subjId Subject ID.
      * @param taskNameHash Task name hash.
      * @param firstClientReq {@code True} if first optimistic tx prepare request sent from client node.
-     * @param {@code True} if it is safe for first client request to wait for topology future.
+     * @param allowWaitTopFut {@code True} if it is safe for first client request to wait for topology future.
      * @param addDepInfo Deployment info flag.
      */
     public GridNearTxPrepareRequest(


[14/16] ignite git commit: IGNITE-6124: fix for lastVer field on GridDhtPartitionsSingleMessage message

Posted by ag...@apache.org.
IGNITE-6124: fix for lastVer field on GridDhtPartitionsSingleMessage message

Signed-off-by: Andrey Gura <ag...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/46cfe1b7
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/46cfe1b7
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/46cfe1b7

Branch: refs/heads/master
Commit: 46cfe1b79062cec4ffd7f414e82dacf0ce01dd10
Parents: 78b7e3f
Author: Sergey Chugunov <se...@gmail.com>
Authored: Sat Aug 26 21:44:13 2017 +0300
Committer: Andrey Gura <ag...@apache.org>
Committed: Tue Aug 29 17:32:04 2017 +0300

----------------------------------------------------------------------
 .../distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/46cfe1b7/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
index 6decb44..299284d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
@@ -1227,7 +1227,7 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
         if (cctx.kernalContext().clientNode()) {
             msg = new GridDhtPartitionsSingleMessage(exchangeId(),
                 true,
-                null,
+                cctx.versions().last(),
                 true);
         }
         else {