You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2017/04/10 09:05:25 UTC

[1/6] ignite git commit: ignite-3477-master mute test

Repository: ignite
Updated Branches:
  refs/heads/ignite-3477-master 2e996471f -> 4f0061b31


ignite-3477-master mute test


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

Branch: refs/heads/ignite-3477-master
Commit: c824b35293a9e131aec4848323bca94acbc7c2da
Parents: abe7118
Author: Dmitriy Govorukhin <dg...@gridgain.com>
Authored: Fri Apr 7 15:44:54 2017 +0300
Committer: Dmitriy Govorukhin <dg...@gridgain.com>
Committed: Fri Apr 7 15:44:54 2017 +0300

----------------------------------------------------------------------
 .../internal/processors/cache/ClusterStateAbstractTest.java     | 5 ++---
 1 file changed, 2 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/c824b352/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateAbstractTest.java
index 731d3a6..f095e79 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateAbstractTest.java
@@ -280,8 +280,7 @@ public abstract class ClusterStateAbstractTest extends GridCommonAbstractTest {
      * @throws Exception If fails.
      */
     public void testDeactivationWithPendingLock() throws Exception {
-        //TODO GG-11851
-        fail();
+        fail("https://issues.apache.org/jira/browse/IGNITE-4931");
 
         startGrids(GRID_CNT);
 
@@ -338,7 +337,7 @@ public abstract class ClusterStateAbstractTest extends GridCommonAbstractTest {
      * @throws Exception If fails.
      */
     public void testDeactivationWithPendingTransaction() throws Exception {
-        fail("Safe way for deactivate cluster must be implemented.");
+        fail("https://issues.apache.org/jira/browse/IGNITE-4931");
 
         startGrids(GRID_CNT);
 


[4/6] ignite git commit: ignite-3477-master remove GridCache(Atomic|Dht|Near)ExpiredEntriesPreloadSelfTest (update)

Posted by ag...@apache.org.
ignite-3477-master remove GridCache(Atomic|Dht|Near)ExpiredEntriesPreloadSelfTest (update)


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

Branch: refs/heads/ignite-3477-master
Commit: 24d68a74401e4281c5fc3422dc39028a4014e057
Parents: 6be3a03
Author: Dmitriy Govorukhin <dg...@gridgain.com>
Authored: Mon Apr 10 11:21:41 2017 +0300
Committer: Dmitriy Govorukhin <dg...@gridgain.com>
Committed: Mon Apr 10 11:21:41 2017 +0300

----------------------------------------------------------------------
 ...heExpiredEntriesPreloadAbstractSelfTest.java | 122 -------------------
 1 file changed, 122 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/24d68a74/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheExpiredEntriesPreloadAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheExpiredEntriesPreloadAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheExpiredEntriesPreloadAbstractSelfTest.java
deleted file mode 100644
index 97c937a..0000000
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheExpiredEntriesPreloadAbstractSelfTest.java
+++ /dev/null
@@ -1,122 +0,0 @@
-/*
- * 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;
-
-import java.util.Collection;
-import javax.cache.expiry.Duration;
-import javax.cache.expiry.ExpiryPolicy;
-import javax.cache.expiry.TouchedExpiryPolicy;
-import org.apache.ignite.Ignite;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.configuration.CacheConfiguration;
-import org.apache.ignite.events.Event;
-import org.apache.ignite.internal.IgniteKernal;
-import org.apache.ignite.internal.processors.cache.GridCacheAbstractSelfTest;
-import org.apache.ignite.internal.processors.cache.GridCacheAdapter;
-import org.apache.ignite.internal.util.typedef.F;
-import org.apache.ignite.internal.util.typedef.PAX;
-import org.apache.ignite.internal.util.typedef.internal.U;
-import org.apache.ignite.testframework.GridTestUtils;
-
-import static java.util.concurrent.TimeUnit.MILLISECONDS;
-import static org.apache.ignite.cache.CacheRebalanceMode.SYNC;
-import static org.apache.ignite.events.EventType.EVT_CACHE_REBALANCE_OBJECT_LOADED;
-
-/**
- * Tests preloading of expired entries.
- */
-public abstract class GridCacheExpiredEntriesPreloadAbstractSelfTest extends GridCacheAbstractSelfTest {
-    /** */
-    private static final int GRID_CNT = 2;
-
-    /** {@inheritDoc} */
-    @Override protected void beforeTest() throws Exception {
-        startGrid(0);
-    }
-
-    /** {@inheritDoc} */
-    @Override protected void afterTest() throws Exception {
-        stopAllGrids();
-    }
-
-    /** {@inheritDoc} */
-    @Override protected void beforeTestsStarted() throws Exception {
-    }
-
-    /** {@inheritDoc} */
-    @Override protected int gridCount() {
-        return GRID_CNT;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected CacheConfiguration cacheConfiguration(String igniteInstanceName) throws Exception {
-        CacheConfiguration cfg = super.cacheConfiguration(igniteInstanceName);
-
-        cfg.setRebalanceMode(SYNC);
-        cfg.setCacheStoreFactory(null);
-        cfg.setWriteThrough(false);
-        cfg.setReadThrough(false);
-
-        return cfg;
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    public void testExpiredEntriesPreloading() throws Exception {
-        IgniteCache<String, Integer> cache0 = jcache(0);
-
-        final int KEYS_NUM = 3;
-
-        for (int i = 0; i < KEYS_NUM; i++)
-            cache0.put(String.valueOf(i), 0);
-
-        final ExpiryPolicy expiry = new TouchedExpiryPolicy(new Duration(MILLISECONDS, 100L));
-
-        IgniteCache cache = grid(0).cache(null).withExpiryPolicy(expiry);
-
-        for (int i = 0; i < KEYS_NUM; i++)
-            cache.put(String.valueOf(i), i);
-
-        // Allow entries to expire.
-        U.sleep(1000);
-
-        // Ensure entries expiration.
-        for (int i = 0; i < KEYS_NUM; i++)
-            assert cache0.get(String.valueOf(i)) == null;
-
-        // Start another node.
-        Ignite g1 = startGrid(1);
-
-        final GridCacheAdapter<String, Integer> cache1 = ((IgniteKernal)g1).context().cache().internalCache();
-
-        cache1.preloader().syncFuture().get();
-
-        Collection<Event> evts = g1.events().localQuery(F.<Event>alwaysTrue(), EVT_CACHE_REBALANCE_OBJECT_LOADED);
-
-        assertEquals("Expected all entries are preloaded.", KEYS_NUM, evts.size());
-
-        boolean rmv = GridTestUtils.waitForCondition(new PAX() {
-            @Override public boolean applyx() {
-                return cache1.isEmpty();
-            }
-        }, 10_000);
-
-        assertTrue("Expired entries were not removed.", rmv);
-    }
-}
\ No newline at end of file


[2/6] ignite git commit: remove GridCache(Atomic|Dht|Near)ExpiredEntriesPreloadSelfTest

Posted by ag...@apache.org.
remove GridCache(Atomic|Dht|Near)ExpiredEntriesPreloadSelfTest


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

Branch: refs/heads/ignite-3477-master
Commit: aa66de672fde2ea5b615400132a71248c240bca9
Parents: c824b35
Author: Konstantin Dudkov <kd...@ya.ru>
Authored: Fri Apr 7 17:18:53 2017 +0300
Committer: Konstantin Dudkov <kd...@ya.ru>
Committed: Fri Apr 7 18:02:40 2017 +0300

----------------------------------------------------------------------
 ...acheAtomicExpiredEntriesPreloadSelfTest.java | 46 --------------------
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java | 39 -----------------
 ...dCacheNearExpiredEntriesPreloadSelfTest.java | 33 --------------
 .../testsuites/IgniteCacheTestSuite2.java       |  9 +---
 4 files changed, 1 insertion(+), 126 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/aa66de67/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheAtomicExpiredEntriesPreloadSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheAtomicExpiredEntriesPreloadSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheAtomicExpiredEntriesPreloadSelfTest.java
deleted file mode 100644
index a78c7f9..0000000
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheAtomicExpiredEntriesPreloadSelfTest.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * 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.dht;
-
-import org.apache.ignite.cache.CacheAtomicityMode;
-import org.apache.ignite.cache.CacheMode;
-import org.apache.ignite.configuration.NearCacheConfiguration;
-import org.apache.ignite.internal.processors.cache.distributed.GridCacheExpiredEntriesPreloadAbstractSelfTest;
-
-import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
-import static org.apache.ignite.cache.CacheMode.PARTITIONED;
-
-/**
- * Tests preloading of expired entries.
- */
-public class GridCacheAtomicExpiredEntriesPreloadSelfTest extends GridCacheExpiredEntriesPreloadAbstractSelfTest {
-    /** {@inheritDoc} */
-    @Override protected CacheMode cacheMode() {
-        return PARTITIONED;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected CacheAtomicityMode atomicityMode() {
-        return ATOMIC;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected NearCacheConfiguration nearConfiguration() {
-        return null;
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/aa66de67/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheDhtExpiredEntriesPreloadSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheDhtExpiredEntriesPreloadSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheDhtExpiredEntriesPreloadSelfTest.java
deleted file mode 100644
index 9603d48..0000000
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCacheDhtExpiredEntriesPreloadSelfTest.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/*
- * 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.dht;
-
-import org.apache.ignite.cache.CacheMode;
-import org.apache.ignite.configuration.NearCacheConfiguration;
-import org.apache.ignite.internal.processors.cache.distributed.GridCacheExpiredEntriesPreloadAbstractSelfTest;
-
-import static org.apache.ignite.cache.CacheMode.PARTITIONED;
-
-/**
- * Tests preloading of expired entries.
- */
-public class GridCacheDhtExpiredEntriesPreloadSelfTest extends GridCacheExpiredEntriesPreloadAbstractSelfTest {
-    /** {@inheritDoc} */
-    @Override protected CacheMode cacheMode() {
-        return PARTITIONED;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected NearCacheConfiguration nearConfiguration() {
-        return null;
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/aa66de67/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearExpiredEntriesPreloadSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearExpiredEntriesPreloadSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearExpiredEntriesPreloadSelfTest.java
deleted file mode 100644
index c31c60e..0000000
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearExpiredEntriesPreloadSelfTest.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * 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 org.apache.ignite.cache.CacheMode;
-import org.apache.ignite.internal.processors.cache.distributed.GridCacheExpiredEntriesPreloadAbstractSelfTest;
-
-import static org.apache.ignite.cache.CacheMode.PARTITIONED;
-
-/**
- * Tests preloading of expired entries.
- */
-public class GridCacheNearExpiredEntriesPreloadSelfTest extends GridCacheExpiredEntriesPreloadAbstractSelfTest {
-    /** {@inheritDoc} */
-    @Override protected CacheMode cacheMode() {
-        return PARTITIONED;
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/aa66de67/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite2.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite2.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite2.java
index 09c0c4c..a9df142 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite2.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite2.java
@@ -37,11 +37,11 @@ import org.apache.ignite.internal.processors.cache.GridCachePartitionedGetSelfTe
 import org.apache.ignite.internal.processors.cache.GridCachePartitionedProjectionAffinitySelfTest;
 import org.apache.ignite.internal.processors.cache.GridCacheVariableTopologySelfTest;
 import org.apache.ignite.internal.processors.cache.IgniteAtomicCacheEntryProcessorNodeJoinTest;
-import org.apache.ignite.internal.processors.cache.MemoryPolicyConfigValidationTest;
 import org.apache.ignite.internal.processors.cache.IgniteCacheEntryProcessorNodeJoinTest;
 import org.apache.ignite.internal.processors.cache.IgniteCacheIncrementTxTest;
 import org.apache.ignite.internal.processors.cache.IgniteCachePartitionMapUpdateTest;
 import org.apache.ignite.internal.processors.cache.IgniteDynamicCacheAndNodeStop;
+import org.apache.ignite.internal.processors.cache.MemoryPolicyConfigValidationTest;
 import org.apache.ignite.internal.processors.cache.distributed.CacheLoadingConcurrentGridStartSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.CacheLoadingConcurrentGridStartSelfTestAllowOverwrite;
 import org.apache.ignite.internal.processors.cache.distributed.CacheLockReleaseNodeLeaveTest;
@@ -52,14 +52,12 @@ import org.apache.ignite.internal.processors.cache.distributed.IgniteCacheClient
 import org.apache.ignite.internal.processors.cache.distributed.IgniteCacheClientNodePartitionsExchangeTest;
 import org.apache.ignite.internal.processors.cache.distributed.IgniteCacheNearOffheapGetSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.IgniteCacheServerNodeConcurrentStart;
-import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicExpiredEntriesPreloadSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheColocatedOptimisticTransactionSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheColocatedPreloadRestartSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheColocatedPrimarySyncSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheColocatedTxSingleThreadedSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEntrySelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionsDisabledSelfTest;
-import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtExpiredEntriesPreloadSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtMappingSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadBigDataSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest;
@@ -77,7 +75,6 @@ import org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePart
 import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteCachePartitionedBackupNodeFailureRecoveryTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearMultiNodeSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearReadersSelfTest;
-import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearExpiredEntriesPreloadSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearJobExecutionSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiGetSelfTest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest;
@@ -238,10 +235,6 @@ public class IgniteCacheTestSuite2 extends TestSuite {
         suite.addTest(new TestSuite(GridCacheNearPartitionedClearSelfTest.class));
         suite.addTest(new TestSuite(IgniteCacheNearOffheapGetSelfTest.class));
 
-        suite.addTest(new TestSuite(GridCacheDhtExpiredEntriesPreloadSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheNearExpiredEntriesPreloadSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheAtomicExpiredEntriesPreloadSelfTest.class));
-
         suite.addTest(new TestSuite(GridCacheOffheapUpdateSelfTest.class));
 
         suite.addTest(new TestSuite(GridCacheNearPrimarySyncSelfTest.class));


[6/6] ignite git commit: Merge branch 'ignite-3477-master' of https://github.com/gridgain/apache-ignite into ignite-3477-master

Posted by ag...@apache.org.
Merge branch 'ignite-3477-master' of https://github.com/gridgain/apache-ignite into ignite-3477-master


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

Branch: refs/heads/ignite-3477-master
Commit: 4f0061b31ee71dff1297b8b601abc5599a94d31d
Parents: 2e99647 973f335
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Mon Apr 10 12:05:05 2017 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Mon Apr 10 12:05:05 2017 +0300

----------------------------------------------------------------------
 .../apache/ignite/internal/IgniteKernal.java    |   3 +
 .../org/apache/ignite/internal/IgnitionEx.java  |   2 +-
 .../processors/cache/GridCacheProcessor.java    |  25 ++++
 .../cache/IgniteCacheOffheapManagerImpl.java    |   8 +-
 .../IgniteCacheDatabaseSharedManager.java       |   6 +-
 .../cache/CacheClientStoreSelfTest.java         |   4 +
 .../cache/CacheStopAndDestroySelfTest.java      |  48 ++++++--
 .../cache/ClusterStateAbstractTest.java         |   5 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java | 122 -------------------
 ...acheAtomicExpiredEntriesPreloadSelfTest.java |  46 -------
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java |  39 ------
 ...dCacheNearExpiredEntriesPreloadSelfTest.java |  33 -----
 .../testsuites/IgniteCacheTestSuite2.java       |   9 +-
 13 files changed, 81 insertions(+), 269 deletions(-)
----------------------------------------------------------------------



[5/6] ignite git commit: Offheap MemoryPolicies can be configured for client nodes, exception is thrown when no MemoryPolicy is configured

Posted by ag...@apache.org.
Offheap MemoryPolicies can be configured for client nodes, exception is thrown when no MemoryPolicy is configured


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

Branch: refs/heads/ignite-3477-master
Commit: 973f3352554f9d5784fb21a4ec6e537561c2d40e
Parents: 24d68a7
Author: Sergey Chugunov <se...@gmail.com>
Authored: Wed Apr 5 19:58:08 2017 +0300
Committer: Sergey Chugunov <se...@gmail.com>
Committed: Mon Apr 10 11:45:55 2017 +0300

----------------------------------------------------------------------
 .../apache/ignite/internal/IgniteKernal.java    |  3 ++
 .../org/apache/ignite/internal/IgnitionEx.java  |  2 +-
 .../processors/cache/GridCacheProcessor.java    | 25 ++++++++++
 .../cache/IgniteCacheOffheapManagerImpl.java    |  8 +---
 .../IgniteCacheDatabaseSharedManager.java       |  6 ++-
 .../cache/CacheClientStoreSelfTest.java         |  4 ++
 .../cache/CacheStopAndDestroySelfTest.java      | 48 ++++++++++++++++----
 7 files changed, 78 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index 9c661df..286ced0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
@@ -2430,6 +2430,9 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
     private void ackMemoryConfiguration() {
         MemoryConfiguration memCfg = cfg.getMemoryConfiguration();
 
+        if (memCfg == null)
+            return;
+
         U.log(log, "System cache MemoryPolicy size is configured to " +
                 (memCfg.getSystemCacheMemorySize() / (1024 * 1024)) +
         "MB size. " +

http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index 15ca88b..c701411 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -2102,7 +2102,7 @@ public class IgnitionEx {
 
             initializeDefaultCacheConfiguration(myCfg);
 
-            if (myCfg.getMemoryConfiguration() == null) {
+            if (!myCfg.isClientMode() && myCfg.getMemoryConfiguration() == null) {
                 MemoryConfiguration dbCfg = new MemoryConfiguration();
 
                 dbCfg.setConcurrencyLevel(Runtime.getRuntime().availableProcessors() * 4);

http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
index ab5db28..2564787 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
@@ -390,6 +390,27 @@ public class GridCacheProcessor extends GridProcessorAdapter {
     }
 
     /**
+     * @param c Ignite Configuration.
+     * @param cc Cache Configuration.
+     * @return {@code true} if cache is starting on client node and this node is affinity node for the cache.
+     */
+    private boolean storesLocallyOnClient(IgniteConfiguration c,
+                                          CacheConfiguration cc) {
+        if (c.isClientMode()
+                && c.getMemoryConfiguration() == null) {
+            if (cc.getCacheMode() == LOCAL)
+                return true;
+
+            if (ctx.discovery().cacheAffinityNode(ctx.discovery().localNode(), cc.getName()))
+                return true;
+
+            return false;
+        }
+        else
+            return false;
+    }
+
+    /**
      * @param c Ignite configuration.
      * @param cc Configuration to validate.
      * @param cacheType Cache type.
@@ -410,6 +431,10 @@ public class GridCacheProcessor extends GridProcessorAdapter {
             }
         }
 
+        if (storesLocallyOnClient(c, cc))
+            throw new IgniteCheckedException("MemoryPolicy for client caches must be explicitly configured " +
+                    "on client node startup. Use MemoryConfiguration to configure MemoryPolicy.");
+
         if (cc.getCacheMode() == LOCAL && !cc.getAffinity().getClass().equals(LocalAffinityFunction.class))
             U.warn(log, "AffinityFunction configuration parameter will be ignored for local cache [cacheName=" +
                 U.maskName(cc.getName()) + ']');

http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
index a1aea2f..9b10d71 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
@@ -119,15 +119,9 @@ public class IgniteCacheOffheapManagerImpl extends GridCacheManagerAdapter imple
     @Override protected void start0() throws IgniteCheckedException {
         super.start0();
 
-        updateValSizeThreshold = cctx.kernalContext().config().getMemoryConfiguration().getPageSize() / 2;
+        updateValSizeThreshold = cctx.shared().database().pageSize() / 2;
 
         if (cctx.affinityNode()) {
-            if (cctx.kernalContext().clientNode()) {
-                assert cctx.isLocal() : cctx.name();
-
-                cctx.shared().database().init();
-            }
-
             cctx.shared().database().checkpointReadLock();
 
             try {

http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/database/IgniteCacheDatabaseSharedManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/database/IgniteCacheDatabaseSharedManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/database/IgniteCacheDatabaseSharedManager.java
index 300e935..d61130b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/database/IgniteCacheDatabaseSharedManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/database/IgniteCacheDatabaseSharedManager.java
@@ -80,8 +80,10 @@ public class IgniteCacheDatabaseSharedManager extends GridCacheSharedManagerAdap
 
     /** {@inheritDoc} */
     @Override protected void start0() throws IgniteCheckedException {
-        if (!cctx.kernalContext().clientNode())
-            init();
+        if (cctx.kernalContext().clientNode() && cctx.kernalContext().config().getMemoryConfiguration() == null)
+            return;
+
+        init();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheClientStoreSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheClientStoreSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheClientStoreSelfTest.java
index b2588a9..35442bb 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheClientStoreSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheClientStoreSelfTest.java
@@ -32,6 +32,7 @@ import org.apache.ignite.cache.store.CacheStore;
 import org.apache.ignite.cache.store.CacheStoreAdapter;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.configuration.MemoryConfiguration;
 import org.apache.ignite.configuration.NearCacheConfiguration;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.lang.IgniteBiInClosure;
@@ -73,6 +74,9 @@ public class CacheClientStoreSelfTest extends GridCommonAbstractTest {
 
         cfg.setClientMode(client);
 
+        if (client)
+            cfg.setMemoryConfiguration(new MemoryConfiguration());
+
         CacheConfiguration cc = new CacheConfiguration();
 
         cc.setName(CACHE_NAME);

http://git-wip-us.apache.org/repos/asf/ignite/blob/973f3352/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheStopAndDestroySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheStopAndDestroySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheStopAndDestroySelfTest.java
index ef6c5fd..1a7e76a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheStopAndDestroySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheStopAndDestroySelfTest.java
@@ -28,6 +28,7 @@ import org.apache.ignite.IgniteException;
 import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.configuration.MemoryConfiguration;
 import org.apache.ignite.configuration.NearCacheConfiguration;
 import org.apache.ignite.internal.managers.communication.GridIoMessage;
 import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
@@ -68,18 +69,16 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
     /** local cache name. */
     protected static String CACHE_NAME_LOC = "cache_local";
 
-    /** {@inheritDoc} */
-    @Override protected void beforeTest() throws Exception {
-        super.beforeTest();
-
-        startGridsMultiThreaded(gridCount());
-    }
+    /** Memory configuration to be used on client nodes with local caches. */
+    private static MemoryConfiguration memCfg;
 
     /** {@inheritDoc} */
     @Override protected void afterTest() throws Exception {
         super.afterTest();
 
         stopAllGrids();
+
+        memCfg = null;
     }
 
     /**
@@ -93,9 +92,12 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
     @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
         IgniteConfiguration iCfg = super.getConfiguration(igniteInstanceName);
 
-        if (getTestIgniteInstanceName(2).equals(igniteInstanceName))
+        if (getTestIgniteInstanceName(2).equals(igniteInstanceName)) {
             iCfg.setClientMode(true);
 
+            iCfg.setMemoryConfiguration(memCfg);
+        }
+
         ((TcpDiscoverySpi)iCfg.getDiscoverySpi()).setIpFinder(ipFinder);
         ((TcpDiscoverySpi)iCfg.getDiscoverySpi()).setForceServerMode(true);
 
@@ -192,6 +194,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testDhtDoubleDestroy() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         dhtDestroy();
 
         dhtDestroy();
@@ -230,6 +234,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testClientDoubleDestroy() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         clientDestroy();
 
         clientDestroy();
@@ -268,6 +274,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testNearDoubleDestroy() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         nearDestroy();
 
         nearDestroy();
@@ -306,6 +314,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testLocalDoubleDestroy() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         localDestroy();
 
         localDestroy();
@@ -339,6 +349,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testDhtClose() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         IgniteCache<Integer, Integer> dhtCache0 = grid(0).getOrCreateCache(getDhtConfig());
 
         final Integer key = primaryKey(dhtCache0);
@@ -418,6 +430,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testDhtCloseWithTry() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         String curVal = null;
 
         for (int i = 0; i < 3; i++) {
@@ -453,6 +467,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testClientClose() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         IgniteCache<String, String> cache0 = grid(0).getOrCreateCache(getClientConfig());
 
         assert cache0.get(KEY_VAL) == null;
@@ -502,6 +518,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testClientCloseWithTry() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         String curVal = null;
 
         for (int i = 0; i < 3; i++) {
@@ -541,6 +559,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
     public void testNearClose() throws Exception {
         fail("https://issues.apache.org/jira/browse/IGNITE-2189");
 
+        startGridsMultiThreaded(gridCount());
+
         IgniteCache<String, String> cache0 = grid(0).getOrCreateCache(getNearConfig());
 
         // GridDhtTxPrepareRequest requests to Client node will be counted.
@@ -615,6 +635,8 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testNearCloseWithTry() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         String curVal = null;
 
         grid(0).getOrCreateCache(getNearConfig());
@@ -651,6 +673,10 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testLocalClose() throws Exception {
+        memCfg = new MemoryConfiguration();
+
+        startGridsMultiThreaded(gridCount());
+
         grid(0).getOrCreateCache(getLocalConfig());
 
         assert grid(0).cache(CACHE_NAME_LOC).get(KEY_VAL) == null;
@@ -695,6 +721,10 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testLocalCloseWithTry() throws Exception {
+        memCfg = new MemoryConfiguration();
+
+        startGridsMultiThreaded(gridCount());
+
         String curVal = null;
 
         for (int i = 0; i < 3; i++) {
@@ -722,7 +752,9 @@ public class CacheStopAndDestroySelfTest extends GridCommonAbstractTest {
     /**
      * Tests start -> destroy -> start -> close using CacheManager.
      */
-    public void testTckStyleCreateDestroyClose() {
+    public void testTckStyleCreateDestroyClose() throws Exception {
+        startGridsMultiThreaded(gridCount());
+
         CacheManager mgr = Caching.getCachingProvider().getCacheManager();
 
         String cacheName = "cache";


[3/6] ignite git commit: Merge remote-tracking branch 'origin/ignite-3477-master' into ignite-3477-master

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


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

Branch: refs/heads/ignite-3477-master
Commit: 6be3a035778ebf9b023b003a462606c83e2cffa3
Parents: aa66de6 c449d6e
Author: Dmitriy Govorukhin <dg...@gridgain.com>
Authored: Mon Apr 10 11:19:57 2017 +0300
Committer: Dmitriy Govorukhin <dg...@gridgain.com>
Committed: Mon Apr 10 11:19:57 2017 +0300

----------------------------------------------------------------------
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java |   2 +
 .../src/main/java/org/apache/ignite/Ignite.java |   8 +
 .../java/org/apache/ignite/MemoryMetrics.java   |  95 +++
 .../binary/BinaryAbstractIdentityResolver.java  |  53 --
 .../binary/BinaryArrayIdentityResolver.java     | 224 -----
 .../binary/BinaryFieldIdentityResolver.java     | 307 -------
 .../ignite/binary/BinaryIdentityResolver.java   |  42 -
 .../ignite/binary/BinaryTypeConfiguration.java  |  25 -
 .../org/apache/ignite/cache/CacheMetrics.java   |  70 --
 .../configuration/MemoryConfiguration.java      |   4 +-
 .../apache/ignite/internal/IgniteKernal.java    |   7 +-
 .../binary/BinaryAbstractIdentityResolver.java  |  56 ++
 .../binary/BinaryArrayIdentityResolver.java     | 222 +++++
 .../ignite/internal/binary/BinaryContext.java   |   4 +-
 .../internal/binary/BinaryIdentityResolver.java |  43 +
 .../internal/binary/BinaryObjectExImpl.java     |   1 -
 .../internal/binary/BinaryWriterExImpl.java     |   1 -
 .../pagemem/impl/PageMemoryNoStoreImpl.java     |  11 +-
 .../cache/CacheClusterMetricsMXBeanImpl.java    |  50 --
 .../cache/CacheLocalMetricsMXBeanImpl.java      |  50 --
 .../processors/cache/CacheMetricsImpl.java      | 125 +--
 .../processors/cache/CacheMetricsSnapshot.java  | 120 ---
 .../processors/cache/GridCacheProcessor.java    |   3 +
 .../IgniteCacheDatabaseSharedManager.java       |  98 ++-
 .../cache/database/IgniteMemoryPoolMetrics.java |  33 -
 .../cache/database/MemoryMetricsImpl.java       | 314 +++++++
 .../processors/cache/database/MemoryPolicy.java |  18 +-
 .../cache/database/freelist/FreeListImpl.java   |  35 +
 .../cache/database/tree/BPlusTree.java          | 110 ++-
 .../platform/cache/PlatformCache.java           |  10 -
 .../utils/PlatformConfigurationUtils.java       |  64 +-
 .../apache/ignite/internal/util/IgniteTree.java |  14 +
 .../visor/node/VisorMemoryConfiguration.java    |   1 -
 .../ignite/mxbean/CacheMetricsMXBean.java       |  40 -
 .../ignite/mxbean/MemoryMetricsMXBean.java      |  89 ++
 .../BinaryArrayIdentityResolverSelfTest.java    |   4 -
 .../BinaryFieldIdentityResolverSelfTest.java    | 333 --------
 ...ryIdentityResolverConfigurationSelfTest.java | 138 ----
 .../BinaryObjectBuilderAdditionalSelfTest.java  |   1 -
 ...naryObjectBuilderDefaultMappersSelfTest.java |   1 -
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java  |   3 +-
 .../cache/CacheConfigurationLeakTest.java       |   3 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |  58 +-
 ...LocalCacheOffHeapAndSwapMetricsSelfTest.java | 182 +----
 .../processors/database/BPlusTreeSelfTest.java  |  31 +-
 .../database/FreeListImplSelfTest.java          |   5 +-
 .../database/MemoryMetricsSelfTest.java         | 313 +++++++
 .../database/MetadataStorageSelfTest.java       |   3 +-
 .../processors/igfs/IgfsIgniteMock.java         |   8 +
 .../platform/PlatformCacheWriteMetricsTask.java | 126 +--
 .../ignite/testframework/junits/IgniteMock.java |   6 +
 .../junits/multijvm/IgniteProcessProxy.java     |   6 +
 .../ignite/testsuites/IgniteBasicTestSuite.java |   2 +
 .../IgniteBinaryObjectsTestSuite.java           |   4 -
 .../HibernateAccessStrategyAdapter.java         |   8 +-
 .../cache/hibernate/HibernateCacheProxy.java    | 811 +++++++++++++++++++
 .../hibernate/HibernateCollectionRegion.java    |   3 +-
 .../cache/hibernate/HibernateEntityRegion.java  |   3 +-
 .../hibernate/HibernateGeneralDataRegion.java   |   3 +-
 .../hibernate/HibernateKeyTransformer.java      |  28 +
 .../cache/hibernate/HibernateKeyWrapper.java    |  62 ++
 .../hibernate/HibernateNaturalIdRegion.java     |   3 +-
 .../HibernateNonStrictAccessStrategy.java       |   5 +-
 .../hibernate/HibernateQueryResultsRegion.java  |   3 +-
 .../HibernateReadOnlyAccessStrategy.java        |   3 +-
 .../HibernateReadWriteAccessStrategy.java       |   3 +-
 .../ignite/cache/hibernate/HibernateRegion.java |   6 +-
 .../cache/hibernate/HibernateRegionFactory.java |  29 +-
 .../hibernate/HibernateTimestampsRegion.java    |   3 +-
 .../HibernateTransactionalAccessStrategy.java   |   2 +-
 .../HibernateTransactionalDataRegion.java       |   3 +-
 .../IgniteBinaryHibernateTestSuite.java         |  37 +
 .../query/h2/database/H2TreeIndex.java          |  16 +-
 .../query/h2/opt/GridH2TreeIndex.java           |  29 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java | 129 ---
 .../IgniteCacheInsertSqlQuerySelfTest.java      |  40 -
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |  38 -
 .../query/h2/IgniteSqlQueryMinMaxTest.java      | 376 +++++++++
 .../h2/database/InlineIndexHelperTest.java      |   4 +
 .../query/h2/opt/GridH2TableSelfTest.java       |  50 ++
 .../IgniteCacheQuerySelfTestSuite.java          |   2 +
 modules/platforms/cpp/binary/Makefile.am        |   1 -
 .../platforms/cpp/binary/include/Makefile.am    |   3 -
 .../binary/binary_array_identity_resolver.h     |  64 --
 .../ignite/binary/binary_identity_resolver.h    |  61 --
 .../include/ignite/binary/binary_object.h       |  12 +-
 .../binary/include/ignite/binary/binary_type.h  |  10 -
 .../ignite/impl/binary/binary_type_impl.h       | 149 ----
 .../ignite/impl/binary/binary_writer_impl.h     |   5 +-
 .../cpp/binary/project/vs/binary.vcxproj        |   4 -
 .../binary/project/vs/binary.vcxproj.filters    |  12 -
 .../binary/binary_array_identity_resolver.cpp   |  42 -
 .../cpp/core-test/config/cache-test.xml         |   2 +-
 .../core-test/include/ignite/binary_test_defs.h |  25 -
 .../cpp/core-test/include/ignite/complex_type.h |   2 -
 .../cpp/core-test/include/ignite/test_type.h    |   1 -
 .../src/binary_identity_resolver_test.cpp       | 254 ------
 .../cpp/core-test/src/cache_invoke_test.cpp     |   3 -
 .../cpp/core-test/src/cache_query_test.cpp      |   2 -
 .../platforms/cpp/core-test/src/cache_test.cpp  |   3 +-
 .../cpp/core-test/src/continuous_query_test.cpp |   6 -
 .../cpp/odbc-test/include/complex_type.h        |   2 -
 .../platforms/cpp/odbc-test/include/test_type.h |   1 -
 .../Binary/BinaryEqualityComparerTest.cs        | 220 ++---
 .../Cache/Query/CacheDmlQueriesTest.cs          |  13 +-
 .../IgniteConfigurationSerializerTest.cs        |   9 +-
 .../IgniteConfigurationTest.cs                  |   7 +-
 .../Apache.Ignite.Core.csproj                   |   5 +-
 .../Binary/BinaryArrayEqualityComparer.cs       | 160 ----
 .../Binary/BinaryTypeConfiguration.cs           |  13 -
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  43 -
 .../IgniteConfigurationSection.xsd              |  14 -
 .../Impl/Binary/BinaryArrayEqualityComparer.cs  | 159 ++++
 .../Binary/BinaryEqualityComparerSerializer.cs  | 100 +--
 .../Impl/Binary/BinaryFieldEqualityComparer.cs  | 138 ----
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |  20 -
 .../Impl/Binary/BinaryObject.cs                 |   2 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |   7 +-
 .../Binary/BinarySurrogateTypeDescriptor.cs     |   6 -
 .../Impl/Binary/BinaryUtils.cs                  |  10 -
 .../Impl/Binary/BinaryWriter.cs                 |   6 +-
 .../Impl/Binary/IBinaryEqualityComparer.cs      |  63 --
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |   5 -
 .../Impl/Binary/Marshaller.cs                   |  24 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   7 +
 .../ant/beautifier/GridJavadocAntTask.java      |  18 +-
 126 files changed, 3253 insertions(+), 3735 deletions(-)
----------------------------------------------------------------------