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 2015/11/30 18:00:29 UTC

[01/12] ignite git commit: ignite-1924

Repository: ignite
Updated Branches:
  refs/heads/ignite-1.5.1 cb5bd7c3f -> c7dd0edd1


ignite-1924


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

Branch: refs/heads/ignite-1.5.1
Commit: eeb584d070f72ab5457135ad15217316d75bba6a
Parents: dc14ccc
Author: Anton Vinogradov <av...@apache.org>
Authored: Mon Nov 30 14:49:29 2015 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Mon Nov 30 14:49:29 2015 +0300

----------------------------------------------------------------------
 .../spi/communication/tcp/IgniteCacheSslStartStopSelfTest.java     | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/eeb584d0/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteCacheSslStartStopSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteCacheSslStartStopSelfTest.java b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteCacheSslStartStopSelfTest.java
index fe84c67..12bd020 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteCacheSslStartStopSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteCacheSslStartStopSelfTest.java
@@ -27,12 +27,12 @@ import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
 /**
  *
  */
-//Can fail as described at https://issues.apache.org/jira/browse/IGNITE-1924
 public class IgniteCacheSslStartStopSelfTest extends IgniteCachePutRetryAbstractSelfTest {
     /** {@inheritDoc} */
     @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(gridName);
 
+        fail("https://issues.apache.org/jira/browse/IGNITE-1924");
         cfg.setSslContextFactory(GridTestUtils.sslFactory());
 
         return cfg;


[12/12] ignite git commit: Merge branch ignite-1.5 into ignite-1.5.1

Posted by ag...@apache.org.
Merge branch ignite-1.5 into ignite-1.5.1


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

Branch: refs/heads/ignite-1.5.1
Commit: c7dd0edd143018fd56005ec19a06681d985a89ec
Parents: cb5bd7c 6260fc1
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Mon Nov 30 20:00:07 2015 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Mon Nov 30 20:00:07 2015 +0300

----------------------------------------------------------------------
 .../GridDeploymentPerVersionStore.java          |  12 +-
 .../distributed/dht/GridDhtLockFuture.java      |  17 ++-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   4 +
 .../communication/tcp/TcpCommunicationSpi.java  |  12 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   2 -
 ...cheAbstractFullApiMultithreadedSelfTest.java |   9 +-
 .../IgniteCacheStoreValueAbstractTest.java      | 111 +++++++++++--------
 .../cache/IgniteCacheTxPreloadNoWriteTest.java  |   2 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   3 +-
 ...eRebalancingUnmarshallingFailedSelfTest.java |  13 ++-
 .../GridCacheLocalIsolatedNodesSelfTest.java    |   6 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |   7 +-
 .../tcp/IgniteCacheSslStartStopSelfTest.java    |   2 +-
 .../twitter/IgniteTwitterStreamerTestSuite.java |  19 ++--
 14 files changed, 137 insertions(+), 82 deletions(-)
----------------------------------------------------------------------



[02/12] ignite git commit: ignite-530

Posted by ag...@apache.org.
ignite-530


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

Branch: refs/heads/ignite-1.5.1
Commit: c5304a94eb0676839acb0302efb1159430ee8cd9
Parents: eeb584d
Author: Anton Vinogradov <av...@apache.org>
Authored: Mon Nov 30 15:12:07 2015 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Mon Nov 30 15:12:07 2015 +0300

----------------------------------------------------------------------
 .../twitter/IgniteTwitterStreamerTestSuite.java  | 19 ++++++++++++-------
 1 file changed, 12 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/c5304a94/modules/twitter/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/twitter/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java b/modules/twitter/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java
index b458bed..e07aaec 100644
--- a/modules/twitter/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java
+++ b/modules/twitter/src/test/java/org/apache/ignite/stream/twitter/IgniteTwitterStreamerTestSuite.java
@@ -17,16 +17,21 @@
 
 package org.apache.ignite.stream.twitter;
 
-import org.junit.runner.RunWith;
-import org.junit.runners.Suite;
+import junit.framework.TestSuite;
 
 /**
  * Twitter streamer tests.
  */
-@RunWith(Suite.class)
-@Suite.SuiteClasses({
-    IgniteTwitterStreamerTest.class
-})
-public class IgniteTwitterStreamerTestSuite {
+public class IgniteTwitterStreamerTestSuite extends TestSuite {
+    /**
+     * @return Twitter streamer tests suite.
+     * @throws Exception If failed.
+     */
+    public static TestSuite suite() throws Exception {
+        TestSuite suite = new TestSuite("Twitter streamed Test Suite");
 
+        suite.addTestSuite(IgniteTwitterStreamerTest.class);
+
+        return suite;
+    }
 }


[07/12] ignite git commit: Ignite-1.5 - Fixing tests.

Posted by ag...@apache.org.
Ignite-1.5 - Fixing tests.


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

Branch: refs/heads/ignite-1.5.1
Commit: aee20d9d6822fd13fd437420b439ea18e99d0223
Parents: eed4b1c
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Mon Nov 30 17:27:41 2015 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Mon Nov 30 17:27:41 2015 +0300

----------------------------------------------------------------------
 .../GridDeploymentPerVersionStore.java          |  12 +-
 .../distributed/dht/GridDhtLockFuture.java      |  17 ++-
 .../communication/tcp/TcpCommunicationSpi.java  |  12 +-
 .../IgniteCacheStoreValueAbstractTest.java      | 111 +++++++++++--------
 .../cache/IgniteCacheTxPreloadNoWriteTest.java  |   2 +-
 ...eRebalancingUnmarshallingFailedSelfTest.java |  13 ++-
 6 files changed, 104 insertions(+), 63 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/aee20d9d/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
index fabbcb2..5e30bf6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
@@ -145,11 +145,15 @@ public class GridDeploymentPerVersionStore extends GridDeploymentStoreAdapter {
                                                 "nodes: " + dep);
                                     }
                                 }
-                                else if (log.isDebugEnabled())
-                                    log.debug("Preserving deployment without node participants: " + dep);
+                                else {
+                                    if (log.isDebugEnabled())
+                                        log.debug("Preserving deployment without node participants: " + dep);
+                                }
+                            }
+                            else {
+                                if (log.isDebugEnabled())
+                                    log.debug("Keeping deployment as it still has participants: " + dep);
                             }
-                            else if (log.isDebugEnabled())
-                                log.debug("Keeping deployment as it still has participants: " + dep);
                         }
 
                         if (deps.isEmpty())

http://git-wip-us.apache.org/repos/asf/ignite/blob/aee20d9d/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLockFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLockFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLockFuture.java
index 2b5d5a4..f0d2e15 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLockFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLockFuture.java
@@ -738,11 +738,22 @@ public final class GridDhtLockFuture extends GridCompoundIdentityFuture<Boolean>
         if (!success && !stopping)
             undoLocks(true);
 
-        if (tx != null)
+        boolean set = false;
+
+        if (tx != null) {
             cctx.tm().txContext(tx);
 
-        if (err == null && !stopping)
-            loadMissingFromStore();
+            set = cctx.tm().setTxTopologyHint(tx);
+        }
+
+        try {
+            if (err == null && !stopping)
+                loadMissingFromStore();
+        }
+        finally {
+            if (set)
+                cctx.tm().setTxTopologyHint(null);
+        }
 
         if (super.onDone(success, err)) {
             if (log.isDebugEnabled())

http://git-wip-us.apache.org/repos/asf/ignite/blob/aee20d9d/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
index b2f0f65..9f8bae3 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
@@ -2305,12 +2305,6 @@ public class TcpCommunicationSpi extends IgniteSpiAdapter
 
                     GridNioRecoveryDescriptor recoveryDesc = recoveryDescriptor(node);
 
-                    if (!recoveryDesc.reserve()) {
-                        U.closeQuiet(ch);
-
-                        return null;
-                    }
-
                     if (getSpiContext().node(node.id()) == null) {
                         recoveryDesc.release();
 
@@ -2320,6 +2314,12 @@ public class TcpCommunicationSpi extends IgniteSpiAdapter
                             "(node left topology): " + node);
                     }
 
+                    if (!recoveryDesc.reserve()) {
+                        U.closeQuiet(ch);
+
+                        return null;
+                    }
+
                     long rcvCnt = -1;
 
                     SSLEngine sslEngine = null;

http://git-wip-us.apache.org/repos/asf/ignite/blob/aee20d9d/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheStoreValueAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheStoreValueAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheStoreValueAbstractTest.java
index 98579fc..95527c3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheStoreValueAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheStoreValueAbstractTest.java
@@ -27,6 +27,7 @@ import javax.cache.Cache;
 import javax.cache.integration.CacheLoaderException;
 import javax.cache.integration.CacheWriterException;
 import javax.cache.processor.MutableEntry;
+import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteDataStreamer;
 import org.apache.ignite.cache.CacheEntryProcessor;
@@ -37,6 +38,9 @@ import org.apache.ignite.cache.affinity.Affinity;
 import org.apache.ignite.cache.store.CacheStoreAdapter;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.internal.IgniteEx;
+import org.apache.ignite.internal.portable.BinaryMarshaller;
+import org.apache.ignite.internal.portable.BinaryObjectImpl;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridNearCacheAdapter;
 import org.apache.ignite.internal.util.lang.GridAbsPredicate;
 import org.apache.ignite.lang.IgniteBiInClosure;
@@ -242,7 +246,9 @@ public abstract class IgniteCacheStoreValueAbstractTest extends IgniteCacheAbstr
      */
     private void checkNoValue(Affinity<Object> aff, Object key) {
         for (int g = 0; g < gridCount(); g++) {
-            GridCacheAdapter cache0 = internalCache(grid(g), null);
+            IgniteEx ig = grid(g);
+
+            GridCacheAdapter cache0 = internalCache(ig, null);
 
             GridCacheEntryEx e = cache0.peekEx(key);
 
@@ -254,43 +260,38 @@ public abstract class IgniteCacheStoreValueAbstractTest extends IgniteCacheAbstr
 
                 assertNotNull(keyObj);
 
-                assertEquals(KeyCacheObjectImpl.class, keyObj.getClass());
-
-                assertNotNull("Unexpected value, node: " + g,
-                    GridTestUtils.getFieldValue(keyObj, CacheObjectAdapter.class, "val"));
+                if (!isBinaryMarshallerUsed(ig)) {
+                    assertNotNull("Unexpected value, node: " + g,
+                        GridTestUtils.getFieldValue(keyObj, CacheObjectAdapter.class, "val"));
 
-                Object key0 = keyObj.value(cache0.context().cacheObjectContext(), true);
-                Object key1 = keyObj.value(cache0.context().cacheObjectContext(), false);
-                Object key2 = keyObj.value(cache0.context().cacheObjectContext(), true);
-                Object key3 = keyObj.value(cache0.context().cacheObjectContext(), false);
+                    Object key0 = keyObj.value(cache0.context().cacheObjectContext(), true);
+                    Object key1 = keyObj.value(cache0.context().cacheObjectContext(), false);
+                    Object key2 = keyObj.value(cache0.context().cacheObjectContext(), true);
+                    Object key3 = keyObj.value(cache0.context().cacheObjectContext(), false);
 
-                assertSame(key0, key1);
-                assertSame(key1, key2);
-                assertSame(key2, key3);
+                    assertSame(key0, key1);
+                    assertSame(key1, key2);
+                    assertSame(key2, key3);
+                }
 
                 CacheObject obj = e.rawGet();
 
                 if (obj != null) {
-                    assertEquals(CacheObjectImpl.class, obj.getClass());
-
-                    assertNull("Unexpected value, node: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    assertNull("Unexpected value, node: " + g, reflectiveValue(obj));
 
                     assertNotNull(obj.value(cache0.context().cacheObjectContext(), true));
 
-                    assertNull("Unexpected value after value() requested1: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    assertNull("Unexpected value after value() requested1: " + g, reflectiveValue(obj));
 
                     assertNotNull(obj.value(cache0.context().cacheObjectContext(), false));
 
-                    assertNull("Unexpected value after value() requested2: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    assertNull("Unexpected value after value() requested2: " + g, reflectiveValue(obj));
                 }
                 else
-                    assertFalse(aff.isPrimaryOrBackup(grid(g).localNode(), key));
+                    assertFalse(aff.isPrimaryOrBackup(ig.localNode(), key));
             }
             else
-                assertFalse("Entry not found, node: " + g, aff.isPrimaryOrBackup(grid(g).localNode(), key));
+                assertFalse("Entry not found, node: " + g, aff.isPrimaryOrBackup(ig.localNode(), key));
         }
     }
 
@@ -379,7 +380,9 @@ public abstract class IgniteCacheStoreValueAbstractTest extends IgniteCacheAbstr
      */
     private void checkHasValue(Affinity<Object> aff, Object key) {
         for (int g = 0; g < gridCount(); g++) {
-            GridCacheAdapter cache0 = internalCache(grid(g), null);
+            IgniteEx ig = grid(g);
+
+            GridCacheAdapter cache0 = internalCache(ig, null);
 
             GridCacheEntryEx e = cache0.peekEx(key);
 
@@ -391,56 +394,72 @@ public abstract class IgniteCacheStoreValueAbstractTest extends IgniteCacheAbstr
 
                 assertNotNull(keyObj);
 
-                assertEquals(KeyCacheObjectImpl.class, keyObj.getClass());
-
-                assertNotNull("Unexpected value, node: " + g,
-                    GridTestUtils.getFieldValue(keyObj, CacheObjectAdapter.class, "val"));
+                if (!isBinaryMarshallerUsed(ig)) {
+                    assertNotNull("Unexpected value, node: " + g,
+                        GridTestUtils.getFieldValue(keyObj, CacheObjectAdapter.class, "val"));
 
-                Object key0 = keyObj.value(cache0.context().cacheObjectContext(), true);
-                Object key1 = keyObj.value(cache0.context().cacheObjectContext(), false);
-                Object key2 = keyObj.value(cache0.context().cacheObjectContext(), true);
-                Object key3 = keyObj.value(cache0.context().cacheObjectContext(), false);
+                    Object key0 = keyObj.value(cache0.context().cacheObjectContext(), true);
+                    Object key1 = keyObj.value(cache0.context().cacheObjectContext(), false);
+                    Object key2 = keyObj.value(cache0.context().cacheObjectContext(), true);
+                    Object key3 = keyObj.value(cache0.context().cacheObjectContext(), false);
 
-                assertSame(key0, key1);
-                assertSame(key1, key2);
-                assertSame(key2, key3);
+                    assertSame(key0, key1);
+                    assertSame(key1, key2);
+                    assertSame(key2, key3);
+                }
 
                 CacheObject obj = e.rawGet();
 
                 if (obj != null) {
-                    assertEquals(CacheObjectImpl.class, obj.getClass());
-
-                    assertNotNull("Unexpected value, node: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    if (!isBinaryMarshallerUsed(ig))
+                        assertNotNull("Unexpected value, node: " + g, reflectiveValue(obj));
 
                     Object val0 = obj.value(cache0.context().cacheObjectContext(), true);
 
-                    assertNotNull("Unexpected value after value() requested1: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    assertNotNull("Unexpected value after value() requested1: " + g, reflectiveValue(obj));
 
                     Object val1 = obj.value(cache0.context().cacheObjectContext(), true);
 
-                    assertNotNull("Unexpected value after value() requested2: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    assertNotNull("Unexpected value after value() requested2: " + g, reflectiveValue(obj));
 
                     assertSame(val0, val1);
 
                     Object val2 = obj.value(cache0.context().cacheObjectContext(), false);
 
-                    assertNotNull("Unexpected value after value() requested3: " + g,
-                        GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val"));
+                    assertNotNull("Unexpected value after value() requested3: " + g, reflectiveValue(obj));
 
                     assertSame(val1, val2);
                 }
                 else
-                    assertFalse(aff.isPrimaryOrBackup(grid(g).localNode(), key));
+                    assertFalse(aff.isPrimaryOrBackup(ig.localNode(), key));
             }
             else
-                assertFalse("Entry not found, node: " + g, aff.isPrimaryOrBackup(grid(g).localNode(), key));
+                assertFalse("Entry not found, node: " + g, aff.isPrimaryOrBackup(ig.localNode(), key));
         }
     }
 
     /**
+     * @param ig Ignite.
+     * @return If binary marshaller is used.
+     */
+    private boolean isBinaryMarshallerUsed(Ignite ig) {
+        return ig.configuration().getMarshaller() == null ||
+            ig.configuration().getMarshaller() instanceof BinaryMarshaller;
+    }
+
+    /**
+     * @param obj Object to extract value from.
+     * @return Cache object.
+     */
+    @SuppressWarnings("IfMayBeConditional")
+    private Object reflectiveValue(CacheObject obj) {
+        if (obj instanceof BinaryObjectImpl)
+            return GridTestUtils.getFieldValue(obj, BinaryObjectImpl.class, "obj");
+        else
+            return GridTestUtils.getFieldValue(obj, CacheObjectAdapter.class, "val");
+    }
+
+    /**
      *
      */
     static class TestKey implements Serializable {

http://git-wip-us.apache.org/repos/asf/ignite/blob/aee20d9d/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheTxPreloadNoWriteTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheTxPreloadNoWriteTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheTxPreloadNoWriteTest.java
index 2a85b57..a68931b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheTxPreloadNoWriteTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheTxPreloadNoWriteTest.java
@@ -109,7 +109,7 @@ public class IgniteCacheTxPreloadNoWriteTest extends GridCommonAbstractTest {
 
         Ignite ignite1 = startGrid(1);
 
-        Integer key = 70;
+        Integer key = primaryKey(ignite1.cache(null));
 
         // Want test scenario when ignite1 is new primary node, but ignite0 is still partition owner.
         assertTrue(aff.isPrimary(ignite1.cluster().localNode(), key));

http://git-wip-us.apache.org/repos/asf/ignite/blob/aee20d9d/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
index 831e82d..506f1c2 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
@@ -27,8 +27,10 @@ import org.apache.ignite.cache.CacheRebalanceMode;
 import org.apache.ignite.cache.query.annotations.QuerySqlField;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.internal.portable.BinaryMarshaller;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
+import org.apache.ignite.testframework.config.GridTestProperties;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 
 /**
@@ -113,6 +115,12 @@ public class GridCacheRebalancingUnmarshallingFailedSelfTest extends GridCommonA
      * @throws Exception e.
      */
     public void test() throws Exception {
+        String marshClsName = GridTestProperties.getProperty(GridTestProperties.MARSH_CLASS_NAME);
+
+        // This test passes with binary marshaller because we do not unmarshall keys.
+        if (marshClsName != null && marshClsName.contains(BinaryMarshaller.class.getSimpleName()))
+            return;
+
         readCnt.set(Integer.MAX_VALUE);
 
         startGrid(0);
@@ -133,9 +141,8 @@ public class GridCacheRebalancingUnmarshallingFailedSelfTest extends GridCommonA
 
         stopGrid(0);
 
-        for (int i = 50; i < 100; i++) {
-            assert grid(1).cache(CACHE).get(new TestKey(String.valueOf(i))) == null;
-        }
+        for (int i = 50; i < 100; i++)
+            assertNull(grid(1).cache(CACHE).get(new TestKey(String.valueOf(i))));
     }
 
     /** {@inheritDoc} */


[05/12] ignite git commit: Fixed GridCacheLocalIsolatedNodesSelfTest and GridCacheLocalFullApiMultithreadedSelfTest.testRemoveAllAsync tests.

Posted by ag...@apache.org.
Fixed GridCacheLocalIsolatedNodesSelfTest and GridCacheLocalFullApiMultithreadedSelfTest.testRemoveAllAsync tests.


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

Branch: refs/heads/ignite-1.5.1
Commit: 407bf939a8beae32108cdb60bfba3efe3cc8d7c1
Parents: 8e605e9
Author: Tikhonov Nikolay <ti...@gmail.com>
Authored: Mon Nov 30 16:49:14 2015 +0300
Committer: Tikhonov Nikolay <ti...@gmail.com>
Committed: Mon Nov 30 16:49:14 2015 +0300

----------------------------------------------------------------------
 .../GridCacheAbstractFullApiMultithreadedSelfTest.java      | 9 +++++++--
 .../cache/local/GridCacheLocalIsolatedNodesSelfTest.java    | 6 +++---
 2 files changed, 10 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/407bf939/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractFullApiMultithreadedSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractFullApiMultithreadedSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractFullApiMultithreadedSelfTest.java
index e89288f..5e43b2a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractFullApiMultithreadedSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractFullApiMultithreadedSelfTest.java
@@ -22,6 +22,7 @@ import java.util.Collection;
 import java.util.Map;
 import java.util.Random;
 import java.util.Set;
+import java.util.HashSet;
 import java.util.TreeSet;
 import java.util.concurrent.atomic.AtomicBoolean;
 import java.util.concurrent.atomic.AtomicInteger;
@@ -341,12 +342,16 @@ public abstract class GridCacheAbstractFullApiMultithreadedSelfTest extends Grid
 
                 IgniteCache<String, Integer> cacheAsync = cache.withAsync();
 
+                Set<Integer> ids = new HashSet<>(set);
+
                 cacheAsync.removeAll(rangeKeys(0, rnd));
 
                 cacheAsync.future().get();
 
-                for (int i = 0; i < rnd; i++)
-                    assert cache.localPeek("key" + i, CachePeekMode.ONHEAP) == null;
+                for (int i = 0; i < rnd; i++) {
+                    if (ids.contains(i))
+                        assert cache.localPeek("key" + i, CachePeekMode.ONHEAP) == null;
+                }
             }
         });
     }

http://git-wip-us.apache.org/repos/asf/ignite/blob/407bf939/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/local/GridCacheLocalIsolatedNodesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/local/GridCacheLocalIsolatedNodesSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/local/GridCacheLocalIsolatedNodesSelfTest.java
index e6b66ca..53122c7 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/local/GridCacheLocalIsolatedNodesSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/local/GridCacheLocalIsolatedNodesSelfTest.java
@@ -66,7 +66,7 @@ public class GridCacheLocalIsolatedNodesSelfTest extends GridCommonAbstractTest
         assert !nid1.equals(nid3);
 
         // Local cache on first node only.
-        CacheConfiguration<String, String> ccfg1 = new CacheConfiguration<>("A");
+        CacheConfiguration<String, String> ccfg1 = new CacheConfiguration<>("A1");
         ccfg1.setCacheMode(LOCAL);
         ccfg1.setNodeFilter(new NodeIdFilter(nid1));
 
@@ -74,7 +74,7 @@ public class GridCacheLocalIsolatedNodesSelfTest extends GridCommonAbstractTest
         c1.put("g1", "c1");
 
         // Local cache on second node only.
-        CacheConfiguration<String, String> ccfg2 = new CacheConfiguration<>("A");
+        CacheConfiguration<String, String> ccfg2 = new CacheConfiguration<>("A2");
         ccfg2.setCacheMode(LOCAL);
         ccfg2.setNodeFilter(new NodeIdFilter(nid2));
 
@@ -82,7 +82,7 @@ public class GridCacheLocalIsolatedNodesSelfTest extends GridCommonAbstractTest
         c2.put("g2", "c2");
 
         // Local cache on third node only.
-        CacheConfiguration<String, String> ccfg3 = new CacheConfiguration<>("A");
+        CacheConfiguration<String, String> ccfg3 = new CacheConfiguration<>("A3");
         ccfg3.setCacheMode(LOCAL);
         ccfg3.setNodeFilter(new NodeIdFilter(nid3));
 


[10/12] ignite git commit: minor

Posted by ag...@apache.org.
minor


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

Branch: refs/heads/ignite-1.5.1
Commit: fcbc6d0e6c7042cb39abbc0b388a5f9ade958d95
Parents: 3d6973b
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Nov 30 17:33:56 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Nov 30 17:33:56 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java  | 2 --
 1 file changed, 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/fcbc6d0e/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
index 8827a78..854ce95 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
@@ -44,7 +44,6 @@ import javax.net.ssl.SSLServerSocketFactory;
 import javax.net.ssl.SSLSocketFactory;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteAuthenticationException;
-import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.IgniteLogger;
@@ -60,7 +59,6 @@ import org.apache.ignite.internal.util.typedef.internal.LT;
 import org.apache.ignite.internal.util.typedef.internal.S;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.lang.IgniteBiTuple;
-import org.apache.ignite.lang.IgniteCallable;
 import org.apache.ignite.lang.IgniteInClosure;
 import org.apache.ignite.lang.IgniteProductVersion;
 import org.apache.ignite.lang.IgniteUuid;


[08/12] ignite git commit: minor

Posted by ag...@apache.org.
minor


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

Branch: refs/heads/ignite-1.5.1
Commit: 776af1a5aade09174422de9b8f5d04f1ce50d458
Parents: 8e605e9
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Nov 30 17:32:59 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Nov 30 17:32:59 2015 +0300

----------------------------------------------------------------------
 .../rest/handlers/cache/GridCacheCommandHandlerSelfTest.java        | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/776af1a5/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
index 484ee87..740b166 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
@@ -62,6 +62,7 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
         TcpDiscoverySpi disco = new TcpDiscoverySpi();
 
         disco.setIpFinder(new TcpDiscoveryVmIpFinder(true));
+        disco.setJoinTimeout(5000);
 
         // Cache config.
         CacheConfiguration cacheCfg = defaultCacheConfiguration();


[03/12] ignite git commit: ignite-1.5 Handle marshal/unmarshal prevVals in GridDhtAtomicUpdateRequest.

Posted by ag...@apache.org.
ignite-1.5 Handle marshal/unmarshal prevVals in GridDhtAtomicUpdateRequest.


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

Branch: refs/heads/ignite-1.5.1
Commit: 0fcc1d18f7d403588e2f018458b1d16c81ed131c
Parents: c5304a9
Author: sboikov <sb...@gridgain.com>
Authored: Mon Nov 30 15:15:06 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Nov 30 15:15:06 2015 +0300

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


http://git-wip-us.apache.org/repos/asf/ignite/blob/0fcc1d18/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateRequest.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateRequest.java
index b3155a7..4f15fa1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateRequest.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicUpdateRequest.java
@@ -647,6 +647,8 @@ public class GridDhtAtomicUpdateRequest extends GridCacheMessage implements Grid
 
         prepareMarshalCacheObjects(nearVals, cctx);
 
+        prepareMarshalCacheObjects(prevVals, cctx);
+
         if (forceTransformBackups) {
             // force addition of deployment info for entry processors if P2P is enabled globally.
             if (!addDepInfo && ctx.deploymentEnabled())
@@ -674,6 +676,8 @@ public class GridDhtAtomicUpdateRequest extends GridCacheMessage implements Grid
 
         finishUnmarshalCacheObjects(nearVals, cctx, ldr);
 
+        finishUnmarshalCacheObjects(prevVals, cctx, ldr);
+
         if (forceTransformBackups) {
             entryProcessors = unmarshalCollection(entryProcessorsBytes, ctx, ldr);
 


[06/12] ignite git commit: Fixed GridCacheNearOnlyMultiNodeP2PDisabledFullApiSelfTest.testReaderTtlNoTx test.

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


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

Branch: refs/heads/ignite-1.5.1
Commit: eed4b1c245d8a22d4e9ae2ce7200089025c8c5ae
Parents: 407bf93
Author: Tikhonov Nikolay <ti...@gmail.com>
Authored: Mon Nov 30 17:09:15 2015 +0300
Committer: Tikhonov Nikolay <ti...@gmail.com>
Committed: Mon Nov 30 17:09:15 2015 +0300

----------------------------------------------------------------------
 .../near/GridCacheNearOnlyMultiNodeFullApiSelfTest.java           | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/eed4b1c2/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearOnlyMultiNodeFullApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearOnlyMultiNodeFullApiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearOnlyMultiNodeFullApiSelfTest.java
index c4407fe..eaab103 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearOnlyMultiNodeFullApiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearOnlyMultiNodeFullApiSelfTest.java
@@ -413,7 +413,8 @@ public class GridCacheNearOnlyMultiNodeFullApiSelfTest extends GridCachePartitio
                         return true;
                 }
                 catch (GridCacheEntryRemovedException e) {
-                    throw new RuntimeException(e);
+                    // If e0.valueBytes() thrown this exception then entry has been removed.
+                    return true;
                 }
             }
         }, Math.min(ttl * 10, getTestTimeout())));


[11/12] ignite git commit: 1.5.0-EA-SNAPSHOT

Posted by ag...@apache.org.
1.5.0-EA-SNAPSHOT


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

Branch: refs/heads/ignite-1.5.1
Commit: 6260fc1fc80cc77cc9a0ef776640845b979b27b3
Parents: fcbc6d0
Author: Ignite Teamcity <ig...@apache.org>
Authored: Mon Nov 30 19:42:45 2015 +0300
Committer: Ignite Teamcity <ig...@apache.org>
Committed: Mon Nov 30 19:42:45 2015 +0300

----------------------------------------------------------------------
 examples/pom.xml                                               | 5 ++---
 examples/schema-import/pom.xml                                 | 2 +-
 modules/aop/pom.xml                                            | 2 +-
 modules/apache-license-gen/pom.xml                             | 2 +-
 modules/aws/pom.xml                                            | 2 +-
 modules/camel/pom.xml                                          | 5 ++---
 modules/clients/pom.xml                                        | 2 +-
 modules/cloud/pom.xml                                          | 2 +-
 modules/codegen/pom.xml                                        | 2 +-
 modules/core/pom.xml                                           | 2 +-
 modules/core/src/main/resources/ignite.properties              | 2 +-
 modules/extdata/p2p/pom.xml                                    | 2 +-
 modules/extdata/uri/modules/uri-dependency/pom.xml             | 2 +-
 modules/extdata/uri/pom.xml                                    | 4 ++--
 modules/flume/pom.xml                                          | 5 ++---
 modules/gce/pom.xml                                            | 2 +-
 modules/geospatial/pom.xml                                     | 2 +-
 modules/hadoop/pom.xml                                         | 2 +-
 modules/hibernate/pom.xml                                      | 2 +-
 modules/indexing/pom.xml                                       | 2 +-
 modules/jcl/pom.xml                                            | 2 +-
 modules/jms11/pom.xml                                          | 2 +-
 modules/jta/pom.xml                                            | 2 +-
 modules/kafka/pom.xml                                          | 2 +-
 modules/log4j/pom.xml                                          | 2 +-
 modules/log4j2/pom.xml                                         | 2 +-
 modules/mesos/pom.xml                                          | 2 +-
 modules/mqtt/pom.xml                                           | 5 ++---
 modules/platforms/cpp/common/configure.ac                      | 2 +-
 modules/platforms/cpp/core-test/configure.ac                   | 2 +-
 modules/platforms/cpp/core/configure.ac                        | 2 +-
 modules/platforms/cpp/examples/configure.ac                    | 2 +-
 modules/platforms/cpp/ignite/configure.ac                      | 2 +-
 .../dotnet/Apache.Ignite.Benchmarks/Properties/AssemblyInfo.cs | 4 ++--
 .../Properties/AssemblyInfo.cs                                 | 4 ++--
 .../dotnet/Apache.Ignite.Core.Tests/Properties/AssemblyInfo.cs | 4 ++--
 .../dotnet/Apache.Ignite.Core/Properties/AssemblyInfo.cs       | 4 ++--
 .../platforms/dotnet/Apache.Ignite/Properties/AssemblyInfo.cs  | 4 ++--
 .../examples/Apache.Ignite.Examples/Properties/AssemblyInfo.cs | 4 ++--
 .../Apache.Ignite.ExamplesDll/Properties/AssemblyInfo.cs       | 4 ++--
 modules/rest-http/pom.xml                                      | 2 +-
 modules/scalar-2.10/pom.xml                                    | 2 +-
 modules/scalar/pom.xml                                         | 2 +-
 modules/schedule/pom.xml                                       | 2 +-
 modules/schema-import/pom.xml                                  | 2 +-
 modules/slf4j/pom.xml                                          | 2 +-
 modules/spark-2.10/pom.xml                                     | 2 +-
 modules/spark/pom.xml                                          | 2 +-
 modules/spring/pom.xml                                         | 2 +-
 modules/ssh/pom.xml                                            | 2 +-
 modules/tools/pom.xml                                          | 2 +-
 modules/twitter/pom.xml                                        | 5 ++---
 modules/urideploy/pom.xml                                      | 2 +-
 modules/visor-console-2.10/pom.xml                             | 2 +-
 modules/visor-console/pom.xml                                  | 2 +-
 modules/visor-plugins/pom.xml                                  | 2 +-
 modules/web/pom.xml                                            | 2 +-
 modules/yardstick/pom.xml                                      | 6 ++----
 modules/yarn/pom.xml                                           | 2 +-
 modules/zookeeper/pom.xml                                      | 2 +-
 pom.xml                                                        | 2 +-
 61 files changed, 75 insertions(+), 82 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/examples/pom.xml
----------------------------------------------------------------------
diff --git a/examples/pom.xml b/examples/pom.xml
index 52b152e..1b79525 100644
--- a/examples/pom.xml
+++ b/examples/pom.xml
@@ -17,8 +17,7 @@
   limitations under the License.
 -->
 
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" 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>
@@ -29,7 +28,7 @@
     </parent>
 
     <artifactId>ignite-examples</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/examples/schema-import/pom.xml
----------------------------------------------------------------------
diff --git a/examples/schema-import/pom.xml b/examples/schema-import/pom.xml
index 5bea512..ee6dc5e 100644
--- a/examples/schema-import/pom.xml
+++ b/examples/schema-import/pom.xml
@@ -35,7 +35,7 @@
     </properties>
 
     <artifactId>ignite-schema-import-demo</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/aop/pom.xml
----------------------------------------------------------------------
diff --git a/modules/aop/pom.xml b/modules/aop/pom.xml
index bb419fa..a2eb499 100644
--- a/modules/aop/pom.xml
+++ b/modules/aop/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-aop</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/apache-license-gen/pom.xml
----------------------------------------------------------------------
diff --git a/modules/apache-license-gen/pom.xml b/modules/apache-license-gen/pom.xml
index 5d14f89..f7cbd71 100644
--- a/modules/apache-license-gen/pom.xml
+++ b/modules/apache-license-gen/pom.xml
@@ -31,7 +31,7 @@
 
     <groupId>org.apache.ignite</groupId>
     <artifactId>ignite-apache-license-gen</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <build>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/aws/pom.xml
----------------------------------------------------------------------
diff --git a/modules/aws/pom.xml b/modules/aws/pom.xml
index 8042d33..281334c 100644
--- a/modules/aws/pom.xml
+++ b/modules/aws/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-aws</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/camel/pom.xml
----------------------------------------------------------------------
diff --git a/modules/camel/pom.xml b/modules/camel/pom.xml
index 60f0597..83982f8 100644
--- a/modules/camel/pom.xml
+++ b/modules/camel/pom.xml
@@ -20,8 +20,7 @@
 <!--
     POM file.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" 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>
@@ -32,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-camel</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/clients/pom.xml
----------------------------------------------------------------------
diff --git a/modules/clients/pom.xml b/modules/clients/pom.xml
index 4f1358b..808aff0 100644
--- a/modules/clients/pom.xml
+++ b/modules/clients/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-clients</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/cloud/pom.xml
----------------------------------------------------------------------
diff --git a/modules/cloud/pom.xml b/modules/cloud/pom.xml
index a49625d..2b5c7e5 100644
--- a/modules/cloud/pom.xml
+++ b/modules/cloud/pom.xml
@@ -29,7 +29,7 @@
     </parent>
 
     <artifactId>ignite-cloud</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/codegen/pom.xml
----------------------------------------------------------------------
diff --git a/modules/codegen/pom.xml b/modules/codegen/pom.xml
index 957049b..26da227 100644
--- a/modules/codegen/pom.xml
+++ b/modules/codegen/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-codegen</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/core/pom.xml
----------------------------------------------------------------------
diff --git a/modules/core/pom.xml b/modules/core/pom.xml
index e02bb23..13c3b34 100644
--- a/modules/core/pom.xml
+++ b/modules/core/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-core</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <repositories>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/core/src/main/resources/ignite.properties
----------------------------------------------------------------------
diff --git a/modules/core/src/main/resources/ignite.properties b/modules/core/src/main/resources/ignite.properties
index 2cf7d15..96443e1 100644
--- a/modules/core/src/main/resources/ignite.properties
+++ b/modules/core/src/main/resources/ignite.properties
@@ -15,7 +15,7 @@
 # limitations under the License.
 #
 
-ignite.version=1.5.0-SNAPSHOT
+ignite.version=1.5.0-EA-SNAPSHOT
 ignite.build=0
 ignite.revision=DEV
 ignite.rel.date=01011970

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/extdata/p2p/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/p2p/pom.xml b/modules/extdata/p2p/pom.xml
index 26d1cd2..b2515a1 100644
--- a/modules/extdata/p2p/pom.xml
+++ b/modules/extdata/p2p/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-extdata-p2p</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/extdata/uri/modules/uri-dependency/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/pom.xml b/modules/extdata/uri/modules/uri-dependency/pom.xml
index 08edb5b..0f4dc02 100644
--- a/modules/extdata/uri/modules/uri-dependency/pom.xml
+++ b/modules/extdata/uri/modules/uri-dependency/pom.xml
@@ -27,7 +27,7 @@
     <artifactId>ignite-extdata-uri-dep</artifactId>
     <packaging>jar</packaging>
 
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <modelVersion>4.0.0</modelVersion>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/extdata/uri/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/pom.xml b/modules/extdata/uri/pom.xml
index c5fb5cf..c335e82 100644
--- a/modules/extdata/uri/pom.xml
+++ b/modules/extdata/uri/pom.xml
@@ -32,7 +32,7 @@
     </parent>
 
     <artifactId>ignite-extdata-uri</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
 
     <dependencies>
         <dependency>
@@ -146,7 +146,7 @@
                                     </fileset>
                                 </copy>
 
-                                <mkdir dir="${basedir}/target/deploy_tmp/"/>
+                                <mkdir dir="${basedir}/target/deploy_tmp/" />
 
                                 <!--uri-classes.gar-->
                                 <gar destfile="${basedir}/target/deploy2/uri-classes.gar" basedir="${basedir}/target/classes" />

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/flume/pom.xml
----------------------------------------------------------------------
diff --git a/modules/flume/pom.xml b/modules/flume/pom.xml
index cd4ee98..006e4a1 100644
--- a/modules/flume/pom.xml
+++ b/modules/flume/pom.xml
@@ -20,8 +20,7 @@
 <!--
     POM file.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" 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>
@@ -32,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-flume</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/gce/pom.xml
----------------------------------------------------------------------
diff --git a/modules/gce/pom.xml b/modules/gce/pom.xml
index 1f8de08..32e1155 100644
--- a/modules/gce/pom.xml
+++ b/modules/gce/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-gce</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/geospatial/pom.xml
----------------------------------------------------------------------
diff --git a/modules/geospatial/pom.xml b/modules/geospatial/pom.xml
index 39ebdc4..ddbd491 100644
--- a/modules/geospatial/pom.xml
+++ b/modules/geospatial/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-geospatial</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/hadoop/pom.xml
----------------------------------------------------------------------
diff --git a/modules/hadoop/pom.xml b/modules/hadoop/pom.xml
index c2cb89b..0b0b229 100644
--- a/modules/hadoop/pom.xml
+++ b/modules/hadoop/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-hadoop</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/hibernate/pom.xml
----------------------------------------------------------------------
diff --git a/modules/hibernate/pom.xml b/modules/hibernate/pom.xml
index 8a04ab7..82d56a5 100644
--- a/modules/hibernate/pom.xml
+++ b/modules/hibernate/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-hibernate</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/indexing/pom.xml
----------------------------------------------------------------------
diff --git a/modules/indexing/pom.xml b/modules/indexing/pom.xml
index d539f6b..ba224ba 100644
--- a/modules/indexing/pom.xml
+++ b/modules/indexing/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-indexing</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/jcl/pom.xml
----------------------------------------------------------------------
diff --git a/modules/jcl/pom.xml b/modules/jcl/pom.xml
index c94c906..8a47ac6 100644
--- a/modules/jcl/pom.xml
+++ b/modules/jcl/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-jcl</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/jms11/pom.xml
----------------------------------------------------------------------
diff --git a/modules/jms11/pom.xml b/modules/jms11/pom.xml
index 3c37e7f..96290e2 100644
--- a/modules/jms11/pom.xml
+++ b/modules/jms11/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-jms11</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/jta/pom.xml
----------------------------------------------------------------------
diff --git a/modules/jta/pom.xml b/modules/jta/pom.xml
index 78242e7..a51b8cb 100644
--- a/modules/jta/pom.xml
+++ b/modules/jta/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-jta</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/kafka/pom.xml
----------------------------------------------------------------------
diff --git a/modules/kafka/pom.xml b/modules/kafka/pom.xml
index 89c1550..70519d2 100644
--- a/modules/kafka/pom.xml
+++ b/modules/kafka/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-kafka</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/log4j/pom.xml
----------------------------------------------------------------------
diff --git a/modules/log4j/pom.xml b/modules/log4j/pom.xml
index fe95700..e83ccca 100644
--- a/modules/log4j/pom.xml
+++ b/modules/log4j/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-log4j</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/log4j2/pom.xml
----------------------------------------------------------------------
diff --git a/modules/log4j2/pom.xml b/modules/log4j2/pom.xml
index eca3b75..7221f08 100644
--- a/modules/log4j2/pom.xml
+++ b/modules/log4j2/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-log4j2</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/mesos/pom.xml
----------------------------------------------------------------------
diff --git a/modules/mesos/pom.xml b/modules/mesos/pom.xml
index 466805c..9b7e8ed 100644
--- a/modules/mesos/pom.xml
+++ b/modules/mesos/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-mesos</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/mqtt/pom.xml
----------------------------------------------------------------------
diff --git a/modules/mqtt/pom.xml b/modules/mqtt/pom.xml
index 21511e8..b786946 100644
--- a/modules/mqtt/pom.xml
+++ b/modules/mqtt/pom.xml
@@ -20,8 +20,7 @@
 <!--
     POM file.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" 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>
@@ -32,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-mqtt</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/cpp/common/configure.ac
----------------------------------------------------------------------
diff --git a/modules/platforms/cpp/common/configure.ac b/modules/platforms/cpp/common/configure.ac
index 5cab969..8f53ea3 100644
--- a/modules/platforms/cpp/common/configure.ac
+++ b/modules/platforms/cpp/common/configure.ac
@@ -19,7 +19,7 @@
 # Process this file with autoconf to produce a configure script.
 
 AC_PREREQ([2.69])
-AC_INIT([Apache Ignite JNI bridge for C++], [1.5.0], [dev@ignite.apache.org], [ignite-common], [ignite.apache.org])
+AC_INIT([Apache Ignite JNI bridge for C++], [1.5.0-EA], [dev@ignite.apache.org], [ignite-common], [ignite.apache.org])
 AC_CONFIG_SRCDIR(src)
 
 AC_CANONICAL_SYSTEM

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/cpp/core-test/configure.ac
----------------------------------------------------------------------
diff --git a/modules/platforms/cpp/core-test/configure.ac b/modules/platforms/cpp/core-test/configure.ac
index b337fba..14baf55 100644
--- a/modules/platforms/cpp/core-test/configure.ac
+++ b/modules/platforms/cpp/core-test/configure.ac
@@ -19,7 +19,7 @@
 # Process this file with autoconf to produce a configure script.
 
 AC_PREREQ([2.69])
-AC_INIT([Apache Ignite C++ Test], [1.5.0], [dev@ignite.apache.org], [ignite], [ignite.apache.org])
+AC_INIT([Apache Ignite C++ Test], [1.5.0-EA], [dev@ignite.apache.org], [ignite], [ignite.apache.org])
 AC_CONFIG_SRCDIR(src)
 
 AC_CANONICAL_SYSTEM

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/cpp/core/configure.ac
----------------------------------------------------------------------
diff --git a/modules/platforms/cpp/core/configure.ac b/modules/platforms/cpp/core/configure.ac
index c1657d3..f10eeb9 100644
--- a/modules/platforms/cpp/core/configure.ac
+++ b/modules/platforms/cpp/core/configure.ac
@@ -19,7 +19,7 @@
 # Process this file with autoconf to produce a configure script.
 
 AC_PREREQ([2.69])
-AC_INIT([Apache Ignite C++], [1.5.0], [dev@ignite.apache.org], [ignite], [ignite.apache.org])
+AC_INIT([Apache Ignite C++], [1.5.0-EA], [dev@ignite.apache.org], [ignite], [ignite.apache.org])
 AC_CONFIG_SRCDIR(src)
 
 AC_CANONICAL_SYSTEM

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/cpp/examples/configure.ac
----------------------------------------------------------------------
diff --git a/modules/platforms/cpp/examples/configure.ac b/modules/platforms/cpp/examples/configure.ac
index a5e902d..2d30028 100644
--- a/modules/platforms/cpp/examples/configure.ac
+++ b/modules/platforms/cpp/examples/configure.ac
@@ -2,7 +2,7 @@
 # Process this file with autoconf to produce a configure script.
 
 AC_PREREQ([2.69])
-AC_INIT([Ingnite C++ examples],[1.4.0],[dec@ignite.apache.org],[ignite-examples],[ignite.apache.org])
+AC_INIT([Ingnite C++ examples],[1.5.0-EA],[dec@ignite.apache.org],[ignite-examples],[ignite.apache.org])
 AC_CONFIG_SRCDIR(src)
 
 AC_CANONICAL_SYSTEM

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/cpp/ignite/configure.ac
----------------------------------------------------------------------
diff --git a/modules/platforms/cpp/ignite/configure.ac b/modules/platforms/cpp/ignite/configure.ac
index 7705797..41d944c 100644
--- a/modules/platforms/cpp/ignite/configure.ac
+++ b/modules/platforms/cpp/ignite/configure.ac
@@ -19,7 +19,7 @@
 # Process this file with autoconf to produce a configure script.
 
 AC_PREREQ([2.69])
-AC_INIT([Apache Ignite C++ Runner], [1.5.0], [dev@ignite.apache.org], [ignite], [ignite.apache.org])
+AC_INIT([Apache Ignite C++ Runner], [1.5.0-EA], [dev@ignite.apache.org], [ignite], [ignite.apache.org])
 AC_CONFIG_SRCDIR(src)
 
 AC_CANONICAL_SYSTEM

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/Apache.Ignite.Benchmarks/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Benchmarks/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/Apache.Ignite.Benchmarks/Properties/AssemblyInfo.cs
index 09d4993..79a980c 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Benchmarks/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Benchmarks/Properties/AssemblyInfo.cs
@@ -31,5 +31,5 @@ using System.Runtime.InteropServices;
 
 [assembly: Guid("8fae8395-7e91-411a-a78f-44d6d3fed0fc")]
 
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
\ No newline at end of file
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/Apache.Ignite.Core.Tests.TestDll/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests.TestDll/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/Apache.Ignite.Core.Tests.TestDll/Properties/AssemblyInfo.cs
index 5d9610e..f967e73 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests.TestDll/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests.TestDll/Properties/AssemblyInfo.cs
@@ -45,5 +45,5 @@ using System.Runtime.InteropServices;
 // You can specify all the values or you can default the Build and Revision Numbers 
 // by using the '*' as shown below:
 // [assembly: AssemblyVersion("1.0.*")]
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Properties/AssemblyInfo.cs
index 2bf822d..7dbe612 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Properties/AssemblyInfo.cs
@@ -31,5 +31,5 @@ using System.Runtime.InteropServices;
 
 [assembly: Guid("de8dd5cc-7c7f-4a09-80d5-7086d9416a7b")]
 
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
\ No newline at end of file
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/Apache.Ignite.Core/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Properties/AssemblyInfo.cs
index c2f46b8..b6e0e5a 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Properties/AssemblyInfo.cs
@@ -33,8 +33,8 @@ using System.Runtime.InteropServices;
 
 [assembly: Guid("97db45a8-f922-456a-a819-7b3c6e5e03ba")]
 
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]
 
 [assembly: CLSCompliant(true)]
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/Apache.Ignite/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/Apache.Ignite/Properties/AssemblyInfo.cs
index 60f81b3..b50be27 100644
--- a/modules/platforms/dotnet/Apache.Ignite/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/Apache.Ignite/Properties/AssemblyInfo.cs
@@ -31,5 +31,5 @@ using System.Runtime.InteropServices;
 
 [assembly: Guid("0f9702ec-da7d-4ce5-b4b7-73310c885355")]
 
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
\ No newline at end of file
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/examples/Apache.Ignite.Examples/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/examples/Apache.Ignite.Examples/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/examples/Apache.Ignite.Examples/Properties/AssemblyInfo.cs
index 0880a82..4e26b64 100644
--- a/modules/platforms/dotnet/examples/Apache.Ignite.Examples/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/examples/Apache.Ignite.Examples/Properties/AssemblyInfo.cs
@@ -31,5 +31,5 @@
 
 [assembly: Guid("41a0cb95-3435-4c78-b867-900b28e2c9ee")]
 
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
\ No newline at end of file
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/platforms/dotnet/examples/Apache.Ignite.ExamplesDll/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/examples/Apache.Ignite.ExamplesDll/Properties/AssemblyInfo.cs b/modules/platforms/dotnet/examples/Apache.Ignite.ExamplesDll/Properties/AssemblyInfo.cs
index d7681db..52f84c9 100644
--- a/modules/platforms/dotnet/examples/Apache.Ignite.ExamplesDll/Properties/AssemblyInfo.cs
+++ b/modules/platforms/dotnet/examples/Apache.Ignite.ExamplesDll/Properties/AssemblyInfo.cs
@@ -31,5 +31,5 @@ using System.Reflection;
 
 [assembly: Guid("ce65ec7c-d3cf-41ad-8f45-f90d5af68d77")]
 
-[assembly: AssemblyVersion("1.5.0")]
-[assembly: AssemblyFileVersion("1.5.0")]
\ No newline at end of file
+[assembly: AssemblyVersion("1.5.0-EA")]
+[assembly: AssemblyFileVersion("1.5.0-EA")]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/rest-http/pom.xml
----------------------------------------------------------------------
diff --git a/modules/rest-http/pom.xml b/modules/rest-http/pom.xml
index 9aa79f2..e777078 100644
--- a/modules/rest-http/pom.xml
+++ b/modules/rest-http/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-rest-http</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/scalar-2.10/pom.xml
----------------------------------------------------------------------
diff --git a/modules/scalar-2.10/pom.xml b/modules/scalar-2.10/pom.xml
index c2046e9..82c07b6 100644
--- a/modules/scalar-2.10/pom.xml
+++ b/modules/scalar-2.10/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-scalar_2.10</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/scalar/pom.xml
----------------------------------------------------------------------
diff --git a/modules/scalar/pom.xml b/modules/scalar/pom.xml
index c8dce64..9106110 100644
--- a/modules/scalar/pom.xml
+++ b/modules/scalar/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-scalar</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/schedule/pom.xml
----------------------------------------------------------------------
diff --git a/modules/schedule/pom.xml b/modules/schedule/pom.xml
index 3f53df6..d26c833 100644
--- a/modules/schedule/pom.xml
+++ b/modules/schedule/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-schedule</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/schema-import/pom.xml
----------------------------------------------------------------------
diff --git a/modules/schema-import/pom.xml b/modules/schema-import/pom.xml
index 1e63cae..3157dac 100644
--- a/modules/schema-import/pom.xml
+++ b/modules/schema-import/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-schema-import</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/slf4j/pom.xml
----------------------------------------------------------------------
diff --git a/modules/slf4j/pom.xml b/modules/slf4j/pom.xml
index b22ae6c..14754eb 100644
--- a/modules/slf4j/pom.xml
+++ b/modules/slf4j/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-slf4j</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/spark-2.10/pom.xml
----------------------------------------------------------------------
diff --git a/modules/spark-2.10/pom.xml b/modules/spark-2.10/pom.xml
index 4697693..55c5386 100644
--- a/modules/spark-2.10/pom.xml
+++ b/modules/spark-2.10/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-spark_2.10</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/spark/pom.xml
----------------------------------------------------------------------
diff --git a/modules/spark/pom.xml b/modules/spark/pom.xml
index 93c3e41..386ef32 100644
--- a/modules/spark/pom.xml
+++ b/modules/spark/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-spark</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/spring/pom.xml
----------------------------------------------------------------------
diff --git a/modules/spring/pom.xml b/modules/spring/pom.xml
index 8d1f918..9b6446f 100644
--- a/modules/spring/pom.xml
+++ b/modules/spring/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-spring</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/ssh/pom.xml
----------------------------------------------------------------------
diff --git a/modules/ssh/pom.xml b/modules/ssh/pom.xml
index 5028322..678fb28 100644
--- a/modules/ssh/pom.xml
+++ b/modules/ssh/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-ssh</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/tools/pom.xml
----------------------------------------------------------------------
diff --git a/modules/tools/pom.xml b/modules/tools/pom.xml
index 26689760..746466f 100644
--- a/modules/tools/pom.xml
+++ b/modules/tools/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-tools</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/twitter/pom.xml
----------------------------------------------------------------------
diff --git a/modules/twitter/pom.xml b/modules/twitter/pom.xml
index 6c02935..644951f 100644
--- a/modules/twitter/pom.xml
+++ b/modules/twitter/pom.xml
@@ -20,8 +20,7 @@
 <!--
     POM file.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" 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>
@@ -32,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-twitter</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/urideploy/pom.xml
----------------------------------------------------------------------
diff --git a/modules/urideploy/pom.xml b/modules/urideploy/pom.xml
index c8fac6e..0008fba 100644
--- a/modules/urideploy/pom.xml
+++ b/modules/urideploy/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-urideploy</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/visor-console-2.10/pom.xml
----------------------------------------------------------------------
diff --git a/modules/visor-console-2.10/pom.xml b/modules/visor-console-2.10/pom.xml
index 73c7a58..ffa449c 100644
--- a/modules/visor-console-2.10/pom.xml
+++ b/modules/visor-console-2.10/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-visor-console_2.10</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/visor-console/pom.xml
----------------------------------------------------------------------
diff --git a/modules/visor-console/pom.xml b/modules/visor-console/pom.xml
index e514a0f..69280c5 100644
--- a/modules/visor-console/pom.xml
+++ b/modules/visor-console/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-visor-console</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/visor-plugins/pom.xml
----------------------------------------------------------------------
diff --git a/modules/visor-plugins/pom.xml b/modules/visor-plugins/pom.xml
index 05b4ede..dc56f2e 100644
--- a/modules/visor-plugins/pom.xml
+++ b/modules/visor-plugins/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-visor-plugins</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/web/pom.xml
----------------------------------------------------------------------
diff --git a/modules/web/pom.xml b/modules/web/pom.xml
index 99a356e..b7c7daa 100644
--- a/modules/web/pom.xml
+++ b/modules/web/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-web</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/yardstick/pom.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/pom.xml b/modules/yardstick/pom.xml
index 5bb41b3..31fa2fd 100644
--- a/modules/yardstick/pom.xml
+++ b/modules/yardstick/pom.xml
@@ -20,9 +20,7 @@
 <!--
     POM file.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0"
-         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" 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>
@@ -33,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-yardstick</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/yarn/pom.xml
----------------------------------------------------------------------
diff --git a/modules/yarn/pom.xml b/modules/yarn/pom.xml
index d1f6390..d771d82 100644
--- a/modules/yarn/pom.xml
+++ b/modules/yarn/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-yarn</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/modules/zookeeper/pom.xml
----------------------------------------------------------------------
diff --git a/modules/zookeeper/pom.xml b/modules/zookeeper/pom.xml
index 303b941..af485f3 100644
--- a/modules/zookeeper/pom.xml
+++ b/modules/zookeeper/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-zookeeper</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <url>http://ignite.apache.org</url>
 
     <properties>

http://git-wip-us.apache.org/repos/asf/ignite/blob/6260fc1f/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 115df88..af54e52 100644
--- a/pom.xml
+++ b/pom.xml
@@ -32,7 +32,7 @@
 
     <groupId>org.apache.ignite</groupId>
     <artifactId>apache-ignite</artifactId>
-    <version>1.5.0-SNAPSHOT</version>
+    <version>1.5.0-EA-SNAPSHOT</version>
     <packaging>pom</packaging>
 
     <properties>


[09/12] ignite git commit: Merge remote-tracking branch 'origin/ignite-1.5' into ignite-1.5_

Posted by ag...@apache.org.
Merge remote-tracking branch 'origin/ignite-1.5' into ignite-1.5_


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

Branch: refs/heads/ignite-1.5.1
Commit: 3d6973b403e2cfe44c31d590a14a738ad37552e7
Parents: 776af1a aee20d9
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Nov 30 17:33:09 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Nov 30 17:33:09 2015 +0300

----------------------------------------------------------------------
 .../GridDeploymentPerVersionStore.java          |  12 +-
 .../distributed/dht/GridDhtLockFuture.java      |  17 ++-
 .../communication/tcp/TcpCommunicationSpi.java  |  12 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java |   9 +-
 .../IgniteCacheStoreValueAbstractTest.java      | 111 +++++++++++--------
 .../cache/IgniteCacheTxPreloadNoWriteTest.java  |   2 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   3 +-
 ...eRebalancingUnmarshallingFailedSelfTest.java |  13 ++-
 .../GridCacheLocalIsolatedNodesSelfTest.java    |   6 +-
 9 files changed, 116 insertions(+), 69 deletions(-)
----------------------------------------------------------------------



[04/12] ignite git commit: minor

Posted by ag...@apache.org.
minor


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

Branch: refs/heads/ignite-1.5.1
Commit: 8e605e9f33c99a4f8404bff3dd8902f4b08704da
Parents: 0fcc1d1
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Nov 30 16:45:27 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Nov 30 16:45:27 2015 +0300

----------------------------------------------------------------------
 .../rest/handlers/cache/GridCacheCommandHandlerSelfTest.java   | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/8e605e9f/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
index e58eb54..484ee87 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
@@ -71,10 +71,10 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
         // Grid config.
         IgniteConfiguration cfg = super.getConfiguration();
 
-        cfg.setLocalHost("localhost");
+        cfg.setLocalHost("127.0.0.1");
 
         ConnectorConfiguration clnCfg = new ConnectorConfiguration();
-        clnCfg.setHost("localhost");
+        clnCfg.setHost("127.0.0.1");
 
         cfg.setConnectorConfiguration(clnCfg);
         cfg.setDiscoverySpi(disco);
@@ -239,4 +239,4 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
                 });
         }
     }
-}
\ No newline at end of file
+}