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/27 13:04:02 UTC

[2/2] ignite git commit: IGNITE-5090 - Get rid of startSize configuration property

IGNITE-5090 - Get rid of startSize configuration property


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

Branch: refs/heads/ignite-2.0
Commit: b2aeac7512ae578a7eb63c209fb4b68ab3166c83
Parents: 7bfff3b
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Thu Apr 27 16:04:40 2017 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Thu Apr 27 16:04:40 2017 +0300

----------------------------------------------------------------------
 .../ignite/ignite-cassandra-server-template.xml |  3 --
 .../tests/ignite-cassandra-client-template.xml  |  3 --
 .../clients/src/test/resources/spring-cache.xml |  9 ------
 .../apache/ignite/IgniteSystemProperties.java   |  3 ++
 .../configuration/CacheConfiguration.java       | 31 +-------------------
 .../processors/cache/GridCacheAdapter.java      | 19 ++++++++----
 .../distributed/dht/GridDhtLocalPartition.java  |  3 +-
 .../processors/cache/local/GridLocalCache.java  |  3 +-
 .../utils/PlatformConfigurationUtils.java       |  2 --
 .../visor/cache/VisorCacheConfiguration.java    | 13 --------
 .../spring-cache-client-benchmark-1.xml         |  3 --
 .../spring-cache-client-benchmark-2.xml         |  3 --
 .../spring-cache-client-benchmark-3.xml         |  3 --
 modules/core/src/test/config/example-cache.xml  |  3 --
 .../src/test/config/load/cache-benchmark.xml    |  4 ---
 .../test/config/load/cache-client-benchmark.xml |  2 --
 .../config/load/dsi-49-server-production.xml    |  2 --
 .../src/test/config/load/dsi-load-client.xml    |  2 --
 .../src/test/config/load/dsi-load-server.xml    |  2 --
 .../core/src/test/config/spring-multicache.xml  | 17 -----------
 .../config/websession/example-cache-base.xml    |  3 --
 .../cache/GridCacheConcurrentMapSelfTest.java   |  1 -
 .../cache/GridCachePutAllFailoverSelfTest.java  |  1 -
 .../CacheLateAffinityAssignmentTest.java        |  1 -
 ...GridCachePreloadRestartAbstractSelfTest.java |  1 -
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |  1 -
 ...idCachePartitionedHitsAndMissesSelfTest.java |  1 -
 .../GridCachePartitionedNodeRestartTest.java    |  1 -
 ...ePartitionedOptimisticTxNodeRestartTest.java |  1 -
 .../GridCacheReplicatedNodeRestartSelfTest.java |  2 --
 .../cache/eviction/EvictionAbstractTest.java    |  1 -
 .../lru/LruNearEvictionPolicySelfTest.java      |  1 -
 .../LruNearOnlyNearEvictionPolicySelfTest.java  |  1 -
 .../IgniteDataStreamerPerformanceTest.java      |  1 -
 .../loadtests/GridCacheMultiNodeLoadTest.java   |  1 -
 .../capacity/spring-capacity-cache.xml          |  3 --
 .../loadtests/colocation/spring-colocation.xml  |  5 ----
 .../GridCachePartitionedAtomicLongLoadTest.java |  1 -
 .../configvariations/ConfigVariations.java      |  2 --
 .../testframework/junits/GridAbstractTest.java  |  1 -
 .../webapp/META-INF/ignite-webapp-config.xml    | 12 --------
 .../matrix/SparseDistributedMatrixStorage.java  |  3 --
 .../config/cache-query-continuous-default.xml   |  1 -
 .../Config/ignite-config.xml                    |  1 -
 .../Cache/CacheConfigurationTest.cs             | 10 -------
 .../Config/Compute/compute-grid1.xml            |  3 --
 .../Config/Compute/compute-grid2.xml            |  1 -
 .../Config/Dynamic/dynamic-data.xml             |  2 --
 .../Config/cache-query-continuous.xml           |  4 ---
 .../Config/native-client-test-cache.xml         |  9 ------
 .../IgniteConfigurationSerializerTest.cs        |  1 -
 .../Cache/Configuration/CacheConfiguration.cs   | 12 --------
 .../Configuration/NearCacheConfiguration.cs     |  2 +-
 .../IgniteConfigurationSection.xsd              |  5 ----
 .../scalar/src/test/resources/spring-cache.xml  |  3 --
 .../java/org/apache/ignite/internal/cache.xml   |  3 --
 .../apache/ignite/internal/filtered-cache.xml   |  3 --
 .../apache/ignite/internal/invalid-cache.xml    |  6 ----
 .../commands/cache/VisorCacheCommand.scala      |  1 -
 modules/web-console/backend/app/mongo.js        |  1 -
 .../generator/ConfigurationGenerator.js         |  2 --
 .../generator/PlatformGenerator.js              |  2 --
 .../generator/defaults/Cache.service.js         |  1 -
 .../states/configuration/caches/memory.pug      |  9 ------
 .../demo/service/DemoCachesLoadService.java     |  1 -
 .../service/DemoRandomCacheLoadService.java     |  1 -
 .../webapp2/META-INF/ignite-webapp-config.xml   | 12 --------
 67 files changed, 21 insertions(+), 250 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/cassandra/store/src/test/bootstrap/aws/ignite/ignite-cassandra-server-template.xml
----------------------------------------------------------------------
diff --git a/modules/cassandra/store/src/test/bootstrap/aws/ignite/ignite-cassandra-server-template.xml b/modules/cassandra/store/src/test/bootstrap/aws/ignite/ignite-cassandra-server-template.xml
index 01000d2..692cd8b 100644
--- a/modules/cassandra/store/src/test/bootstrap/aws/ignite/ignite-cassandra-server-template.xml
+++ b/modules/cassandra/store/src/test/bootstrap/aws/ignite/ignite-cassandra-server-template.xml
@@ -115,7 +115,6 @@
                 <!-- Configuring persistence for "cache1" cache -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache1"/>
-                    <property name="startSize" value="1000000"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="backups" value="0"/>
                     <property name="readThrough" value="true"/>
@@ -132,7 +131,6 @@
                 <!-- Configuring persistence for "cache2" cache -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache2"/>
-                    <property name="startSize" value="1000000"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="backups" value="0"/>
                     <property name="readThrough" value="true"/>
@@ -149,7 +147,6 @@
                 <!-- Configuring persistence for "cache3" cache -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache3"/>
-                    <property name="startSize" value="1000000"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="backups" value="0"/>
                     <property name="readThrough" value="true"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/cassandra/store/src/test/bootstrap/aws/tests/ignite-cassandra-client-template.xml
----------------------------------------------------------------------
diff --git a/modules/cassandra/store/src/test/bootstrap/aws/tests/ignite-cassandra-client-template.xml b/modules/cassandra/store/src/test/bootstrap/aws/tests/ignite-cassandra-client-template.xml
index c5a9c9a..2989563 100644
--- a/modules/cassandra/store/src/test/bootstrap/aws/tests/ignite-cassandra-client-template.xml
+++ b/modules/cassandra/store/src/test/bootstrap/aws/tests/ignite-cassandra-client-template.xml
@@ -118,7 +118,6 @@
                 <!-- Configuring persistence for "cache1" cache -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache1"/>
-                    <property name="startSize" value="1000000"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="backups" value="0"/>
                     <property name="readThrough" value="true"/>
@@ -135,7 +134,6 @@
                 <!-- Configuring persistence for "cache2" cache -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache2"/>
-                    <property name="startSize" value="1000000"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="backups" value="0"/>
                     <property name="readThrough" value="true"/>
@@ -152,7 +150,6 @@
                 <!-- Configuring persistence for "cache3" cache -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache3"/>
-                    <property name="startSize" value="1000000"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="backups" value="0"/>
                     <property name="readThrough" value="true"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/clients/src/test/resources/spring-cache.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-cache.xml b/modules/clients/src/test/resources/spring-cache.xml
index 8cbc688..86946f6 100644
--- a/modules/clients/src/test/resources/spring-cache.xml
+++ b/modules/clients/src/test/resources/spring-cache.xml
@@ -70,9 +70,6 @@
                         <bean class="org.apache.ignite.configuration.NearCacheConfiguration"/>
                     </property>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="1500000"/>
-
                     <!--
                         Setting this value will cause local node to wait for remote commits.
                         However, it's important to set it this way in the examples as we assert on
@@ -110,9 +107,6 @@
 
                     <!-- Set synchronous rebalancing (default is asynchronous). -->
                     <property name="rebalanceMode" value="SYNC"/>
-
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="150000"/>
                 </bean>
 
                 <!--
@@ -124,9 +118,6 @@
 
                     <!-- LOCAL cache mode. -->
                     <property name="cacheMode" value="LOCAL"/>
-
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="150000"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
index 37e8c6b..96930f8 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
@@ -583,6 +583,9 @@ public final class IgniteSystemProperties {
      */
     public static final String IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE = "IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE";
 
+    /** Cache start size for on-heap maps. Defaults to 4096. */
+    public static final String IGNITE_CACHE_START_SIZE = "IGNITE_CACHE_START_SIZE";
+
     /** Returns true for system properties only avoiding sending sensitive information. */
     private static final IgnitePredicate<Map.Entry<String, String>> PROPS_FILTER = new IgnitePredicate<Map.Entry<String, String>>() {
         @Override public boolean apply(final Map.Entry<String, String> entry) {

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
index b0fcbc0..11fc43a 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
@@ -122,9 +122,6 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
     /** Default lock timeout. */
     public static final long DFLT_LOCK_TIMEOUT = 0;
 
-    /** Initial default cache size. */
-    public static final int DFLT_START_SIZE = 1500000;
-
     /** Default cache size to use with eviction policy. */
     public static final int DFLT_CACHE_SIZE = 100000;
 
@@ -132,7 +129,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
     public static final int DFLT_SQL_INDEX_MAX_INLINE_SIZE = -1;
 
     /** Initial default near cache size. */
-    public static final int DFLT_NEAR_START_SIZE = DFLT_START_SIZE / 4;
+    public static final int DFLT_NEAR_START_SIZE = 1500000 / 4;
 
     /** Default value for 'invalidate' flag that indicates if this is invalidation-based cache. */
     public static final boolean DFLT_INVALIDATE = false;
@@ -232,9 +229,6 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
     /** Default lock timeout. */
     private long dfltLockTimeout = DFLT_LOCK_TIMEOUT;
 
-    /** Default cache start size. */
-    private int startSize = DFLT_START_SIZE;
-
     /** Near cache configuration. */
     private NearCacheConfiguration<K, V> nearCfg;
 
@@ -445,7 +439,6 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
         sqlSchema = cc.getSqlSchema();
         sqlEscapeAll = cc.isSqlEscapeAll();
         sqlFuncCls = cc.getSqlFunctionClasses();
-        startSize = cc.getStartSize();
         storeFactory = cc.getCacheStoreFactory();
         storeSesLsnrs = cc.getCacheStoreSessionListenerFactories();
         tmLookupClsName = cc.getTransactionManagerLookupClassName();
@@ -673,28 +666,6 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
     }
 
     /**
-     * Gets initial cache size which will be used to pre-create internal
-     * hash table after start. Default value is defined by {@link #DFLT_START_SIZE}.
-     *
-     * @return Initial cache size.
-     */
-    public int getStartSize() {
-        return startSize;
-    }
-
-    /**
-     * Initial size for internal hash map.
-     *
-     * @param startSize Cache start size.
-     * @return {@code this} for chaining.
-     */
-    public CacheConfiguration<K, V> setStartSize(int startSize) {
-        this.startSize = startSize;
-
-        return this;
-    }
-
-    /**
      * Gets flag indicating whether value should be loaded from store if it is not in the cache
      * for following cache operations:
      * <ul>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
index b364df8..0b1ab74 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
@@ -161,6 +161,10 @@ public abstract class GridCacheAdapter<K, V> implements IgniteInternalCache<K, V
     /** clearLocally() split threshold. */
     public static final int CLEAR_ALL_SPLIT_THRESHOLD = 10000;
 
+    /** Default cache start size. */
+    public static final int DFLT_START_CACHE_SIZE = IgniteSystemProperties.getInteger(
+        IgniteSystemProperties.IGNITE_CACHE_START_SIZE, 4096);
+
     /** Size of keys batch to removeAll. */
     // TODO GG-11231 (workaround for GG-11231).
     private static final int REMOVE_ALL_KEYS_BATCH = 10000;
@@ -295,6 +299,14 @@ public abstract class GridCacheAdapter<K, V> implements IgniteInternalCache<K, V
 
     /**
      * @param ctx Cache context.
+     */
+    @SuppressWarnings("OverriddenMethodCallDuringObjectConstruction")
+    protected GridCacheAdapter(GridCacheContext<K, V> ctx) {
+        this(ctx, DFLT_START_CACHE_SIZE);
+    }
+
+    /**
+     * @param ctx Cache context.
      * @param startSize Start size.
      */
     @SuppressWarnings("OverriddenMethodCallDuringObjectConstruction")
@@ -549,12 +561,7 @@ public abstract class GridCacheAdapter<K, V> implements IgniteInternalCache<K, V
      */
     public void start() throws IgniteCheckedException {
         if (map == null) {
-            int initSize = ctx.config().getStartSize();
-
-            if (!isLocal())
-                initSize /= ctx.affinity().partitions();
-
-            map = new GridCacheLocalConcurrentMap(ctx, entryFactory(), initSize);
+            map = new GridCacheLocalConcurrentMap(ctx, entryFactory(), DFLT_START_CACHE_SIZE);
         }
     }
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLocalPartition.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLocalPartition.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLocalPartition.java
index 6b4c2ad..5425954 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLocalPartition.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtLocalPartition.java
@@ -34,6 +34,7 @@ import org.apache.ignite.internal.IgniteInternalFuture;
 import org.apache.ignite.internal.NodeStoppingException;
 import org.apache.ignite.internal.pagemem.wal.record.delta.PartitionMetaStateRecord;
 import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
+import org.apache.ignite.internal.processors.cache.GridCacheAdapter;
 import org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapImpl;
 import org.apache.ignite.internal.processors.cache.GridCacheContext;
 import org.apache.ignite.internal.processors.cache.GridCacheEntryEx;
@@ -138,7 +139,7 @@ public class GridDhtLocalPartition extends GridCacheConcurrentMapImpl implements
      */
     @SuppressWarnings("ExternalizableWithoutPublicNoArgConstructor")
     GridDhtLocalPartition(GridCacheContext cctx, int id, GridCacheMapEntryFactory entryFactory) {
-        super(cctx, entryFactory, cctx.config().getStartSize() / cctx.affinity().partitions());
+        super(cctx, entryFactory, Math.max(10, GridCacheAdapter.DFLT_START_CACHE_SIZE / cctx.affinity().partitions()));
 
         this.id = id;
         this.cctx = cctx;

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/local/GridLocalCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/local/GridLocalCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/local/GridLocalCache.java
index 9d202d4..94f618a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/local/GridLocalCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/local/GridLocalCache.java
@@ -20,7 +20,6 @@ package org.apache.ignite.internal.processors.cache.local;
 import java.io.Externalizable;
 import java.util.Collection;
 import java.util.concurrent.Callable;
-import java.util.concurrent.atomic.AtomicLong;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.cache.CachePeekMode;
 import org.apache.ignite.internal.IgniteInternalFuture;
@@ -66,7 +65,7 @@ public class GridLocalCache<K, V> extends GridCacheAdapter<K, V> {
      * @param ctx Cache registry.
      */
     public GridLocalCache(GridCacheContext<K, V> ctx) {
-        super(ctx, ctx.config().getStartSize());
+        super(ctx, DFLT_START_CACHE_SIZE);
 
         preldr = new GridCachePreloaderAdapter(ctx);
     }

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
index 6de5db8..908b63c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
@@ -162,7 +162,6 @@ public class PlatformConfigurationUtils {
         ccfg.setRebalanceThrottle(in.readLong());
         ccfg.setRebalanceTimeout(in.readLong());
         ccfg.setSqlEscapeAll(in.readBoolean());
-        ccfg.setStartSize(in.readInt());
         ccfg.setWriteBehindBatchSize(in.readInt());
         ccfg.setWriteBehindEnabled(in.readBoolean());
         ccfg.setWriteBehindFlushFrequency(in.readLong());
@@ -795,7 +794,6 @@ public class PlatformConfigurationUtils {
         writer.writeLong(ccfg.getRebalanceThrottle());
         writer.writeLong(ccfg.getRebalanceTimeout());
         writer.writeBoolean(ccfg.isSqlEscapeAll());
-        writer.writeInt(ccfg.getStartSize());
         writer.writeInt(ccfg.getWriteBehindBatchSize());
         writer.writeBoolean(ccfg.isWriteBehindEnabled());
         writer.writeLong(ccfg.getWriteBehindFlushFrequency());

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
index c1b56c1..f40df80 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
@@ -63,9 +63,6 @@ public class VisorCacheConfiguration extends VisorDataTransferObject {
     /** Invalidate. */
     private boolean invalidate;
 
-    /** Start size. */
-    private int startSize;
-
     /** Max concurrent async operations. */
     private int maxConcurrentAsyncOps;
 
@@ -182,7 +179,6 @@ public class VisorCacheConfiguration extends VisorDataTransferObject {
         eagerTtl = ccfg.isEagerTtl();
         writeSynchronizationMode = ccfg.getWriteSynchronizationMode();
         invalidate = ccfg.isInvalidate();
-        startSize = ccfg.getStartSize();
         maxConcurrentAsyncOps = ccfg.getMaxConcurrentAsyncOperations();
         interceptor = compactClass(ccfg.getInterceptor());
         dfltLockTimeout = ccfg.getDefaultLockTimeout();
@@ -265,13 +261,6 @@ public class VisorCacheConfiguration extends VisorDataTransferObject {
     }
 
     /**
-     * @return Start size.
-     */
-    public int getStartSize() {
-        return startSize;
-    }
-
-    /**
      * @return Max concurrent async operations
      */
     public int getMaxConcurrentAsyncOperations() {
@@ -519,7 +508,6 @@ public class VisorCacheConfiguration extends VisorDataTransferObject {
         out.writeBoolean(eagerTtl);
         U.writeEnum(out, writeSynchronizationMode);
         out.writeBoolean(invalidate);
-        out.writeInt(startSize);
         out.writeInt(maxConcurrentAsyncOps);
         U.writeString(out, interceptor);
         out.writeLong(dfltLockTimeout);
@@ -562,7 +550,6 @@ public class VisorCacheConfiguration extends VisorDataTransferObject {
         eagerTtl = in.readBoolean();
         writeSynchronizationMode = CacheWriteSynchronizationMode.fromOrdinal(in.readByte());
         invalidate = in.readBoolean();
-        startSize = in.readInt();
         maxConcurrentAsyncOps = in.readInt();
         interceptor = U.readString(in);
         dfltLockTimeout = in.readLong();

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
index 374585b..868f88e 100644
--- a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
+++ b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
@@ -71,9 +71,6 @@
 
                     <property name="cacheMode" value="PARTITIONED"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="10000"/>
-
                     <property name="swapEnabled" value="false"/>
 
                     <property name="writeSynchronizationMode" value="FULL_ASYNC"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
index ec6fd76..543b0f5 100644
--- a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
+++ b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
@@ -69,9 +69,6 @@
 
                     <property name="cacheMode" value="PARTITIONED"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="10000"/>
-
                     <property name="swapEnabled" value="false"/>
 
                     <property name="writeSynchronizationMode" value="FULL_ASYNC"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
index c74262a..10ebffb 100644
--- a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
+++ b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
@@ -69,9 +69,6 @@
 
                     <property name="cacheMode" value="PARTITIONED"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="10000"/>
-
                     <property name="swapEnabled" value="false"/>
 
                     <property name="writeSynchronizationMode" value="FULL_ASYNC"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/example-cache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/example-cache.xml b/modules/core/src/test/config/example-cache.xml
index 95be5b3..596f7ad 100644
--- a/modules/core/src/test/config/example-cache.xml
+++ b/modules/core/src/test/config/example-cache.xml
@@ -129,9 +129,6 @@
 
     <!-- Template for all example cache configurations. -->
     <bean id="cache-template" abstract="true" class="org.apache.ignite.configuration.CacheConfiguration">
-        <!-- Initial cache size. -->
-        <property name="startSize" value="3000000"/>
-
         <!-- Set synchronous rebalancing (default is asynchronous). -->
         <property name="rebalanceMode" value="SYNC"/>
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/load/cache-benchmark.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/cache-benchmark.xml b/modules/core/src/test/config/load/cache-benchmark.xml
index d43cd61..4422b53 100644
--- a/modules/core/src/test/config/load/cache-benchmark.xml
+++ b/modules/core/src/test/config/load/cache-benchmark.xml
@@ -39,8 +39,6 @@
                     <property name="swapEnabled" value="false"/>
 
                     <property name="writeSynchronizationMode" value="FULL_ASYNC"/>
-
-                    <property name="startSize" value="400000"/>
                 </bean>
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="local"/>
@@ -50,8 +48,6 @@
                     <property name="swapEnabled" value="false"/>
 
                     <property name="writeSynchronizationMode" value="FULL_ASYNC"/>
-
-                    <property name="startSize" value="400000"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/load/cache-client-benchmark.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/cache-client-benchmark.xml b/modules/core/src/test/config/load/cache-client-benchmark.xml
index 34da940..41bd974 100644
--- a/modules/core/src/test/config/load/cache-client-benchmark.xml
+++ b/modules/core/src/test/config/load/cache-client-benchmark.xml
@@ -39,8 +39,6 @@
                     <property name="swapEnabled" value="false"/>
 
                     <property name="writeSynchronizationMode" value="FULL_ASYNC"/>
-
-                    <property name="startSize" value="400000"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/load/dsi-49-server-production.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/dsi-49-server-production.xml b/modules/core/src/test/config/load/dsi-49-server-production.xml
index 5887c63..346731c 100644
--- a/modules/core/src/test/config/load/dsi-49-server-production.xml
+++ b/modules/core/src/test/config/load/dsi-49-server-production.xml
@@ -41,7 +41,6 @@
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="PARTITIONED_CACHE"/>
                     <property name="cacheMode" value="PARTITIONED"/>
-                    <property name="startSize" value="500000"/>
                     <property name="rebalanceMode" value="SYNC"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="evictionPolicy">
@@ -69,7 +68,6 @@
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="REPLICATED_CACHE"/>
                     <property name="cacheMode" value="REPLICATED"/>
-                    <property name="startSize" value="200"/>
                     <property name="rebalanceMode" value="NONE"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="swapEnabled" value="false"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/load/dsi-load-client.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/dsi-load-client.xml b/modules/core/src/test/config/load/dsi-load-client.xml
index 1112a17..ea96486 100644
--- a/modules/core/src/test/config/load/dsi-load-client.xml
+++ b/modules/core/src/test/config/load/dsi-load-client.xml
@@ -42,7 +42,6 @@
                     <property name="name" value="REPLICATED_CACHE"/>
                     <property name="cacheMode" value="REPLICATED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="200"/>
                     <property name="rebalanceMode" value="NONE"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="swapEnabled" value="false"/>
@@ -51,7 +50,6 @@
                     <property name="name" value="CLIENT_PARTITIONED_CACHE"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="200"/>
                     <property name="rebalanceMode" value="SYNC"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="swapEnabled" value="false"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/load/dsi-load-server.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/dsi-load-server.xml b/modules/core/src/test/config/load/dsi-load-server.xml
index 7f746e6..73050d5 100644
--- a/modules/core/src/test/config/load/dsi-load-server.xml
+++ b/modules/core/src/test/config/load/dsi-load-server.xml
@@ -41,7 +41,6 @@
                     <property name="name" value="REPLICATED_CACHE"/>
                     <property name="cacheMode" value="REPLICATED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="200"/>
                     <property name="rebalanceMode" value="NONE"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="swapEnabled" value="false"/>
@@ -50,7 +49,6 @@
                     <property name="name" value="PARTITIONED_CACHE"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="200"/>
                     <property name="rebalanceMode" value="SYNC"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/spring-multicache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/spring-multicache.xml b/modules/core/src/test/config/spring-multicache.xml
index 7644a30..ac89f0d 100644
--- a/modules/core/src/test/config/spring-multicache.xml
+++ b/modules/core/src/test/config/spring-multicache.xml
@@ -66,8 +66,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -90,8 +88,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -114,8 +110,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -138,8 +132,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -162,9 +154,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -187,8 +176,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -211,8 +198,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>
@@ -235,8 +220,6 @@
 
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
 
-                    <property name="startSize" value="10"/>
-
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
 
                     <property name="rebalanceMode" value="SYNC"/>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/config/websession/example-cache-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/websession/example-cache-base.xml b/modules/core/src/test/config/websession/example-cache-base.xml
index 9654fab..f8fb6d9 100644
--- a/modules/core/src/test/config/websession/example-cache-base.xml
+++ b/modules/core/src/test/config/websession/example-cache-base.xml
@@ -135,9 +135,6 @@
 
     <!-- Template for all example cache configurations. -->
     <bean id="cache-template" abstract="true" class="org.apache.ignite.configuration.CacheConfiguration">
-        <!-- Initial cache size. -->
-        <property name="startSize" value="3000000"/>
-
         <!-- Set synchronous rebalancing (default is asynchronous). -->
         <property name="rebalanceMode" value="SYNC"/>
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConcurrentMapSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConcurrentMapSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConcurrentMapSelfTest.java
index 593fc3e..ae1f822 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConcurrentMapSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConcurrentMapSelfTest.java
@@ -50,7 +50,6 @@ public class GridCacheConcurrentMapSelfTest extends GridCommonAbstractTest {
 
         cc.setCacheMode(LOCAL);
         cc.setWriteSynchronizationMode(FULL_SYNC);
-        cc.setStartSize(4);
 
         TcpDiscoverySpi disco = new TcpDiscoverySpi();
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
index 2505c68..71eb767 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
@@ -683,7 +683,6 @@ public class GridCachePutAllFailoverSelfTest extends GridCommonAbstractTest {
             cacheCfg.setName("partitioned");
             cacheCfg.setAtomicityMode(atomicityMode());
             cacheCfg.setCacheMode(PARTITIONED);
-            cacheCfg.setStartSize(4500000);
 
             cacheCfg.setBackups(backups);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
index f1cdb07..fed388a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
@@ -1972,7 +1972,6 @@ public class CacheLateAffinityAssignmentTest extends GridCommonAbstractTest {
         ccfg.setBackups(rnd.nextInt(10));
         ccfg.setRebalanceMode(rnd.nextBoolean() ? SYNC : ASYNC);
         ccfg.setAffinity(affinityFunction(rnd.nextInt(2048) + 10));
-        ccfg.setStartSize(128);
 
         if (rnd.nextBoolean()) {
             Set<String> exclude = new HashSet<>();

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePreloadRestartAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePreloadRestartAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePreloadRestartAbstractSelfTest.java
index 6d21dd2..e6007f1 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePreloadRestartAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePreloadRestartAbstractSelfTest.java
@@ -113,7 +113,6 @@ public abstract class GridCachePreloadRestartAbstractSelfTest extends GridCommon
         cc.setName(CACHE_NAME);
         cc.setCacheMode(PARTITIONED);
         cc.setWriteSynchronizationMode(FULL_SYNC);
-        cc.setStartSize(20);
         cc.setRebalanceMode(preloadMode);
         cc.setRebalanceBatchSize(preloadBatchSize);
         cc.setAffinity(new RendezvousAffinityFunction(false, partitions));

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheMultiTxLockSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheMultiTxLockSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheMultiTxLockSelfTest.java
index 1e0eaad..6fd5dd3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheMultiTxLockSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheMultiTxLockSelfTest.java
@@ -80,7 +80,6 @@ public class IgniteCacheMultiTxLockSelfTest extends GridCommonAbstractTest {
         ccfg.setWriteSynchronizationMode(PRIMARY_SYNC);
         ccfg.setBackups(2);
         ccfg.setCacheMode(PARTITIONED);
-        ccfg.setStartSize(100000);
 
         LruEvictionPolicy plc = new LruEvictionPolicy();
         plc.setMaxSize(100000);

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
index 0c48e78..64f5940 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
@@ -84,7 +84,6 @@ public class GridCachePartitionedHitsAndMissesSelfTest extends GridCommonAbstrac
         CacheConfiguration cfg = defaultCacheConfiguration();
 
         cfg.setCacheMode(PARTITIONED);
-        cfg.setStartSize(700000);
         cfg.setWriteSynchronizationMode(FULL_ASYNC);
         cfg.setEvictionPolicy(null);
         cfg.setBackups(1);

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedNodeRestartTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedNodeRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedNodeRestartTest.java
index 3fbec7b..d7a0cdd 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedNodeRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedNodeRestartTest.java
@@ -48,7 +48,6 @@ public class GridCachePartitionedNodeRestartTest extends GridCacheAbstractNodeRe
         cc.setCacheMode(PARTITIONED);
         cc.setWriteSynchronizationMode(FULL_SYNC);
         cc.setNearConfiguration(null);
-        cc.setStartSize(20);
         cc.setRebalanceMode(rebalancMode);
         cc.setRebalanceBatchSize(rebalancBatchSize);
         cc.setAffinity(new RendezvousAffinityFunction(false, partitions));

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedOptimisticTxNodeRestartTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedOptimisticTxNodeRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedOptimisticTxNodeRestartTest.java
index b135675..df9b27f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedOptimisticTxNodeRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedOptimisticTxNodeRestartTest.java
@@ -54,7 +54,6 @@ public class GridCachePartitionedOptimisticTxNodeRestartTest extends GridCacheAb
         cc.setName(CACHE_NAME);
         cc.setCacheMode(PARTITIONED);
         cc.setWriteSynchronizationMode(FULL_SYNC);
-        cc.setStartSize(20);
         cc.setRebalanceMode(rebalancMode);
         cc.setRebalanceBatchSize(rebalancBatchSize);
         cc.setAffinity(new RendezvousAffinityFunction(false, partitions));

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/GridCacheReplicatedNodeRestartSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/GridCacheReplicatedNodeRestartSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/GridCacheReplicatedNodeRestartSelfTest.java
index f0e7ba5..bfee8b6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/GridCacheReplicatedNodeRestartSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/GridCacheReplicatedNodeRestartSelfTest.java
@@ -42,8 +42,6 @@ public class GridCacheReplicatedNodeRestartSelfTest extends GridCacheAbstractNod
 
         cc.setWriteSynchronizationMode(FULL_SYNC);
 
-        cc.setStartSize(20);
-
         cc.setRebalanceMode(SYNC);
 
         cc.setRebalanceBatchSize(20);

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/EvictionAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/EvictionAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/EvictionAbstractTest.java
index abb553d..b5bfcea 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/EvictionAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/EvictionAbstractTest.java
@@ -106,7 +106,6 @@ public abstract class EvictionAbstractTest<T extends EvictionPolicy<?, ?>>
         cc.setEvictionPolicy(createPolicy(plcMax));
         cc.setOnheapCacheEnabled(true);
         cc.setWriteSynchronizationMode(syncCommit ? FULL_SYNC : FULL_ASYNC);
-        cc.setStartSize(plcMax);
         cc.setAtomicityMode(TRANSACTIONAL);
 
         if (nearEnabled) {

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearEvictionPolicySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearEvictionPolicySelfTest.java
index 33ec6d9..27295c6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearEvictionPolicySelfTest.java
@@ -62,7 +62,6 @@ public class LruNearEvictionPolicySelfTest extends GridCommonAbstractTest {
         cc.setAtomicityMode(atomicityMode);
         cc.setWriteSynchronizationMode(PRIMARY_SYNC);
         cc.setRebalanceMode(SYNC);
-        cc.setStartSize(100);
         cc.setBackups(0);
 
         NearCacheConfiguration nearCfg = new NearCacheConfiguration();

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearOnlyNearEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearOnlyNearEvictionPolicySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearOnlyNearEvictionPolicySelfTest.java
index 90f007a..a329e83 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearOnlyNearEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/lru/LruNearOnlyNearEvictionPolicySelfTest.java
@@ -79,7 +79,6 @@ public class LruNearOnlyNearEvictionPolicySelfTest extends GridCommonAbstractTes
             cc.setAtomicityMode(atomicityMode);
             cc.setWriteSynchronizationMode(PRIMARY_SYNC);
             cc.setRebalanceMode(SYNC);
-            cc.setStartSize(100);
             cc.setBackups(0);
 
             c.setCacheConfiguration(cc);

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/internal/processors/datastreamer/IgniteDataStreamerPerformanceTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/datastreamer/IgniteDataStreamerPerformanceTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/datastreamer/IgniteDataStreamerPerformanceTest.java
index e5f5011..3ae176d 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/datastreamer/IgniteDataStreamerPerformanceTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/datastreamer/IgniteDataStreamerPerformanceTest.java
@@ -82,7 +82,6 @@ public class IgniteDataStreamerPerformanceTest extends GridCommonAbstractTest {
 
             cc.setNearConfiguration(null);
             cc.setWriteSynchronizationMode(FULL_SYNC);
-            cc.setStartSize(ENTRY_CNT / GRID_CNT);
 
             cc.setBackups(1);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/loadtests/GridCacheMultiNodeLoadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/GridCacheMultiNodeLoadTest.java b/modules/core/src/test/java/org/apache/ignite/loadtests/GridCacheMultiNodeLoadTest.java
index ac98f9c..8c4b7d9 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/GridCacheMultiNodeLoadTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/GridCacheMultiNodeLoadTest.java
@@ -62,7 +62,6 @@ public class GridCacheMultiNodeLoadTest extends GridCommonAbstractTest {
         cacheCfg.setName(CACHE_NAME);
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setNearConfiguration(null);
-        cacheCfg.setStartSize(10);
         cacheCfg.setWriteSynchronizationMode(FULL_SYNC);
 
         LruEvictionPolicy plc = new LruEvictionPolicy();

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml b/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
index d52c91b..49324d3 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
@@ -61,9 +61,6 @@
 
                     <property name="cacheMode" value="PARTITIONED"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="10000000"/>
-
                     <!--
                         Setting this to true FULL_SYNC will cause local node to wait for remote commits.
                     -->

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml b/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
index 2383249..f92c2b7 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
@@ -95,11 +95,6 @@
 
                     <property name="cacheMode" value="PARTITIONED"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize">
-                        <util:constant static-field="org.apache.ignite.loadtests.colocation.GridTestConstants.CACHE_INIT_SIZE"/>
-                    </property>
-
                     <!--
                         This shows how to configure number of backups. The below configuration
                         sets the number of backups to 1 (which is default).

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/loadtests/datastructures/GridCachePartitionedAtomicLongLoadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/datastructures/GridCachePartitionedAtomicLongLoadTest.java b/modules/core/src/test/java/org/apache/ignite/loadtests/datastructures/GridCachePartitionedAtomicLongLoadTest.java
index 2ac615a..3017272 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/datastructures/GridCachePartitionedAtomicLongLoadTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/datastructures/GridCachePartitionedAtomicLongLoadTest.java
@@ -71,7 +71,6 @@ public class GridCachePartitionedAtomicLongLoadTest extends GridCommonAbstractTe
         CacheConfiguration cc = defaultCacheConfiguration();
 
         cc.setCacheMode(CacheMode.PARTITIONED);
-        cc.setStartSize(200);
         cc.setRebalanceMode(CacheRebalanceMode.SYNC);
         cc.setWriteSynchronizationMode(FULL_SYNC);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariations.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariations.java b/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariations.java
index c787d19..d38eb14 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariations.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariations.java
@@ -97,7 +97,6 @@ public class ConfigVariations {
         Parameters.objectParameters("setLoadPreviousValue", true),
         asArray(SIMPLE_CACHE_STORE_PARAM),
         Parameters.objectParameters("setWriteSynchronizationMode", CacheWriteSynchronizationMode.FULL_SYNC),
-        Parameters.objectParameters("setStartSize", 1024),
         Parameters.booleanParameters("setOnheapCacheEnabled")
     };
 
@@ -124,7 +123,6 @@ public class ConfigVariations {
         ),
         // Set default parameters.
         Parameters.objectParameters("setWriteSynchronizationMode", CacheWriteSynchronizationMode.FULL_SYNC),
-        Parameters.objectParameters("setStartSize", 1024),
         Parameters.booleanParameters("setOnheapCacheEnabled")
     };
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
index d9dd639..b6940d2 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
@@ -1522,7 +1522,6 @@ public abstract class GridAbstractTest extends TestCase {
     public static CacheConfiguration defaultCacheConfiguration() {
         CacheConfiguration cfg = new CacheConfiguration(DEFAULT_CACHE_NAME);
 
-        cfg.setStartSize(1024);
         cfg.setAtomicityMode(TRANSACTIONAL);
         cfg.setNearConfiguration(new NearCacheConfiguration());
         cfg.setWriteSynchronizationMode(FULL_SYNC);

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/core/src/test/webapp/META-INF/ignite-webapp-config.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/webapp/META-INF/ignite-webapp-config.xml b/modules/core/src/test/webapp/META-INF/ignite-webapp-config.xml
index 429ff15..ac3a8da 100644
--- a/modules/core/src/test/webapp/META-INF/ignite-webapp-config.xml
+++ b/modules/core/src/test/webapp/META-INF/ignite-webapp-config.xml
@@ -103,9 +103,6 @@
                     <!-- Enable primary sync write mode. -->
                     <property name="writeSynchronizationMode" value="PRIMARY_SYNC"/>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="1500000"/>
-
                     <!--
                         This shows how to configure number of backups. The below configuration
                         sets the number of backups to 1 (which is default).
@@ -132,9 +129,6 @@
                         <bean class="org.apache.ignite.configuration.NearCacheConfiguration"/>
                     </property>
 
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="1500000"/>
-
                     <!--
                         Setting this value will cause local node to wait for remote commits.
                         However, it's important to set it this way in the examples as we assert on
@@ -170,9 +164,6 @@
 
                     <!-- Set synchronous rebalancing (default is asynchronous). -->
                     <property name="rebalanceMode" value="SYNC"/>
-
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="150000"/>
                 </bean>
 
                 <!--
@@ -184,9 +175,6 @@
 
                     <!-- LOCAL cache mode. -->
                     <property name="cacheMode" value="LOCAL"/>
-
-                    <!-- Initial cache size. -->
-                    <property name="startSize" value="150000"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/storage/matrix/SparseDistributedMatrixStorage.java
----------------------------------------------------------------------
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/storage/matrix/SparseDistributedMatrixStorage.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/storage/matrix/SparseDistributedMatrixStorage.java
index cf200c7..bfc0e9f 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/storage/matrix/SparseDistributedMatrixStorage.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/storage/matrix/SparseDistributedMatrixStorage.java
@@ -90,9 +90,6 @@ public class SparseDistributedMatrixStorage extends CacheUtils implements Matrix
     private IgniteCache<Integer, Map<Integer, Double>> newCache() {
         CacheConfiguration<Integer, Map<Integer, Double>> cfg = new CacheConfiguration<>();
 
-        // Assume 10% density.
-        cfg.setStartSize(Math.max(1024, (rows * cols) / 10));
-
         // Write to primary.
         cfg.setWriteSynchronizationMode(CacheWriteSynchronizationMode.PRIMARY_SYNC);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/cpp/core-test/config/cache-query-continuous-default.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/cpp/core-test/config/cache-query-continuous-default.xml b/modules/platforms/cpp/core-test/config/cache-query-continuous-default.xml
index 2e43c5a..94facb0 100644
--- a/modules/platforms/cpp/core-test/config/cache-query-continuous-default.xml
+++ b/modules/platforms/cpp/core-test/config/cache-query-continuous-default.xml
@@ -36,7 +36,6 @@
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="backups" value="0"/>
-                    <property name="startSize" value="10"/>
                     <property name="queryEntities">
                         <list>
                             <bean class="org.apache.ignite.cache.QueryEntity">

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests.NuGet/Config/ignite-config.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests.NuGet/Config/ignite-config.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests.NuGet/Config/ignite-config.xml
index 3f8f5f9..294b32a 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests.NuGet/Config/ignite-config.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests.NuGet/Config/ignite-config.xml
@@ -42,7 +42,6 @@
             <list>
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="testcache"/>
-                    <property name="startSize" value="10"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheConfigurationTest.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheConfigurationTest.cs b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheConfigurationTest.cs
index 70fd473..9af103b 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheConfigurationTest.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheConfigurationTest.cs
@@ -197,7 +197,6 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreEqual(CacheConfiguration.DefaultAtomicityMode, cfg.AtomicityMode);
             Assert.AreEqual(CacheConfiguration.DefaultCacheMode, cfg.CacheMode);
             Assert.AreEqual(CacheConfiguration.DefaultCopyOnRead, cfg.CopyOnRead);
-            Assert.AreEqual(CacheConfiguration.DefaultStartSize, cfg.StartSize);
             Assert.AreEqual(CacheConfiguration.DefaultEagerTtl, cfg.EagerTtl);
             Assert.AreEqual(CacheConfiguration.DefaultInvalidate, cfg.Invalidate);
             Assert.AreEqual(CacheConfiguration.DefaultKeepVinaryInStore, cfg.KeepBinaryInStore);
@@ -210,8 +209,6 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreEqual(CacheConfiguration.DefaultRebalanceMode, cfg.RebalanceMode);
             Assert.AreEqual(CacheConfiguration.DefaultRebalanceThrottle, cfg.RebalanceThrottle);
             Assert.AreEqual(CacheConfiguration.DefaultRebalanceTimeout, cfg.RebalanceTimeout);
-            Assert.AreEqual(CacheConfiguration.DefaultStartSize, cfg.StartSize);
-            Assert.AreEqual(CacheConfiguration.DefaultStartSize, cfg.StartSize);
             Assert.AreEqual(CacheConfiguration.DefaultWriteBehindBatchSize, cfg.WriteBehindBatchSize);
             Assert.AreEqual(CacheConfiguration.DefaultWriteBehindEnabled, cfg.WriteBehindEnabled);
             Assert.AreEqual(CacheConfiguration.DefaultWriteBehindFlushFrequency, cfg.WriteBehindFlushFrequency);
@@ -230,7 +227,6 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreEqual(x.AtomicityMode, y.AtomicityMode);
             Assert.AreEqual(x.CacheMode, y.CacheMode);
             Assert.AreEqual(x.CopyOnRead, y.CopyOnRead);
-            Assert.AreEqual(x.StartSize, y.StartSize);
             Assert.AreEqual(x.EagerTtl, y.EagerTtl);
             Assert.AreEqual(x.Invalidate, y.Invalidate);
             Assert.AreEqual(x.KeepBinaryInStore, y.KeepBinaryInStore);
@@ -243,8 +239,6 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreEqual(x.RebalanceMode, y.RebalanceMode);
             Assert.AreEqual(x.RebalanceThrottle, y.RebalanceThrottle);
             Assert.AreEqual(x.RebalanceTimeout, y.RebalanceTimeout);
-            Assert.AreEqual(x.StartSize, y.StartSize);
-            Assert.AreEqual(x.StartSize, y.StartSize);
             Assert.AreEqual(x.WriteBehindBatchSize, y.WriteBehindBatchSize);
             Assert.AreEqual(x.WriteBehindEnabled, y.WriteBehindEnabled);
             Assert.AreEqual(x.WriteBehindFlushFrequency, y.WriteBehindFlushFrequency);
@@ -302,8 +296,6 @@ namespace Apache.Ignite.Core.Tests.Cache
                 return;
             }
 
-            Assert.AreEqual(x.NearStartSize, y.NearStartSize);
-
             AssertConfigsAreEqual(x.EvictionPolicy, y.EvictionPolicy);
         }
 
@@ -490,7 +482,6 @@ namespace Apache.Ignite.Core.Tests.Cache
             return new CacheConfiguration
             {
                 Name = name ?? CacheName,
-                StartSize = 2,
                 MaxConcurrentAsyncOperations = 3,
                 WriteBehindFlushThreadCount = 4,
                 LongQueryWarningTimeout = TimeSpan.FromSeconds(5),
@@ -579,7 +570,6 @@ namespace Apache.Ignite.Core.Tests.Cache
             return new CacheConfiguration
             {
                 Name = name ?? CacheName2,
-                StartSize = 2,
                 MaxConcurrentAsyncOperations = 3,
                 WriteBehindFlushThreadCount = 4,
                 LongQueryWarningTimeout = TimeSpan.FromSeconds(5),

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid1.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid1.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid1.xml
index aa4c4e8..c170182 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid1.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid1.xml
@@ -43,7 +43,6 @@
             <list>
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="default"/>
-                    <property name="startSize" value="10"/>
                     <property name="queryEntities">
                         <list>
                             <bean class="org.apache.ignite.cache.QueryEntity">
@@ -60,11 +59,9 @@
                 </bean>
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache1"/>
-                    <property name="startSize" value="10"/>
                 </bean>
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache2"/>
-                    <property name="startSize" value="10"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid2.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid2.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid2.xml
index 3774b51..81db6d2 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid2.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Compute/compute-grid2.xml
@@ -40,7 +40,6 @@
             <list>
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="cache1"/>
-                    <property name="startSize" value="10"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Dynamic/dynamic-data.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Dynamic/dynamic-data.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Dynamic/dynamic-data.xml
index 14ecf90..682a517 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Dynamic/dynamic-data.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/Dynamic/dynamic-data.xml
@@ -35,14 +35,12 @@
                     <property name="name" value="p"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
                     <property name="name" value="pa"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="atomicityMode" value="ATOMIC"/>
-                    <property name="startSize" value="10"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/cache-query-continuous.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/cache-query-continuous.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/cache-query-continuous.xml
index 1bea206..903091a 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/cache-query-continuous.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/cache-query-continuous.xml
@@ -37,7 +37,6 @@
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="backups" value="0"/>
-                    <property name="startSize" value="10"/>
 
                     <property name="queryEntities">
                         <list>
@@ -77,7 +76,6 @@
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="backups" value="1"/>
-                    <property name="startSize" value="10"/>
 
                     <property name="queryEntities">
                         <list>
@@ -117,7 +115,6 @@
                     <property name="atomicityMode" value="ATOMIC"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="backups" value="0"/>
-                    <property name="startSize" value="10"/>
                     <property name="queryEntities">
                         <list>
                             <bean class="org.apache.ignite.cache.QueryEntity">
@@ -156,7 +153,6 @@
                     <property name="atomicityMode" value="ATOMIC"/>
                     <property name="writeSynchronizationMode" value="FULL_SYNC"/>
                     <property name="backups" value="1"/>
-                    <property name="startSize" value="10"/>
                     <property name="queryEntities">
                         <list>
                             <bean class="org.apache.ignite.cache.QueryEntity">

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/native-client-test-cache.xml
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/native-client-test-cache.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/native-client-test-cache.xml
index db07ad5..8c77d75 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/native-client-test-cache.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/native-client-test-cache.xml
@@ -39,28 +39,24 @@
                     <property name="name" value="local"/>
                     <property name="cacheMode" value="LOCAL"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
                     <property name="name" value="local_atomic"/>
                     <property name="cacheMode" value="LOCAL"/>
                     <property name="atomicityMode" value="ATOMIC"/>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
                     <property name="name" value="partitioned"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
                     <property name="name" value="partitioned_atomic"/>
                     <property name="cacheMode" value="PARTITIONED"/>
                     <property name="atomicityMode" value="ATOMIC"/>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
@@ -70,7 +66,6 @@
                     <property name="nearConfiguration">
                         <bean class="org.apache.ignite.configuration.NearCacheConfiguration" />
                     </property>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
@@ -80,26 +75,22 @@
                     <property name="nearConfiguration">
                         <bean class="org.apache.ignite.configuration.NearCacheConfiguration" />
                     </property>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
                     <property name="name" value="replicated"/>
                     <property name="cacheMode" value="REPLICATED"/>
                     <property name="atomicityMode" value="TRANSACTIONAL"/>
-                    <property name="startSize" value="10"/>
                 </bean>
 
                 <bean parent="cache-template">
                     <property name="name" value="replicated_atomic"/>
                     <property name="cacheMode" value="REPLICATED"/>
                     <property name="atomicityMode" value="ATOMIC"/>
-                    <property name="startSize" value="10"/>
                 </bean>
                 
                 <bean parent="cache-template">
                     <property name="name" value="template*"/>
-                    <property name="startSize" value="10"/>
                 </bean>
             </list>
         </property>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
index 538153c..dfd0d09 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
@@ -673,7 +673,6 @@ namespace Apache.Ignite.Core.Tests
                         RebalanceThrottle = TimeSpan.FromHours(44),
                         RebalanceTimeout = TimeSpan.FromMinutes(8),
                         SqlEscapeAll = true,
-                        StartSize = 1023,
                         WriteBehindBatchSize = 45,
                         WriteBehindEnabled = true,
                         WriteBehindFlushFrequency = TimeSpan.FromSeconds(55),

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/CacheConfiguration.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/CacheConfiguration.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/CacheConfiguration.cs
index dd50c3c..9c95c40 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/CacheConfiguration.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/CacheConfiguration.cs
@@ -66,9 +66,6 @@ namespace Apache.Ignite.Core.Cache.Configuration
         /// <summary> Default lock timeout. </summary>
         public static readonly TimeSpan DefaultLockTimeout = TimeSpan.Zero;
 
-        /// <summary> Initial default cache size. </summary>
-        public const int DefaultStartSize = 1500000;
-
         /// <summary> Default cache size to use with eviction policy. </summary>
         public const int DefaultCacheSize = 100000;
 
@@ -169,7 +166,6 @@ namespace Apache.Ignite.Core.Cache.Configuration
             RebalanceMode = DefaultRebalanceMode;
             RebalanceThrottle = DefaultRebalanceThrottle;
             RebalanceTimeout = DefaultRebalanceTimeout;
-            StartSize = DefaultStartSize;
             WriteBehindBatchSize = DefaultWriteBehindBatchSize;
             WriteBehindEnabled = DefaultWriteBehindEnabled;
             WriteBehindFlushFrequency = DefaultWriteBehindFlushFrequency;
@@ -231,7 +227,6 @@ namespace Apache.Ignite.Core.Cache.Configuration
             RebalanceThrottle = reader.ReadLongAsTimespan();
             RebalanceTimeout = reader.ReadLongAsTimespan();
             SqlEscapeAll = reader.ReadBoolean();
-            StartSize = reader.ReadInt();
             WriteBehindBatchSize = reader.ReadInt();
             WriteBehindEnabled = reader.ReadBoolean();
             WriteBehindFlushFrequency = reader.ReadLongAsTimespan();
@@ -289,7 +284,6 @@ namespace Apache.Ignite.Core.Cache.Configuration
             writer.WriteLong((long) RebalanceThrottle.TotalMilliseconds);
             writer.WriteLong((long) RebalanceTimeout.TotalMilliseconds);
             writer.WriteBoolean(SqlEscapeAll);
-            writer.WriteInt(StartSize);
             writer.WriteInt(WriteBehindBatchSize);
             writer.WriteBoolean(WriteBehindEnabled);
             writer.WriteLong((long) WriteBehindFlushFrequency.TotalMilliseconds);
@@ -389,12 +383,6 @@ namespace Apache.Ignite.Core.Cache.Configuration
         public bool EagerTtl { get; set; }
 
         /// <summary>
-        /// Gets or sets initial cache size which will be used to pre-create internal hash table after start.
-        /// </summary>
-        [DefaultValue(DefaultStartSize)]
-        public int StartSize { get; set; }
-
-        /// <summary>
         /// Gets or sets flag indicating whether value should be loaded from store if it is not in the cache 
         /// for the following cache operations:   
         /// <list type="bullet">

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/NearCacheConfiguration.cs
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/NearCacheConfiguration.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/NearCacheConfiguration.cs
index dc9219f..037bbc9 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/NearCacheConfiguration.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Cache/Configuration/NearCacheConfiguration.cs
@@ -31,7 +31,7 @@ namespace Apache.Ignite.Core.Cache.Configuration
     public class NearCacheConfiguration
     {
         /// <summary> Initial default near cache size. </summary>
-        public const int DefaultNearStartSize = CacheConfiguration.DefaultStartSize / 4;
+        public const int DefaultNearStartSize = 1500000 / 4;
 
         /// <summary>
         /// Initializes a new instance of the <see cref="NearCacheConfiguration"/> class.

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
----------------------------------------------------------------------
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd b/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
index 8476f1f..9098d89 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
@@ -579,11 +579,6 @@
                                             <xs:documentation>Write synchronization mode. This mode controls whether the main caller should wait for update on other nodes to complete or not.</xs:documentation>
                                         </xs:annotation>
                                     </xs:attribute>
-                                    <xs:attribute name="startSize" type="xs:int">
-                                        <xs:annotation>
-                                            <xs:documentation>Initial cache size which will be used to pre-create internal hash table after start.</xs:documentation>
-                                        </xs:annotation>
-                                    </xs:attribute>
                                     <xs:attribute name="loadPreviousValue" type="xs:string">
                                         <xs:annotation>
                                             <xs:documentation>

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/scalar/src/test/resources/spring-cache.xml
----------------------------------------------------------------------
diff --git a/modules/scalar/src/test/resources/spring-cache.xml b/modules/scalar/src/test/resources/spring-cache.xml
index 210335e0..fab6d55 100644
--- a/modules/scalar/src/test/resources/spring-cache.xml
+++ b/modules/scalar/src/test/resources/spring-cache.xml
@@ -79,9 +79,6 @@
 
     <!-- Template for all example cache configurations. -->
     <bean id="cache-template" abstract="true" class="org.apache.ignite.configuration.CacheConfiguration">
-        <!-- Initial cache size. -->
-        <property name="startSize" value="3000000"/>
-
         <!-- Set synchronous rebalancing (default is asynchronous). -->
         <property name="rebalanceMode" value="SYNC"/>
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/spring/src/test/java/org/apache/ignite/internal/cache.xml
----------------------------------------------------------------------
diff --git a/modules/spring/src/test/java/org/apache/ignite/internal/cache.xml b/modules/spring/src/test/java/org/apache/ignite/internal/cache.xml
index ddd3b48..9b9b25e 100644
--- a/modules/spring/src/test/java/org/apache/ignite/internal/cache.xml
+++ b/modules/spring/src/test/java/org/apache/ignite/internal/cache.xml
@@ -35,9 +35,6 @@
         http://www.springframework.org/schema/util
         http://www.springframework.org/schema/util/spring-util.xsd">
     <bean id="cache-configuration" class="org.apache.ignite.configuration.CacheConfiguration">
-        <!-- Initial cache size. -->
-        <property name="startSize" value="3000000"/>
-
         <!-- Set synchronous rebalancing (default is asynchronous). -->
         <property name="rebalanceMode" value="SYNC"/>
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/b2aeac75/modules/spring/src/test/java/org/apache/ignite/internal/filtered-cache.xml
----------------------------------------------------------------------
diff --git a/modules/spring/src/test/java/org/apache/ignite/internal/filtered-cache.xml b/modules/spring/src/test/java/org/apache/ignite/internal/filtered-cache.xml
index df2a4dd..6866974 100644
--- a/modules/spring/src/test/java/org/apache/ignite/internal/filtered-cache.xml
+++ b/modules/spring/src/test/java/org/apache/ignite/internal/filtered-cache.xml
@@ -35,9 +35,6 @@
         http://www.springframework.org/schema/util
         http://www.springframework.org/schema/util/spring-util.xsd">
     <bean id="cache-configuration" class="org.apache.ignite.configuration.CacheConfiguration">
-        <!-- Initial cache size. -->
-        <property name="startSize" value="3000000"/>
-
         <!-- Set synchronous rebalancing (default is asynchronous). -->
         <property name="rebalanceMode" value="SYNC"/>