You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2015/09/24 15:13:17 UTC

[01/10] ignite git commit: Added test.

Repository: ignite
Updated Branches:
  refs/heads/ignite-808 7aaeecbd4 -> 7d96b53a4


Added test.


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

Branch: refs/heads/ignite-808
Commit: 4b0c029cef4b351f0d389a171c30b7dcf8c1ca22
Parents: b56b15c
Author: sboikov <sb...@gridgain.com>
Authored: Thu Sep 24 12:19:28 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Sep 24 12:19:28 2015 +0300

----------------------------------------------------------------------
 .../near/NearCacheMultithreadedUpdateTest.java  | 217 +++++++++++++++++++
 1 file changed, 217 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/4b0c029c/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/NearCacheMultithreadedUpdateTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/NearCacheMultithreadedUpdateTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/NearCacheMultithreadedUpdateTest.java
new file mode 100644
index 0000000..9d92724
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/NearCacheMultithreadedUpdateTest.java
@@ -0,0 +1,217 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.cache.distributed.near;
+
+import java.util.concurrent.Callable;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.atomic.AtomicInteger;
+import org.apache.ignite.Ignite;
+import org.apache.ignite.IgniteCache;
+import org.apache.ignite.cache.CacheAtomicityMode;
+import org.apache.ignite.configuration.CacheConfiguration;
+import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.configuration.NearCacheConfiguration;
+import org.apache.ignite.internal.IgniteInternalFuture;
+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;
+import org.apache.ignite.testframework.GridTestUtils;
+import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+
+import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
+import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
+import static org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC;
+
+/**
+ *
+ */
+public class NearCacheMultithreadedUpdateTest extends GridCommonAbstractTest {
+    /** */
+    private static TcpDiscoveryIpFinder ipFinder = new TcpDiscoveryVmIpFinder(true);
+
+    /** */
+    private boolean client;
+
+    /** */
+    private final int SRV_CNT = 3;
+
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        ((TcpDiscoverySpi)cfg.getDiscoverySpi()).setIpFinder(ipFinder);
+
+        cfg.setClientMode(client);
+
+        return cfg;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void beforeTestsStarted() throws Exception {
+        super.beforeTestsStarted();
+
+        startGridsMultiThreaded(SRV_CNT);
+
+        client = true;
+
+        startGrid(SRV_CNT);
+
+        client = false;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void afterTestsStopped() throws Exception {
+        super.afterTestsStopped();
+
+        stopAllGrids();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testUpdateMultithreadedTx() throws Exception {
+        updateMultithreaded(TRANSACTIONAL, false);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testUpdateMultithreadedTxRestart() throws Exception {
+        updateMultithreaded(TRANSACTIONAL, true);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testUpdateMultithreadedAtomic() throws Exception {
+        updateMultithreaded(ATOMIC, false);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testUpdateMultithreadedAtomicRestart() throws Exception {
+        updateMultithreaded(ATOMIC, true);
+    }
+
+    /**
+     * @param atomicityMode Cache atomicity mode.
+     * @param restart If {@code true} restarts one node.
+     * @throws Exception If failed.
+     */
+    private void updateMultithreaded(CacheAtomicityMode atomicityMode, boolean restart) throws Exception {
+        Ignite srv = ignite(0);
+
+        srv.destroyCache(null);
+
+        IgniteCache<Integer, Integer> srvCache = srv.createCache(cacheConfiguration(atomicityMode));
+
+        Ignite client = ignite(SRV_CNT);
+
+        assertTrue(client.configuration().isClientMode());
+
+        final IgniteCache<Integer, Integer> clientCache =
+            client.createNearCache(null, new NearCacheConfiguration<Integer, Integer>());
+
+        final AtomicBoolean stop = new AtomicBoolean();
+
+        IgniteInternalFuture<?> restartFut = null;
+
+        // Primary key for restarted node.
+        final Integer key0 = primaryKey(ignite(SRV_CNT - 1).cache(null));
+
+        if (restart) {
+            restartFut = GridTestUtils.runAsync(new Callable<Void>() {
+                @Override public Void call() throws Exception {
+                    while (!stop.get()) {
+                        Thread.sleep(300);
+
+                        log.info("Stop node.");
+
+                        stopGrid(SRV_CNT - 1);
+
+                        Thread.sleep(300);
+
+                        log.info("Start node.");
+
+                        startGrid(SRV_CNT - 1);
+                    }
+
+                    return null;
+                }
+            }, "restart-thread");
+        }
+
+        try {
+            long stopTime = System.currentTimeMillis() + 30_000;
+
+            int iter = 0;
+
+            while (System.currentTimeMillis() < stopTime) {
+                if (iter % 100 == 0)
+                    log.info("Iteration: " + iter);
+
+                final Integer key = iter++;
+
+                final AtomicInteger val = new AtomicInteger();
+
+                GridTestUtils.runMultiThreaded(new Callable<Void>() {
+                    @Override public Void call() throws Exception {
+                        clientCache.put(key0, val.incrementAndGet());
+
+                        for (int i = 0; i < 10; i++)
+                            clientCache.put(key, val.incrementAndGet());
+
+                        return null;
+                    }
+                }, 20, "update-thread");
+
+                if (restart) {
+                    assertEquals(srvCache.get(key), clientCache.get(key));
+                    assertEquals(srvCache.get(key0), clientCache.get(key0));
+                }
+                else {
+                    assertEquals(srvCache.get(key), clientCache.localPeek(key));
+                    assertEquals(srvCache.get(key0), clientCache.localPeek(key0));
+                }
+            }
+
+            stop.set(true);
+
+            if (restartFut != null)
+                restartFut.get();
+        }
+        finally {
+            stop.set(true);
+        }
+    }
+
+    /**
+     * @param atomicityMode Cache atomicity mode.
+     * @return Cache configuration.
+     */
+    private CacheConfiguration<Integer, Integer> cacheConfiguration(CacheAtomicityMode atomicityMode) {
+        CacheConfiguration<Integer, Integer> ccfg = new CacheConfiguration<>();
+
+        ccfg.setAtomicityMode(atomicityMode);
+        ccfg.setWriteSynchronizationMode(FULL_SYNC);
+        ccfg.setBackups(1);
+
+        return ccfg;
+    }
+}


[09/10] ignite git commit: Merge remote-tracking branch 'origin/master'

Posted by sb...@apache.org.
Merge remote-tracking branch 'origin/master'


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

Branch: refs/heads/ignite-808
Commit: 31c44054c25e03e95fb4a3e237bfa6bf273c59dd
Parents: 1056a31 3c5758b
Author: sboikov <sb...@gridgain.com>
Authored: Thu Sep 24 15:52:40 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Sep 24 15:52:40 2015 +0300

----------------------------------------------------------------------
 examples/schema-import/pom.xml | 10 ++++++++--
 pom.xml                        |  1 +
 2 files changed, 9 insertions(+), 2 deletions(-)
----------------------------------------------------------------------



[07/10] ignite git commit: Merge remote-tracking branch 'origin/master'

Posted by sb...@apache.org.
Merge remote-tracking branch 'origin/master'


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

Branch: refs/heads/ignite-808
Commit: 3c5758bab14b30b1dad7eb39d1c388e5f6956e0f
Parents: dd7d4fa ece3400
Author: Anton Vinogradov <av...@apache.org>
Authored: Thu Sep 24 15:17:46 2015 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Thu Sep 24 15:17:46 2015 +0300

----------------------------------------------------------------------
 .../socket/WordsSocketStreamerServer.java       |   5 +-
 .../org/apache/ignite/IgniteAtomicLong.java     |   2 +-
 .../org/apache/ignite/IgniteFileSystem.java     |   2 +-
 .../apache/ignite/cache/CacheAtomicityMode.java |  17 +-
 .../configuration/CacheConfiguration.java       |  17 +-
 .../apache/ignite/internal/IgniteKernal.java    |   4 +-
 .../cache/DynamicCacheDescriptor.java           |  10 +-
 .../processors/cache/GridCacheAdapter.java      |   8 +-
 .../processors/cache/GridCacheMapEntry.java     |  51 +-
 .../GridCachePartitionExchangeManager.java      |   6 +
 .../processors/cache/GridCacheProcessor.java    |  28 +-
 .../cache/GridCacheSwapEntryImpl.java           |  31 +-
 .../processors/cache/GridCacheSwapManager.java  |  80 ++-
 .../processors/cache/IgniteCacheProxy.java      |   4 +-
 .../continuous/CacheContinuousQueryManager.java |  66 +-
 .../continuous/GridContinuousProcessor.java     |   3 +-
 .../datastreamer/DataStreamerImpl.java          |   2 -
 .../internal/processors/igfs/IgfsImpl.java      |  87 +--
 .../processors/igfs/IgfsMetaManager.java        | 193 +++++-
 .../org/apache/ignite/mxbean/IgniteMXBean.java  |   8 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   7 +-
 .../discovery/DiscoverySpiCustomMessage.java    |  12 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    | 410 +++++++++----
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |   6 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   2 +-
 .../tcp/internal/TcpDiscoveryNodesRing.java     |  94 +--
 .../messages/TcpDiscoveryDiscardMessage.java    |  15 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |   2 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |  19 +-
 .../org/apache/ignite/stream/StreamAdapter.java | 104 +++-
 .../stream/StreamMultipleTupleExtractor.java    |  38 ++
 .../stream/StreamSingleTupleExtractor.java      |  40 ++
 .../ignite/stream/StreamTupleExtractor.java     |  20 +-
 .../ignite/stream/socket/SocketStreamer.java    |   3 +-
 .../GridCacheAbstractRemoveFailureTest.java     |   6 +-
 .../GridCacheVariableTopologySelfTest.java      |   3 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |  65 +-
 .../distributed/CacheAffEarlySelfTest.java      | 245 --------
 .../distributed/CacheAffinityEarlyTest.java     | 168 +++++
 .../IgniteCachePutRetryAbstractSelfTest.java    |  33 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |   2 +-
 .../near/NearCacheMultithreadedUpdateTest.java  | 217 +++++++
 ...ontinuousQueryReplicatedOneNodeSelfTest.java | 120 ++++
 .../processors/igfs/IgfsAbstractSelfTest.java   | 201 ++++--
 .../igfs/IgfsClientCacheSelfTest.java           |  15 +-
 .../igfs/IgfsMetaManagerSelfTest.java           | 106 ++--
 ...lientDiscoverySpiFailureTimeoutSelfTest.java | 139 ++++-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |  13 +-
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |  53 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java | 315 +++++++++-
 .../stream/socket/SocketStreamerSelfTest.java   | 112 +++-
 .../IgniteCacheFailoverTestSuite.java           |   4 -
 .../IgniteCacheFailoverTestSuite3.java          |  23 +-
 .../testsuites/IgniteCacheTestSuite4.java       |   2 +
 .../testsuites/IgniteHadoopTestSuite.java       |  19 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  19 +-
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |  54 +-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |  11 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |   5 +
 .../processors/query/h2/opt/GridH2Table.java    |  10 +-
 .../cache/CacheIndexStreamerTest.java           |  37 +-
 .../processors/cache/GridCacheSwapSelfTest.java |   4 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   4 +-
 .../IgniteCacheWithIndexingTestSuite.java       |   2 +
 modules/mqtt/pom.xml                            | 114 ++++
 .../apache/ignite/stream/mqtt/MqttStreamer.java | 611 +++++++++++++++++++
 .../stream/mqtt/IgniteMqttStreamerTest.java     | 553 +++++++++++++++++
 .../mqtt/IgniteMqttStreamerTestSuite.java       |  34 ++
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |   2 -
 modules/yardstick/config/ignite-base-config.xml |   2 +-
 pom.xml                                         |   1 +
 71 files changed, 3762 insertions(+), 958 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/3c5758ba/pom.xml
----------------------------------------------------------------------


[05/10] ignite git commit: schema-import examples fix (cherry picked from commit b054fdc)

Posted by sb...@apache.org.
schema-import examples fix
(cherry picked from commit b054fdc)


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

Branch: refs/heads/ignite-808
Commit: 94f5248b0e03f04c53f0c264a880803e20de2d3a
Parents: 30f5b9e
Author: Anton Vinogradov <av...@apache.org>
Authored: Thu Sep 24 14:52:09 2015 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Thu Sep 24 15:16:20 2015 +0300

----------------------------------------------------------------------
 examples/schema-import/pom.xml | 2 +-
 pom.xml                        | 1 +
 2 files changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/94f5248b/examples/schema-import/pom.xml
----------------------------------------------------------------------
diff --git a/examples/schema-import/pom.xml b/examples/schema-import/pom.xml
index fdbd631..fce6f47 100644
--- a/examples/schema-import/pom.xml
+++ b/examples/schema-import/pom.xml
@@ -38,7 +38,7 @@
     </properties>
 
     <artifactId>ignite-schema-import-demo</artifactId>
-    <version>1.0.0-SNAPSHOT</version>
+    <version>1.3.3-p7-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/ignite/blob/94f5248b/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index b47958f..33689a4 100644
--- a/pom.xml
+++ b/pom.xml
@@ -466,6 +466,7 @@
             <id>examples</id>
             <modules>
                 <module>examples</module>
+                <module>examples/schema-import</module>
             </modules>
         </profile>
 


[06/10] ignite git commit: schema-import examples fix (cherry picked from commit b054fdc)

Posted by sb...@apache.org.
schema-import examples fix
(cherry picked from commit b054fdc)


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

Branch: refs/heads/ignite-808
Commit: dd7d4fac3a5f391b23c196a5d9951de9d3a762fa
Parents: 94f5248
Author: Anton Vinogradov <av...@apache.org>
Authored: Thu Sep 24 15:17:15 2015 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Thu Sep 24 15:17:15 2015 +0300

----------------------------------------------------------------------
 examples/schema-import/pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/dd7d4fac/examples/schema-import/pom.xml
----------------------------------------------------------------------
diff --git a/examples/schema-import/pom.xml b/examples/schema-import/pom.xml
index fce6f47..32ce869 100644
--- a/examples/schema-import/pom.xml
+++ b/examples/schema-import/pom.xml
@@ -38,7 +38,7 @@
     </properties>
 
     <artifactId>ignite-schema-import-demo</artifactId>
-    <version>1.3.3-p7-SNAPSHOT</version>
+    <version>1.5.0-SNAPSHOT</version>
 
     <dependencies>
         <dependency>


[03/10] ignite git commit: Fixed imports.

Posted by sb...@apache.org.
Fixed imports.


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

Branch: refs/heads/ignite-808
Commit: ece3400438709b2bac2ad9d206028b4bdb897073
Parents: f6ba3c3
Author: sboikov <sb...@gridgain.com>
Authored: Thu Sep 24 13:09:15 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Sep 24 13:09:15 2015 +0300

----------------------------------------------------------------------
 .../IgniteCacheFailoverTestSuite.java           |  4 ----
 .../IgniteCacheFailoverTestSuite3.java          | 23 +++-----------------
 2 files changed, 3 insertions(+), 24 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/ece34004/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite.java
index abc8765..c9e507d 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite.java
@@ -33,18 +33,14 @@ import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtR
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheTxNodeFailureSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridNearCacheTxNodeFailureSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteAtomicLongChangingTopologySelfTest;
-import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteCachePutRetryAtomicSelfTest;
-import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteCachePutRetryTransactionalSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicClientInvalidPartitionHandlingSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicClientRemoveFailureTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicInvalidPartitionHandlingSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicPrimaryWriteOrderRemoveFailureTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicRemoveFailureTest;
-import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.IgniteCachePutRetryAtomicPrimaryWriteOrderSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearRemoveFailureTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicPrimaryWriteOrderNearRemoveFailureTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearRemoveFailureTest;
-import org.apache.ignite.spi.communication.tcp.IgniteCacheSslStartStopSelfTest;
 import org.apache.ignite.testframework.GridTestUtils;
 
 /**

http://git-wip-us.apache.org/repos/asf/ignite/blob/ece34004/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite3.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite3.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite3.java
index 318db9e..0bde89a 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite3.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheFailoverTestSuite3.java
@@ -18,18 +18,10 @@
 package org.apache.ignite.testsuites;
 
 import junit.framework.TestSuite;
-import org.apache.ignite.internal.processors.cache.GridCacheIncrementTransformTest;
-import org.apache.ignite.internal.processors.cache.IgniteCacheTopologySafeGetSelfTest;
-import org.apache.ignite.internal.processors.cache.distributed.*;
-import org.apache.ignite.internal.processors.cache.distributed.dht.*;
-import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.*;
-import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearRemoveFailureTest;
-import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicPrimaryWriteOrderNearRemoveFailureTest;
-import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearRemoveFailureTest;
+import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteCachePutRetryAtomicSelfTest;
+import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteCachePutRetryTransactionalSelfTest;
+import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.IgniteCachePutRetryAtomicPrimaryWriteOrderSelfTest;
 import org.apache.ignite.spi.communication.tcp.IgniteCacheSslStartStopSelfTest;
-import org.apache.ignite.testframework.GridTestUtils;
-
-import java.util.Set;
 
 /**
  * Test suite.
@@ -40,15 +32,6 @@ public class IgniteCacheFailoverTestSuite3 extends TestSuite {
      * @throws Exception Thrown in case of the failure.
      */
     public static TestSuite suite() throws Exception {
-        return suite(null);
-    }
-
-    /**
-     * @param ignoredTests Tests don't include in the execution.
-     * @return Test suite.
-     * @throws Exception Thrown in case of the failure.
-     */
-    public static TestSuite suite(Set<Class> ignoredTests) throws Exception {
         TestSuite suite = new TestSuite("Cache Failover Test Suite3");
 
         suite.addTestSuite(IgniteCachePutRetryAtomicSelfTest.class);


[08/10] ignite git commit: ignite-1540 Handle error in GridDhtAtomicUpdateFuture.onDone

Posted by sb...@apache.org.
ignite-1540 Handle error in GridDhtAtomicUpdateFuture.onDone


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

Branch: refs/heads/ignite-808
Commit: 1056a31fc72ea25c8790e37f2621f3d6e1908c89
Parents: ece3400
Author: sboikov <sb...@gridgain.com>
Authored: Thu Sep 24 15:52:17 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Sep 24 15:52:17 2015 +0300

----------------------------------------------------------------------
 .../cache/distributed/dht/atomic/GridDhtAtomicUpdateFuture.java | 5 +++++
 1 file changed, 5 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/1056a31f/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateFuture.java
index 0cbad48..35b8e27 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateFuture.java
@@ -311,6 +311,11 @@ public class GridDhtAtomicUpdateFuture extends GridFutureAdapter<Void>
         if (super.onDone(res, err)) {
             cctx.mvcc().removeAtomicFuture(version());
 
+            if (err != null) {
+                for (KeyCacheObject key : keys)
+                    updateRes.addFailedKey(key, err);
+            }
+
             if (updateReq.writeSynchronizationMode() == FULL_SYNC)
                 completionCb.apply(updateReq, updateRes);
 


[02/10] ignite git commit: Fixed test.

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


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

Branch: refs/heads/ignite-808
Commit: f6ba3c3b4575c60f94ae4742b5d2d7bd2183f938
Parents: 4b0c029
Author: sboikov <sb...@gridgain.com>
Authored: Thu Sep 24 12:56:19 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Sep 24 12:56:19 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheVariableTopologySelfTest.java       | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/f6ba3c3b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVariableTopologySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVariableTopologySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVariableTopologySelfTest.java
index 7078843..80103c3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVariableTopologySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVariableTopologySelfTest.java
@@ -19,6 +19,7 @@ package org.apache.ignite.internal.processors.cache;
 
 import java.util.Random;
 import java.util.concurrent.atomic.AtomicBoolean;
+import javax.cache.CacheException;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.cache.CacheWriteSynchronizationMode;
@@ -146,7 +147,7 @@ public class GridCacheVariableTopologySelfTest extends GridCommonAbstractTest {
                     catch (TransactionRollbackException | ClusterTopologyException e) {
                         info("Caught exception: " + e);
                     }
-                    catch (IgniteException e) {
+                    catch (CacheException | IgniteException e) {
                         if (X.hasCause(e, ClusterTopologyCheckedException.class))
                             info("Caught cache exception: " + e);
                         else


[04/10] ignite git commit: schema-import examples fix (cherry picked from commit 169066b)

Posted by sb...@apache.org.
schema-import examples fix
(cherry picked from commit 169066b)


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

Branch: refs/heads/ignite-808
Commit: 30f5b9ef82fe9216fd89827977c601b8eb17db50
Parents: 1021d4e
Author: Anton Vinogradov <av...@apache.org>
Authored: Thu Sep 24 14:33:26 2015 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Thu Sep 24 15:16:17 2015 +0300

----------------------------------------------------------------------
 examples/schema-import/pom.xml | 10 ++++++++--
 1 file changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/30f5b9ef/examples/schema-import/pom.xml
----------------------------------------------------------------------
diff --git a/examples/schema-import/pom.xml b/examples/schema-import/pom.xml
index d302606..fdbd631 100644
--- a/examples/schema-import/pom.xml
+++ b/examples/schema-import/pom.xml
@@ -26,13 +26,19 @@
     xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <modelVersion>4.0.0</modelVersion>
 
+    <parent>
+        <groupId>org.apache.ignite</groupId>
+        <artifactId>ignite-parent</artifactId>
+        <version>1</version>
+        <relativePath>../../parent</relativePath>
+    </parent>
+
     <properties>
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
     </properties>
 
-    <groupId>org.apache.ignite</groupId>
     <artifactId>ignite-schema-import-demo</artifactId>
-    <version>${project.version}</version>
+    <version>1.0.0-SNAPSHOT</version>
 
     <dependencies>
         <dependency>


[10/10] ignite git commit: Merge remote-tracking branch 'remotes/origin/master' into ignite-808

Posted by sb...@apache.org.
Merge remote-tracking branch 'remotes/origin/master' into ignite-808


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

Branch: refs/heads/ignite-808
Commit: 7d96b53a4108991f2784c9993d68a209524fe599
Parents: 7aaeecb 31c4405
Author: sboikov <sb...@gridgain.com>
Authored: Thu Sep 24 16:12:49 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Sep 24 16:12:49 2015 +0300

----------------------------------------------------------------------
 examples/schema-import/pom.xml                  |  10 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   5 +
 .../GridCacheVariableTopologySelfTest.java      |   3 +-
 .../near/NearCacheMultithreadedUpdateTest.java  | 217 +++++++++++++++++++
 .../IgniteCacheFailoverTestSuite.java           |   4 -
 .../IgniteCacheFailoverTestSuite3.java          |  23 +-
 pom.xml                                         |   1 +
 7 files changed, 236 insertions(+), 27 deletions(-)
----------------------------------------------------------------------