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 07:17:28 UTC

[26/37] ignite git commit: IGNITE-3488: Prohibited null as cache name. This closes #1790.

IGNITE-3488: Prohibited null as cache name. This closes #1790.


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

Branch: refs/heads/ignite-5090
Commit: 8f9edebfe74e2de1368d42ba951fa074b116eb17
Parents: 74f11e8
Author: Igor Seliverstov <gv...@gmail.com>
Authored: Wed Apr 26 17:51:43 2017 +0300
Committer: devozerov <vo...@gridgain.com>
Committed: Wed Apr 26 17:51:57 2017 +0300

----------------------------------------------------------------------
 examples/config/example-cache.xml               |   1 +
 .../jmh/cache/JmhCacheAbstractBenchmark.java    |   7 +-
 .../stream/camel/IgniteCamelStreamerTest.java   |  10 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |  37 ++--
 .../client/ClientDefaultCacheSelfTest.java      |   2 +-
 .../ClientAbstractMultiNodeSelfTest.java        |  25 ++-
 .../integration/ClientAbstractSelfTest.java     |   9 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |  10 +-
 .../jdbc2/JdbcComplexQuerySelfTest.java         |   5 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |   5 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |   6 +-
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java |  14 +-
 .../jdbc2/JdbcInsertStatementSelfTest.java      |   4 +-
 .../jdbc2/JdbcMergeStatementSelfTest.java       |   4 +-
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |   3 +-
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java  |  45 ++--
 .../jdbc2/JdbcPreparedStatementSelfTest.java    |   4 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |   4 +-
 .../internal/jdbc2/JdbcStatementSelfTest.java   |   4 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java   |  14 +-
 .../rest/AbstractRestProcessorSelfTest.java     |   2 +-
 .../JettyRestProcessorAbstractSelfTest.java     | 184 +++++++++--------
 .../rest/JettyRestProcessorSignedSelfTest.java  |   4 +-
 .../rest/RestBinaryProtocolSelfTest.java        | 101 ++++-----
 .../rest/RestMemcacheProtocolSelfTest.java      |  47 ++---
 .../processors/rest/RestProcessorTest.java      |   2 +-
 .../rest/TaskCommandHandlerSelfTest.java        |   7 +-
 .../processors/rest/TestBinaryClient.java       |  23 ++-
 .../tcp/redis/RedisProtocolSelfTest.java        |   8 +-
 .../jdbc/AbstractJdbcPojoQuerySelfTest.java     |   2 +-
 .../ignite/jdbc/JdbcConnectionSelfTest.java     |   5 +-
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |   3 +-
 .../ignite/jdbc/JdbcPojoQuerySelfTest.java      |   2 +-
 .../jdbc/JdbcPreparedStatementSelfTest.java     |   2 +-
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |   2 +-
 .../ignite/jdbc/JdbcStatementSelfTest.java      |   2 +-
 .../src/main/java/org/apache/ignite/Ignite.java |  10 +-
 .../java/org/apache/ignite/IgniteCompute.java   |   8 +-
 .../configuration/CacheConfiguration.java       |   6 +-
 .../ignite/internal/IgniteComputeImpl.java      |  37 +++-
 .../org/apache/ignite/internal/IgniteEx.java    |  12 +-
 .../apache/ignite/internal/IgniteKernal.java    |  76 +++----
 .../internal/cluster/ClusterGroupAdapter.java   |  23 ++-
 .../ignite/internal/cluster/ClusterGroupEx.java |   5 +-
 .../affinity/GridAffinityProcessor.java         |  67 +++---
 .../processors/cache/GridCacheProcessor.java    | 203 +++++++++----------
 .../processors/cache/GridCacheUtils.java        |  30 ++-
 .../processors/query/GridQueryIndexing.java     |  23 +--
 .../redis/GridRedisRestCommandHandler.java      |   3 +
 .../redis/key/GridRedisDelCommandHandler.java   |   1 +
 .../key/GridRedisExistsCommandHandler.java      |   1 +
 .../server/GridRedisDbSizeCommandHandler.java   |   1 +
 .../string/GridRedisAppendCommandHandler.java   |   3 +
 .../string/GridRedisGetCommandHandler.java      |   1 +
 .../string/GridRedisGetRangeCommandHandler.java |   1 +
 .../string/GridRedisGetSetCommandHandler.java   |   1 +
 .../string/GridRedisIncrDecrCommandHandler.java |   2 +
 .../string/GridRedisMGetCommandHandler.java     |   1 +
 .../string/GridRedisMSetCommandHandler.java     |   1 +
 .../string/GridRedisSetCommandHandler.java      |   1 +
 .../string/GridRedisSetRangeCommandHandler.java |   2 +
 .../string/GridRedisStrlenCommandHandler.java   |   1 +
 .../tcp/GridTcpMemcachedNioListener.java        |   5 +-
 .../spi/indexing/IndexingQueryFilter.java       |   2 +-
 .../core/src/test/config/discovery-stress.xml   |   2 +-
 .../core/src/test/config/spring-cache-load.xml  |   1 +
 .../core/src/test/config/spring-cache-swap.xml  |   2 +
 .../src/test/config/spring-cache-teststore.xml  |   2 +
 .../test/config/store/jdbc/ignite-jdbc-type.xml |   6 +
 .../GridCacheAffinityBackupsSelfTest.java       |   2 +-
 .../apache/ignite/GridTestStoreNodeStartup.java |   2 +-
 .../ignite/IgniteCacheAffinitySelfTest.java     |   2 +-
 .../cache/IgniteWarmupClosureSelfTest.java      |   2 +-
 .../ignite/cache/LargeEntryUpdateTest.java      |   2 +-
 .../affinity/AffinityClientNodeSelfTest.java    |  14 +-
 ...ityFunctionBackupFilterAbstractSelfTest.java |   8 +-
 ...unctionExcludeNeighborsAbstractSelfTest.java |   4 +-
 .../affinity/AffinityHistoryCleanupTest.java    |   2 +-
 .../local/LocalAffinityFunctionTest.java        |   2 +-
 ...cheStoreSessionListenerAbstractSelfTest.java |   6 +-
 .../store/GridCacheBalancingStoreSelfTest.java  |   8 +-
 .../IgniteCacheExpiryStoreLoadSelfTest.java     |   2 +-
 .../store/StoreResourceInjectionSelfTest.java   |   2 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |   8 +-
 .../ignite/internal/GridAffinityMappedTest.java |   6 +-
 .../internal/GridAffinityP2PSelfTest.java       |   6 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   6 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |   2 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |   8 +-
 .../GridProjectionForCachesSelfTest.java        |  13 +-
 ...ectionLocalJobMultipleArgumentsSelfTest.java |   4 +-
 .../ignite/internal/GridStartStopSelfTest.java  |   8 +-
 .../GridTaskFailoverAffinityRunTest.java        |   4 +-
 .../IgniteClientReconnectApiExceptionTest.java  |  18 +-
 .../IgniteClientReconnectCacheTest.java         |  70 +++----
 ...eClientReconnectContinuousProcessorTest.java |  10 +-
 .../IgniteClientReconnectFailoverTest.java      |   4 +-
 .../internal/IgniteClientReconnectStopTest.java |   2 +-
 .../IgniteComputeEmptyClusterGroupTest.java     |   8 +-
 ...eConcurrentEntryProcessorAccessStopTest.java |   2 +-
 .../internal/binary/BinaryEnumsSelfTest.java    |   2 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |   2 +-
 .../internal/binary/BinaryTreeSelfTest.java     |   4 +-
 .../binary/GridBinaryAffinityKeySelfTest.java   |  30 +--
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |   4 +-
 .../IgniteVariousConnectionNumberTest.java      |   4 +-
 .../GridDeploymentMessageCountSelfTest.java     |   6 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   2 +-
 .../OptimizedMarshallerNodeFailoverTest.java    |   6 +-
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java |   2 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |   2 +-
 .../CacheAtomicSingleMessageCountSelfTest.java  |   4 +-
 .../cache/CacheClientStoreSelfTest.java         |   2 +-
 .../cache/CacheConcurrentReadThroughTest.java   |   2 +-
 .../cache/CacheConfigurationLeakTest.java       |   2 +-
 .../cache/CacheDeferredDeleteQueueTest.java     |   4 +-
 .../CacheDeferredDeleteSanitySelfTest.java      |   4 +-
 ...cheDhtLocalPartitionAfterRemoveSelfTest.java |   6 +-
 .../cache/CacheEnumOperationsAbstractTest.java  |   2 +-
 ...CacheExchangeMessageDuplicatedStateTest.java |  10 +-
 .../cache/CacheFutureExceptionSelfTest.java     |   2 +-
 .../cache/CacheGetEntryAbstractTest.java        |  16 +-
 .../processors/cache/CacheGetFromJobTest.java   |   2 +-
 ...erceptorPartitionCounterLocalSanityTest.java |   2 +-
 ...torPartitionCounterRandomOperationsTest.java |   2 +-
 .../CacheMemoryPolicyConfigurationTest.java     |  10 +-
 .../processors/cache/CacheNamesSelfTest.java    |   8 +-
 .../CacheNamesWithSpecialCharactersTest.java    |   4 +-
 .../cache/CacheNearReaderUpdateTest.java        |   2 +-
 ...cheNearUpdateTopologyChangeAbstractTest.java |   8 +-
 .../cache/CacheOffheapMapEntrySelfTest.java     |   2 +-
 .../processors/cache/CachePutIfAbsentTest.java  |   2 +-
 .../cache/CacheReadThroughRestartSelfTest.java  |   8 +-
 .../cache/CacheRebalancingSelfTest.java         |   4 +-
 .../cache/CacheRemoveAllSelfTest.java           |   4 +-
 .../CacheSerializableTransactionsTest.java      |   6 +-
 .../CacheStartupInDeploymentModesTest.java      |   4 +-
 .../CacheStoreUsageMultinodeAbstractTest.java   |   8 +-
 ...eUsageMultinodeDynamicStartAbstractTest.java |   4 +-
 .../processors/cache/CacheTxFastFinishTest.java |   4 +-
 .../processors/cache/CrossCacheLockTest.java    |   4 +-
 .../cache/CrossCacheTxRandomOperationsTest.java |   2 +-
 .../EntryVersionConsistencyReadThroughTest.java |  10 +-
 .../GridCacheAbstractFailoverSelfTest.java      |   4 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java | 114 +++++------
 .../GridCacheAbstractLocalStoreSelfTest.java    |  26 +--
 .../cache/GridCacheAbstractMetricsSelfTest.java | 102 +++++-----
 .../GridCacheAbstractRemoveFailureTest.java     |   6 +-
 .../cache/GridCacheAbstractSelfTest.java        |   4 +-
 ...acheAbstractUsersAffinityMapperSelfTest.java |   7 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |  26 +--
 .../cache/GridCacheAffinityRoutingSelfTest.java |  10 +-
 ...eAtomicEntryProcessorDeploymentSelfTest.java |   2 +-
 .../GridCacheAtomicMessageCountSelfTest.java    |   6 +-
 .../cache/GridCacheBasicApiAbstractTest.java    |  30 +--
 .../cache/GridCacheClearLocallySelfTest.java    |   8 +-
 .../cache/GridCacheConcurrentMapSelfTest.java   |  10 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |  10 +-
 .../GridCacheConditionalDeploymentSelfTest.java |   4 +-
 ...idCacheConfigurationConsistencySelfTest.java |   2 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   8 +-
 .../cache/GridCacheDeploymentSelfTest.java      |  46 ++---
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   4 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |  16 +-
 .../GridCacheEvictionEventAbstractTest.java     |   2 +-
 .../GridCacheFinishPartitionsSelfTest.java      |  16 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |   2 +-
 .../cache/GridCacheIncrementTransformTest.java  |   4 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |   8 +-
 .../cache/GridCacheIteratorPerformanceTest.java |   6 +-
 .../cache/GridCacheKeyCheckSelfTest.java        |   6 +-
 .../GridCacheMarshallerTxAbstractTest.java      |  10 +-
 .../GridCacheMarshallingNodeJoinSelfTest.java   |   4 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |   2 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |   4 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |   6 +-
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |   6 +-
 .../cache/GridCacheMvccFlagsTest.java           |   4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |   6 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |  34 ++--
 .../processors/cache/GridCacheMvccSelfTest.java |  58 +++---
 .../cache/GridCacheNestedTxAbstractTest.java    |  12 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |   4 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |  20 +-
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |  14 +-
 .../cache/GridCacheOffheapUpdateSelfTest.java   |  14 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |  16 +-
 ...hePartitionedProjectionAffinitySelfTest.java |   8 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |  14 +-
 .../GridCacheQueryIndexingDisabledSelfTest.java |   2 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |   6 +-
 .../GridCacheReferenceCleanupSelfTest.java      |  10 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |   6 +-
 .../GridCacheReturnValueTransferSelfTest.java   |   4 +-
 .../processors/cache/GridCacheStopSelfTest.java |   8 +-
 ...ridCacheStoreManagerDeserializationTest.java |   3 +
 .../cache/GridCacheStorePutxSelfTest.java       |   2 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |   4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |  10 +-
 ...acheTcpClientDiscoveryMultiThreadedTest.java |   4 +-
 ...cheTransactionalAbstractMetricsSelfTest.java |   8 +-
 .../GridCacheTtlManagerEvictionSelfTest.java    |   6 +-
 .../cache/GridCacheTtlManagerLoadTest.java      |   4 +-
 .../GridCacheTtlManagerNotificationTest.java    |   8 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |  12 +-
 .../GridCacheValueBytesPreloadingSelfTest.java  |  12 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |  14 +-
 .../GridCacheVariableTopologySelfTest.java      |   4 +-
 .../cache/GridCacheVersionMultinodeTest.java    |   2 +-
 .../GridCacheVersionTopologyChangeTest.java     |   2 +-
 ...ProjectionForCachesOnDaemonNodeSelfTest.java |  16 +-
 .../IgniteCacheAbstractStopBusySelfTest.java    |   3 +-
 .../cache/IgniteCacheAbstractTest.java          |   2 +-
 ...IgniteCacheBinaryEntryProcessorSelfTest.java |   6 +-
 ...teCacheConfigurationDefaultTemplateTest.java |   6 +-
 .../IgniteCacheConfigurationTemplateTest.java   |  29 +--
 ...niteCacheCopyOnReadDisabledAbstractTest.java |   2 +-
 .../cache/IgniteCacheDynamicStopSelfTest.java   |  10 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |   6 +-
 ...niteCacheEntryListenerExpiredEventsTest.java |   2 +-
 .../IgniteCacheEntryProcessorCallTest.java      |   8 +-
 .../IgniteCacheEntryProcessorNodeJoinTest.java  |  16 +-
 ...niteCacheExpireAndUpdateConsistencyTest.java |   2 +-
 ...IgniteCacheGetCustomCollectionsSelfTest.java |   2 +-
 .../cache/IgniteCacheIncrementTxTest.java       |  10 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |   2 +-
 ...gniteCacheInvokeReadThroughAbstractTest.java |   2 +-
 ...gniteCacheLoadRebalanceEvictionSelfTest.java |   6 +-
 .../IgniteCacheManyAsyncOperationsTest.java     |   2 +-
 .../cache/IgniteCacheObjectPutSelfTest.java     |   2 +-
 ...CacheP2pUnmarshallingRebalanceErrorTest.java |   4 +-
 .../IgniteCachePartitionMapUpdateTest.java      |   4 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |  22 +-
 .../IgniteCacheReadThroughStoreCallTest.java    |   2 +-
 ...iteCacheScanPredicateDeploymentSelfTest.java |   2 +-
 .../cache/IgniteCacheSerializationSelfTest.java |   4 +-
 .../cache/IgniteCacheStartStopLoadTest.java     |   2 +-
 .../cache/IgniteCacheStoreCollectionTest.java   |   4 +-
 .../IgniteCacheStoreValueAbstractTest.java      |  30 +--
 .../cache/IgniteCacheTxPreloadNoWriteTest.java  |  12 +-
 .../IgniteClientAffinityAssignmentSelfTest.java |  22 +-
 .../IgniteDaemonNodeMarshallerCacheTest.java    |   2 +-
 .../cache/IgniteDynamicCacheAndNodeStop.java    |   4 +-
 .../cache/IgniteDynamicCacheFilterTest.java     |  10 +-
 ...eDynamicCacheStartNoExchangeTimeoutTest.java |  34 ++--
 .../cache/IgniteDynamicCacheStartSelfTest.java  |  36 ++--
 ...niteDynamicCacheStartStopConcurrentTest.java |   6 +-
 .../IgniteDynamicClientCacheStartSelfTest.java  |  44 ++--
 .../cache/IgniteExchangeFutureHistoryTest.java  |   2 +-
 ...iteMarshallerCacheClassNameConflictTest.java |   8 +-
 ...lerCacheClientRequestsMappingOnMissTest.java |  22 +-
 ...eMarshallerCacheConcurrentReadWriteTest.java |   8 +-
 .../cache/IgniteOnePhaseCommitNearSelfTest.java |   8 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |  12 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |   6 +-
 .../IgniteStartCacheInTransactionSelfTest.java  |  18 +-
 .../cache/IgniteStaticCacheStartSelfTest.java   |   2 +-
 ...gniteTopologyValidatorAbstractCacheTest.java |  37 ++--
 ...iteTopologyValidatorAbstractTxCacheTest.java |  20 +-
 ...niteTopologyValidatorGridSplitCacheTest.java |   2 +-
 .../processors/cache/IgniteTxAbstractTest.java  |   6 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |   6 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |   2 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |  36 ++--
 .../cache/IgniteTxMultiNodeAbstractTest.java    |  58 +++---
 .../IgniteTxMultiThreadedAbstractTest.java      |   4 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |   2 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |  34 ++--
 .../binary/BinaryMetadataUpdatesFlowTest.java   |  10 +-
 .../CacheKeepBinaryWithInterceptorTest.java     |   6 +-
 ...yAtomicEntryProcessorDeploymentSelfTest.java |   6 +-
 ...naryObjectMetadataExchangeMultinodeTest.java |  16 +-
 ...acheBinaryObjectUserClassloaderSelfTest.java |   4 +-
 ...naryObjectsAbstractDataStreamerSelfTest.java |   4 +-
 ...aryObjectsAbstractMultiThreadedSelfTest.java |   2 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |   8 +-
 .../GridCacheBinaryStoreAbstractSelfTest.java   |   2 +-
 ...ntNodeBinaryObjectMetadataMultinodeTest.java |   8 +-
 ...CacheClientNodeBinaryObjectMetadataTest.java |   4 +-
 .../GridDataStreamerImplSelfTest.java           |  20 +-
 ...IgniteCacheAbstractExecutionContextTest.java |   4 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |   2 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   2 +-
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   2 +-
 .../GridCacheQueueApiSelfAbstractTest.java      |   2 +-
 .../GridCacheQueueCleanupSelfTest.java          |  10 +-
 .../GridCacheSequenceApiSelfAbstractTest.java   |   2 +-
 .../GridCacheSetAbstractSelfTest.java           |   2 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |   2 +-
 .../IgniteAtomicLongApiAbstractSelfTest.java    |   2 +-
 .../IgniteCountDownLatchAbstractSelfTest.java   |   2 +-
 .../IgniteLockAbstractSelfTest.java             |   2 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   2 +-
 ...achePartitionedAtomicSequenceTxSelfTest.java |   2 +-
 ...idCachePartitionedNodeRestartTxSelfTest.java |  24 +--
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   4 +-
 ...acheAsyncOperationsFailoverAbstractTest.java |   4 +-
 .../distributed/CacheAsyncOperationsTest.java   |   2 +-
 .../CacheGetFutureHangsSelfTest.java            |   4 +-
 .../CacheGetInsideLockChangingTopologyTest.java |   2 +-
 .../CacheLateAffinityAssignmentTest.java        |   8 +-
 ...CacheLoadingConcurrentGridStartSelfTest.java |  20 +-
 .../CacheLockReleaseNodeLeaveTest.java          |  26 +--
 .../CachePutAllFailoverAbstractTest.java        |   2 +-
 .../CacheTryLockMultithreadedTest.java          |   4 +-
 .../GridCacheAbstractJobExecutionTest.java      |  14 +-
 ...tractPartitionedByteArrayValuesSelfTest.java |   2 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java   |   6 +-
 .../GridCacheBasicOpAbstractTest.java           |  26 +--
 .../GridCacheClientModesAbstractSelfTest.java   |  20 +-
 .../GridCacheEntrySetAbstractSelfTest.java      |   2 +-
 .../distributed/GridCacheLockAbstractTest.java  |   6 +-
 .../distributed/GridCacheMixedModeSelfTest.java |   4 +-
 .../GridCacheMultiNodeAbstractTest.java         |  10 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |  27 ++-
 ...dCacheMultithreadedFailoverAbstractTest.java |   2 +-
 .../GridCacheNodeFailureAbstractTest.java       |   6 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |   4 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |   8 +-
 .../GridCachePreloadEventsAbstractSelfTest.java |   4 +-
 .../GridCacheTransformEventSelfTest.java        |   2 +-
 ...niteBinaryMetadataUpdateNodeRestartTest.java |   2 +-
 .../distributed/IgniteCache150ClientsTest.java  |   2 +-
 ...niteCacheClientNodeChangingTopologyTest.java | 130 ++++++------
 .../IgniteCacheClientNodeConcurrentStart.java   |   2 +-
 ...teCacheClientNodePartitionsExchangeTest.java |  16 +-
 .../IgniteCacheClientReconnectTest.java         |   2 +-
 .../IgniteCacheConnectionRecoveryTest.java      |   2 +-
 .../distributed/IgniteCacheCreatePutTest.java   |   6 +-
 .../distributed/IgniteCacheGetRestartTest.java  |   2 +-
 .../distributed/IgniteCacheManyClientsTest.java |   6 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java |   4 +-
 ...eCacheMessageRecoveryIdleConnectionTest.java |   2 +-
 .../IgniteCacheNearRestartRollbackSelfTest.java |   4 +-
 .../distributed/IgniteCachePrimarySyncTest.java |   4 +-
 .../IgniteCacheReadFromBackupTest.java          |   2 +-
 .../IgniteCacheServerNodeConcurrentStart.java   |   6 +-
 .../IgniteCacheSingleGetMessageTest.java        |   2 +-
 .../IgniteCacheSizeFailoverTest.java            |   6 +-
 .../IgniteCacheSystemTransactionsSelfTest.java  |   6 +-
 .../IgniteNoClassOnServerAbstractTest.java      |   2 +-
 .../IgniteTxCachePrimarySyncTest.java           |  45 ++--
 ...teSynchronizationModesMultithreadedTest.java |  15 +-
 ...iteTxConsistencyRestartAbstractSelfTest.java |  12 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |  10 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |  22 +-
 .../IgniteTxTimeoutAbstractTest.java            |   2 +-
 ...heAbstractTransformWriteThroughSelfTest.java |   2 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |  50 ++---
 .../dht/GridCacheColocatedDebugTest.java        | 112 +++++-----
 ...eColocatedOptimisticTransactionSelfTest.java |   2 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |   6 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   8 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |   4 +-
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |  10 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |  24 +--
 .../GridCacheDhtPreloadDisabledSelfTest.java    |  10 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |   6 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |   4 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |  18 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |   4 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |  24 +--
 ...ePartitionedNearDisabledMetricsSelfTest.java |  12 +-
 ...idCachePartitionedPreloadEventsSelfTest.java |   6 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |  18 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |  10 +-
 ...ridCachePartitionedUnloadEventsSelfTest.java |  10 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java     |  12 +-
 .../IgniteCacheCommitDelayTxRecoveryTest.java   |  22 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |   2 +-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |   5 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java    |   8 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |   2 +-
 ...artitionedBackupNodeFailureRecoveryTest.java |   6 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |  12 +-
 .../IgniteCachePutRetryAbstractSelfTest.java    |   8 +-
 .../dht/IgniteCachePutRetryAtomicSelfTest.java  |   4 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |   6 +-
 .../dht/IgniteCacheTxRecoveryRollbackTest.java  |  20 +-
 .../dht/IgniteTxReentryColocatedSelfTest.java   |   2 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |  12 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |  10 +-
 .../atomic/IgniteCacheAtomicProtocolTest.java   |   2 +-
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   6 +-
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |   2 +-
 ...AtomicPartitionedTckMetricsSelfTestImpl.java |   8 +-
 .../near/GridCacheGetStoreErrorSelfTest.java    |   4 +-
 .../near/GridCacheNearEvictionSelfTest.java     |   6 +-
 .../near/GridCacheNearMetricsSelfTest.java      |  32 +--
 .../near/GridCacheNearMultiGetSelfTest.java     |   4 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |  12 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |  10 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |  16 +-
 .../GridCacheNearPartitionedClearSelfTest.java  |   2 +-
 .../GridCacheNearReaderPreloadSelfTest.java     |   2 +-
 .../near/GridCacheNearReadersSelfTest.java      |  36 ++--
 .../near/GridCacheNearTxForceKeyTest.java       |   8 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |  18 +-
 ...AffinityExcludeNeighborsPerformanceTest.java |   2 +-
 .../GridCachePartitionedAffinitySelfTest.java   |   8 +-
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |   4 +-
 .../GridCachePartitionedEvictionSelfTest.java   |   2 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |   4 +-
 ...GridCachePartitionedFilteredPutSelfTest.java |   2 +-
 .../GridCachePartitionedFullApiSelfTest.java    |   8 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |   4 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |   2 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |  24 +--
 ...achePartitionedMultiNodeFullApiSelfTest.java |  34 ++--
 ...ePartitionedMultiThreadedPutGetSelfTest.java |   8 +-
 .../GridCachePartitionedStorePutSelfTest.java   |   6 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |   2 +-
 .../near/GridCachePutArrayValueSelfTest.java    |   2 +-
 ...idCacheRendezvousAffinityClientSelfTest.java |   2 +-
 .../near/GridPartitionedBackupLoadSelfTest.java |   4 +-
 .../near/IgniteCacheNearOnlyTxTest.java         |  24 +--
 .../near/IgniteCacheNearReadCommittedTest.java  |   4 +-
 .../near/IgniteTxReentryNearSelfTest.java       |   2 +-
 .../near/NearCacheMultithreadedUpdateTest.java  |   8 +-
 .../near/NearCachePutAllMultinodeTest.java      |   4 +-
 .../near/NearCacheSyncUpdateTest.java           |   4 +-
 .../near/NoneRebalanceModeSelfTest.java         |   4 +-
 ...cingDelayedPartitionMapExchangeSelfTest.java |   8 +-
 .../GridCacheRebalancingOrderingTest.java       |   2 +-
 .../GridCacheRebalancingSyncCheckDataTest.java  |   6 +-
 .../GridCacheRebalancingSyncSelfTest.java       |  10 +-
 ...eRebalancingUnmarshallingFailedSelfTest.java |   2 +-
 ...stractReplicatedByteArrayValuesSelfTest.java |   2 +-
 .../GridCacheSyncReplicatedPreloadSelfTest.java |  14 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |  50 ++---
 ...eplicatedPreloadStartStopEventsSelfTest.java |   2 +-
 .../cache/eviction/EvictionAbstractTest.java    |  12 +-
 ...heConcurrentEvictionConsistencySelfTest.java |   2 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |   2 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   2 +-
 .../GridCacheEvictionFilterSelfTest.java        |   4 +-
 .../GridCacheEvictionTouchSelfTest.java         |   8 +-
 .../lru/LruNearEvictionPolicySelfTest.java      |   6 +-
 .../LruNearOnlyNearEvictionPolicySelfTest.java  |   8 +-
 .../paged/PageEvictionAbstractTest.java         |   5 +-
 .../SortedEvictionPolicyPerformanceTest.java    |   2 +-
 .../IgniteCacheClientNearCacheExpiryTest.java   |   4 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |  10 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |   6 +-
 .../expiry/IgniteCacheLargeValueExpireTest.java |   4 +-
 ...eCacheOnlyOneTtlCleanupThreadExistsTest.java |   5 +-
 .../expiry/IgniteCacheTtlCleanupSelfTest.java   |   8 +-
 .../IgniteCacheLoadAllAbstractTest.java         |   2 +-
 .../IgniteCacheStoreSessionAbstractTest.java    |   5 +-
 ...acheStoreSessionWriteBehindAbstractTest.java |   2 +-
 .../IgniteCacheTxStoreSessionTest.java          |  22 +-
 ...dCacheAtomicLocalTckMetricsSelfTestImpl.java |   8 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   2 +-
 .../local/GridCacheLocalFullApiSelfTest.java    |   4 +-
 .../cache/local/GridCacheLocalLockSelfTest.java |   6 +-
 .../GridCacheLocalMultithreadedSelfTest.java    |   2 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |   2 +-
 .../BinaryTxCacheLocalEntriesSelfTest.java      |   2 +-
 .../continuous/CacheContinuousBatchAckTest.java |   2 +-
 ...eContinuousQueryAsyncFilterListenerTest.java |   2 +-
 ...acheContinuousQueryExecuteInPrimaryTest.java |   2 +-
 ...ContinuousQueryFailoverAbstractSelfTest.java |  85 ++++----
 ...ontinuousQueryOperationFromCallbackTest.java |   2 +-
 .../CacheContinuousQueryOperationP2PTest.java   |   2 +-
 .../CacheContinuousQueryOrderingEventTest.java  |   2 +-
 ...acheContinuousQueryRandomOperationsTest.java |   2 +-
 .../CacheKeepBinaryIterationTest.java           |   2 +-
 .../ClientReconnectContinuousQueryTest.java     |   4 +-
 ...yRemoteFilterMissingInClassPathSelfTest.java |   2 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |  68 ++++---
 ...dCacheContinuousQueryNodesFilteringTest.java |   2 +-
 ...dCacheContinuousQueryReplicatedSelfTest.java |   8 +-
 ...eContinuousQueryReplicatedTxOneNodeTest.java |   4 +-
 ...CacheContinuousQueryClientReconnectTest.java |   6 +-
 .../IgniteCacheContinuousQueryClientTest.java   |  18 +-
 ...eCacheContinuousQueryImmutableEntryTest.java |  10 +-
 ...teCacheContinuousQueryNoUnsubscribeTest.java |  14 +-
 ...IgniteCacheContinuousQueryReconnectTest.java |   8 +-
 ...BehindStorePartitionedMultiNodeSelfTest.java |   6 +-
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java |   2 +-
 ...CacheClientWriteBehindStoreAbstractTest.java |   2 +-
 ...ClientWriteBehindStoreNonCoalescingTest.java |   2 +-
 ...simisticDeadlockDetectionCrossCacheTest.java |   3 +-
 .../CacheVersionedEntryAbstractTest.java        |  10 +-
 .../database/IgniteDbAbstractTest.java          |   2 +-
 .../database/IgniteDbDynamicCacheSelfTest.java  |   4 +-
 .../database/IgniteDbPutGetAbstractTest.java    |  64 +++---
 .../DataStreamProcessorSelfTest.java            |  58 +++---
 .../datastreamer/DataStreamerImplSelfTest.java  |  10 +-
 .../DataStreamerMultiThreadedSelfTest.java      |   2 +-
 .../DataStreamerUpdateAfterLoadTest.java        |   5 +-
 .../IgniteDataStreamerPerformanceTest.java      |   2 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |   4 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |   3 +-
 .../igfs/IgfsDataManagerSelfTest.java           |   3 +-
 .../processors/igfs/IgfsIgniteMock.java         |   7 -
 .../igfs/IgfsMetaManagerSelfTest.java           |   3 +-
 .../processors/igfs/IgfsOneClientNodeTest.java  |   7 +-
 .../processors/igfs/IgfsProcessorSelfTest.java  |   3 +-
 .../processors/igfs/IgfsStartCacheTest.java     |   4 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |   3 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |   4 +-
 .../IgfsAbstractRecordResolverSelfTest.java     |   4 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |   4 +
 .../query/GridQueryCommandHandlerTest.java      |   2 +-
 .../GridServiceProcessorAbstractSelfTest.java   |   2 +-
 .../ServicePredicateAccessCacheTest.java        |   2 +-
 .../cache/GridCacheAbstractLoadTest.java        |   5 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |   2 +-
 .../loadtests/cache/GridCacheLoadTest.java      |   4 +-
 .../capacity/GridCapacityLoadTest.java          |   2 +-
 .../capacity/spring-capacity-cache.xml          |   2 +
 .../GridContinuousOperationsLoadTest.java       |   2 +-
 .../GridCachePartitionedAtomicLongLoadTest.java |   2 +-
 .../loadtests/discovery/GridGcTimeoutTest.java  |   2 +-
 .../marshaller/GridMarshallerAbstractTest.java  |  10 +-
 .../platform/PlatformComputeEchoTask.java       |  11 +-
 .../ignite/platform/PlatformSqlQueryTask.java   |   2 +-
 .../CacheCheckpointSpiSecondCacheSelfTest.java  |   7 +-
 .../communication/GridCacheMessageSelfTest.java |   2 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |   6 +-
 ...gniteClientReconnectMassiveShutdownTest.java |   4 +-
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |  12 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |  16 +-
 .../stream/socket/SocketStreamerSelfTest.java   |   6 +-
 .../ignite/testframework/GridTestUtils.java     |   2 +-
 .../testframework/junits/GridAbstractTest.java  |   5 +-
 .../junits/common/GridCommonAbstractTest.java   |  23 ++-
 .../multijvm/IgniteClusterProcessProxy.java     |   9 +-
 .../junits/multijvm/IgniteProcessProxy.java     |   5 -
 .../testframework/test/ParametersTest.java      |   7 +-
 .../tests/p2p/CacheDeploymentTestTask1.java     |   2 +-
 .../tests/p2p/CacheDeploymentTestTask3.java     |   2 +-
 .../p2p/GridP2PContinuousDeploymentTask1.java   |   2 +-
 .../CacheNoValueClassOnServerTestClient.java    |   2 +-
 .../sink/flink/FlinkIgniteSinkSelfTest.java     |   4 +-
 .../query/h2/H2IndexingAbstractGeoSelfTest.java |   3 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |   4 +-
 .../HibernateL2CacheConfigurationSelfTest.java  |   2 +-
 .../hibernate/HibernateL2CacheSelfTest.java     |   4 +-
 .../CacheHibernateStoreFactorySelfTest.java     |   2 +-
 .../CacheHibernateStoreFactorySelfTest.java     |   2 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  32 +--
 .../cache/BinarySerializationQuerySelfTest.java |   5 +-
 .../CacheBinaryKeyConcurrentQueryTest.java      |   2 +-
 .../cache/CacheIndexStreamerTest.java           |   4 +-
 .../CacheOffheapBatchIndexingBaseTest.java      |   2 +-
 .../CacheOperationsWithExpirationTest.java      |   2 +-
 .../cache/CacheQueryBuildValueTest.java         |   4 +-
 .../cache/CacheQueryEvictDataLostTest.java      |   2 +-
 .../cache/CacheQueryFilterExpiredTest.java      |   2 +-
 .../CacheRandomOperationsMultithreadedTest.java |   2 +-
 ...CacheScanPartitionQueryFallbackSelfTest.java |  12 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   |  18 +-
 .../cache/GridCacheOffHeapSelfTest.java         |   4 +-
 .../GridCacheOffheapIndexEntryEvictTest.java    |   4 +-
 .../cache/GridCacheQuerySimpleBenchmark.java    |   2 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   2 +-
 .../IgniteBinaryObjectFieldsQuerySelfTest.java  |   9 +-
 .../IgniteBinaryObjectQueryArgumentsTest.java   |   4 +-
 ...eBinaryWrappedObjectFieldsQuerySelfTest.java |   3 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |   2 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |   2 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   6 +-
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java |   2 +-
 .../IgniteCacheCollocatedQuerySelfTest.java     |   6 +-
 ...acheConfigurationPrimitiveTypesSelfTest.java |  14 +-
 .../IgniteCacheCrossCacheJoinRandomTest.java    |   2 +-
 ...acheDistributedJoinCollocatedAndNotTest.java |   2 +-
 ...acheDistributedJoinCustomAffinityMapper.java |   2 +-
 .../IgniteCacheDistributedJoinNoIndexTest.java  |   2 +-
 ...ributedJoinPartitionedAndReplicatedTest.java |   2 +-
 ...CacheDistributedJoinQueryConditionsTest.java |   2 +-
 .../cache/IgniteCacheDistributedJoinTest.java   |   6 +-
 .../IgniteCacheFieldsQueryNoDataSelfTest.java   |   2 +-
 ...teCacheFullTextQueryNodeJoiningSelfTest.java |   6 +-
 ...PartitionedAndReplicatedCollocationTest.java |   2 +-
 ...teCacheJoinPartitionedAndReplicatedTest.java |   2 +-
 ...IgniteCacheJoinQueryWithAffinityKeyTest.java |   2 +-
 .../cache/IgniteCacheLargeResultSelfTest.java   |   4 +-
 ...eLockPartitionOnAffinityRunAbstractTest.java |   4 +
 .../IgniteCacheMultipleIndexedTypesTest.java    |   2 +-
 .../IgniteCacheObjectKeyIndexingSelfTest.java   |   6 +-
 .../cache/IgniteCacheOffheapEvictQueryTest.java |   2 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java  |   4 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |   4 +-
 .../cache/IgniteCacheQueriesLoadTest1.java      |   2 +-
 .../IgniteCacheQueryH2IndexingLeakTest.java     |   4 +-
 .../cache/IgniteCacheQueryIndexSelfTest.java    |   4 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java     |  14 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |  15 +-
 ...gniteCacheSqlQueryMultiThreadedSelfTest.java |   6 +-
 .../IgniteCacheStarvationOnRebalanceTest.java   |   2 +-
 ...ClientReconnectCacheQueriesFailoverTest.java |  10 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |   2 +-
 .../cache/QueryEntityCaseMismatchTest.java      |   2 +-
 .../cache/SqlFieldsQuerySelfTest.java           |   2 +-
 ...niteCacheDistributedQueryCancelSelfTest.java |   6 +-
 ...butedQueryStopOnCancelOrTimeoutSelfTest.java |   6 +-
 .../IgniteCachePartitionedQuerySelfTest.java    |   2 +-
 .../IgniteCacheQueryNoRebalanceSelfTest.java    |   4 +-
 .../near/IgniteCacheQueryNodeFailTest.java      |   4 +-
 .../IgniteCacheQueryNodeRestartSelfTest.java    |   2 +-
 .../DynamicIndexAbstractConcurrentSelfTest.java |   5 +-
 ...eCacheLocalQueryCancelOrTimeoutSelfTest.java |   6 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java     |   6 +-
 .../query/IgniteQueryDedicatedPoolTest.java     |   2 +-
 .../query/IgniteSqlDistributedJoinSelfTest.java |   2 +-
 .../query/IgniteSqlSchemaIndexingTest.java      |   2 +-
 .../query/IgniteSqlSplitterSelfTest.java        |   2 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   4 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java      |   4 +-
 .../query/h2/sql/GridQueryParsingTest.java      |   7 +-
 .../stream/jms11/IgniteJmsStreamerTest.java     |  28 +--
 ...CacheJtaConfigurationValidationSelfTest.java |   2 +-
 ...CacheJtaFactoryConfigValidationSelfTest.java |   2 +-
 ...titionedCacheJtaLookupClassNameSelfTest.java |   2 +-
 .../kafka/KafkaIgniteStreamerSelfTest.java      |   8 +-
 .../stream/mqtt/IgniteMqttStreamerTest.java     |  12 +-
 .../Binary/BinaryCompactFooterInteropTest.cs    |   2 +-
 .../Binary/BinaryDynamicRegistrationTest.cs     |  18 +-
 .../Binary/JavaBinaryInteropTest.cs             |   6 +-
 .../BinaryConfigurationTest.cs                  |   2 +-
 .../Cache/Affinity/AffinityFieldTest.cs         |   4 +-
 .../Cache/Affinity/AffinityTest.cs              |   4 +-
 .../Cache/CacheConfigurationTest.cs             |  11 +-
 .../Cache/CacheForkedTest.cs                    |   2 +-
 .../Cache/CacheNearTest.cs                      |  34 +++-
 .../Cache/Query/CacheLinqTest.cs                |  23 ++-
 .../Compute/CancellationTest.cs                 |   4 +-
 .../Compute/ComputeApiTest.cs                   |  30 +--
 .../Config/Compute/compute-grid1.xml            |   1 +
 .../Config/Compute/compute-standalone.xml       |   4 +-
 .../Config/cache-binarizables.xml               |   4 +-
 .../native-client-test-cache-affinity.xml       |   1 +
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |  13 +-
 .../IgniteStartStopTest.cs                      |   2 +-
 .../Apache.Ignite.Core.Tests/MarshallerTest.cs  |  24 ++-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   4 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   3 +-
 .../Apache.Ignite.Core/Impl/Compute/Compute.cs  |  12 ++
 .../Impl/Compute/ComputeImpl.cs                 |   2 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |  14 ++
 .../scala/org/apache/ignite/scalar/scalar.scala |  19 +-
 .../scalar/src/test/resources/spring-cache.xml  |   1 +
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |   2 +-
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |   2 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |   2 +-
 .../spring/GridSpringCacheManagerSelfTest.java  |   6 +-
 .../jdbc/CacheJdbcBlobStoreFactorySelfTest.java |   2 +-
 .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java |   4 +-
 .../internal/IgniteDynamicCacheConfigTest.java  |   2 +-
 .../GridTransformSpringInjectionSelfTest.java   |   2 +-
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   8 +-
 .../IgniteStartFromStreamConfigurationTest.java |   4 +-
 .../GridSpringTransactionManagerSelfTest.java   |   2 +-
 .../twitter/IgniteTwitterStreamerTest.java      |   8 +-
 .../cache/VisorCacheClearCommandSpec.scala      |  24 +--
 .../commands/cache/VisorCacheCommandSpec.scala  |   2 +-
 .../cache/VisorCacheResetCommandSpec.scala      |   8 +-
 .../stream/zeromq/IgniteZeroMqStreamerTest.java |  12 +-
 661 files changed, 3189 insertions(+), 3044 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/examples/config/example-cache.xml
----------------------------------------------------------------------
diff --git a/examples/config/example-cache.xml b/examples/config/example-cache.xml
index 98e1a71..b0d13f4 100644
--- a/examples/config/example-cache.xml
+++ b/examples/config/example-cache.xml
@@ -41,6 +41,7 @@
             <list>
                 <!-- Partitioned cache example configuration (Atomic mode). -->
                 <bean class="org.apache.ignite.configuration.CacheConfiguration">
+                    <property name="name" value="default"/>
                     <property name="atomicityMode" value="ATOMIC"/>
                     <property name="backups" value="1"/>
                 </bean>

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheAbstractBenchmark.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheAbstractBenchmark.java
index 3d50b12..bb919f1 100644
--- a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheAbstractBenchmark.java
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheAbstractBenchmark.java
@@ -64,6 +64,9 @@ public class JmhCacheAbstractBenchmark extends JmhAbstractBenchmark {
     /** IP finder shared across nodes. */
     private static final TcpDiscoveryVmIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
 
+    /** Default cache name. */
+    private static final String DEFAULT_CACHE_NAME = "default";
+
     /** Target node. */
     protected Ignite node;
 
@@ -116,7 +119,7 @@ public class JmhCacheAbstractBenchmark extends JmhAbstractBenchmark {
             node = Ignition.start(clientCfg);
         }
 
-        cache = node.cache(null);
+        cache = node.cache(DEFAULT_CACHE_NAME);
     }
 
     /**
@@ -159,7 +162,7 @@ public class JmhCacheAbstractBenchmark extends JmhAbstractBenchmark {
     protected CacheConfiguration cacheConfiguration() {
         CacheConfiguration cacheCfg = new CacheConfiguration();
 
-        cacheCfg.setName(null);
+        cacheCfg.setName(DEFAULT_CACHE_NAME);
         cacheCfg.setCacheMode(CacheMode.PARTITIONED);
         cacheCfg.setRebalanceMode(CacheRebalanceMode.SYNC);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/camel/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTest.java
----------------------------------------------------------------------
diff --git a/modules/camel/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTest.java b/modules/camel/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTest.java
index 6940ea2..88b7eb8 100644
--- a/modules/camel/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTest.java
+++ b/modules/camel/src/test/java/org/apache/ignite/stream/camel/IgniteCamelStreamerTest.java
@@ -107,7 +107,7 @@ public class IgniteCamelStreamerTest extends GridCommonAbstractTest {
         }
 
         // create Camel streamer
-        dataStreamer = grid().dataStreamer(null);
+        dataStreamer = grid().dataStreamer(DEFAULT_CACHE_NAME);
         streamer = createCamelStreamer(dataStreamer);
     }
 
@@ -121,7 +121,7 @@ public class IgniteCamelStreamerTest extends GridCommonAbstractTest {
 
         dataStreamer.close();
 
-        grid().cache(null).clear();
+        grid().cache(DEFAULT_CACHE_NAME).clear();
     }
 
     /**
@@ -391,7 +391,7 @@ public class IgniteCamelStreamerTest extends GridCommonAbstractTest {
             }
         };
 
-        remoteLsnr = ignite.events(ignite.cluster().forCacheNodes(null))
+        remoteLsnr = ignite.events(ignite.cluster().forCacheNodes(DEFAULT_CACHE_NAME))
             .remoteListen(callback, null, EVT_CACHE_OBJECT_PUT);
 
         return latch;
@@ -402,7 +402,7 @@ public class IgniteCamelStreamerTest extends GridCommonAbstractTest {
      */
     private void assertCacheEntriesLoaded(int cnt) {
         // get the cache and check that the entries are present
-        IgniteCache<Integer, String> cache = grid().cache(null);
+        IgniteCache<Integer, String> cache = grid().cache(DEFAULT_CACHE_NAME);
 
         // for each key from 0 to count from the TEST_DATA (ordered by key), check that the entry is present in cache
         for (Integer key : new ArrayList<>(new TreeSet<>(TEST_DATA.keySet())).subList(0, cnt))
@@ -412,7 +412,7 @@ public class IgniteCamelStreamerTest extends GridCommonAbstractTest {
         assertEquals(cnt, cache.size(CachePeekMode.ALL));
 
         // remove the event listener
-        grid().events(grid().cluster().forCacheNodes(null)).stopRemoteListen(remoteLsnr);
+        grid().events(grid().cluster().forCacheNodes(DEFAULT_CACHE_NAME)).stopRemoteListen(remoteLsnr);
     }
 
 }

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientAbstractMultiThreadedSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientAbstractMultiThreadedSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientAbstractMultiThreadedSelfTest.java
index 027574b..ecdbd4a 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientAbstractMultiThreadedSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientAbstractMultiThreadedSelfTest.java
@@ -47,6 +47,7 @@ import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
@@ -179,7 +180,7 @@ public abstract class ClientAbstractMultiThreadedSelfTest extends GridCommonAbst
 
         c.setDiscoverySpi(disco);
 
-        c.setCacheConfiguration(cacheConfiguration(null), cacheConfiguration(PARTITIONED_CACHE_NAME),
+        c.setCacheConfiguration(cacheConfiguration(DEFAULT_CACHE_NAME), cacheConfiguration(PARTITIONED_CACHE_NAME),
             cacheConfiguration(REPLICATED_CACHE_NAME), cacheConfiguration(PARTITIONED_ASYNC_BACKUP_CACHE_NAME),
             cacheConfiguration(REPLICATED_ASYNC_CACHE_NAME));
 
@@ -191,31 +192,35 @@ public abstract class ClientAbstractMultiThreadedSelfTest extends GridCommonAbst
      * @return Cache configuration.
      * @throws Exception In case of error.
      */
-    private CacheConfiguration cacheConfiguration(@Nullable String cacheName) throws Exception {
+    private CacheConfiguration cacheConfiguration(@NotNull String cacheName) throws Exception {
         CacheConfiguration cfg = defaultCacheConfiguration();
 
         cfg.setAffinity(new RendezvousAffinityFunction());
 
         cfg.setAtomicityMode(TRANSACTIONAL);
 
-        if (cacheName == null)
-            cfg.setCacheMode(LOCAL);
-        else if (PARTITIONED_CACHE_NAME.equals(cacheName)) {
-            cfg.setCacheMode(PARTITIONED);
-
-            cfg.setBackups(0);
-        }
-        else if (PARTITIONED_ASYNC_BACKUP_CACHE_NAME.equals(cacheName)) {
-            cfg.setCacheMode(PARTITIONED);
-
-            cfg.setBackups(1);
+        switch (cacheName) {
+            case DEFAULT_CACHE_NAME:
+                cfg.setCacheMode(LOCAL);
+                break;
+            case PARTITIONED_CACHE_NAME:
+                cfg.setCacheMode(PARTITIONED);
+
+                cfg.setBackups(0);
+                break;
+            case PARTITIONED_ASYNC_BACKUP_CACHE_NAME:
+                cfg.setCacheMode(PARTITIONED);
+
+                cfg.setBackups(1);
+                break;
+            default:
+                cfg.setCacheMode(REPLICATED);
+                break;
         }
-        else
-            cfg.setCacheMode(REPLICATED);
 
         cfg.setName(cacheName);
 
-        if (cacheName != null && !cacheName.contains("async"))
+        if (!DEFAULT_CACHE_NAME.equals(cacheName) && !cacheName.contains("async"))
             cfg.setWriteSynchronizationMode(FULL_SYNC);
 
         return cfg;

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientDefaultCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientDefaultCacheSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientDefaultCacheSelfTest.java
index eae4b0e..25fa2e9 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientDefaultCacheSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientDefaultCacheSelfTest.java
@@ -112,7 +112,7 @@ public class ClientDefaultCacheSelfTest extends GridCommonAbstractTest {
 
         cfg.setDiscoverySpi(disco);
 
-        CacheConfiguration cLoc = new CacheConfiguration();
+        CacheConfiguration cLoc = new CacheConfiguration(DEFAULT_CACHE_NAME);
 
         cLoc.setName(LOCAL_CACHE);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractMultiNodeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractMultiNodeSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractMultiNodeSelfTest.java
index 2fba49a..c97d978 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractMultiNodeSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractMultiNodeSelfTest.java
@@ -73,6 +73,7 @@ import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 import static java.util.concurrent.TimeUnit.MILLISECONDS;
@@ -189,7 +190,7 @@ public abstract class ClientAbstractMultiNodeSelfTest extends GridCommonAbstract
 
         c.setCommunicationSpi(spi);
 
-        c.setCacheConfiguration(cacheConfiguration(null), cacheConfiguration(PARTITIONED_CACHE_NAME),
+        c.setCacheConfiguration(cacheConfiguration(DEFAULT_CACHE_NAME), cacheConfiguration(PARTITIONED_CACHE_NAME),
             cacheConfiguration(REPLICATED_CACHE_NAME), cacheConfiguration(REPLICATED_ASYNC_CACHE_NAME));
 
         c.setPublicThreadPoolSize(40);
@@ -204,20 +205,24 @@ public abstract class ClientAbstractMultiNodeSelfTest extends GridCommonAbstract
      * @return Cache configuration.
      * @throws Exception In case of error.
      */
-    private CacheConfiguration cacheConfiguration(@Nullable String cacheName) throws Exception {
+    private CacheConfiguration cacheConfiguration(@NotNull String cacheName) throws Exception {
         CacheConfiguration cfg = defaultCacheConfiguration();
 
         cfg.setAtomicityMode(TRANSACTIONAL);
 
-        if (cacheName == null)
-            cfg.setCacheMode(LOCAL);
-        else if (PARTITIONED_CACHE_NAME.equals(cacheName)) {
-            cfg.setCacheMode(PARTITIONED);
-
-            cfg.setBackups(0);
+        switch (cacheName) {
+            case DEFAULT_CACHE_NAME:
+                cfg.setCacheMode(LOCAL);
+                break;
+            case PARTITIONED_CACHE_NAME:
+                cfg.setCacheMode(PARTITIONED);
+
+                cfg.setBackups(0);
+                break;
+            default:
+                cfg.setCacheMode(REPLICATED);
+                break;
         }
-        else
-            cfg.setCacheMode(REPLICATED);
 
         cfg.setName(cacheName);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractSelfTest.java
index 45cc88a..89eebdf 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/integration/ClientAbstractSelfTest.java
@@ -70,6 +70,7 @@ import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 import static org.apache.ignite.IgniteSystemProperties.IGNITE_JETTY_PORT;
@@ -162,7 +163,7 @@ public abstract class ClientAbstractSelfTest extends GridCommonAbstractTest {
                 cacheStore.map.clear();
         }
 
-        grid().cache(null).clear();
+        grid().cache(DEFAULT_CACHE_NAME).clear();
         grid().cache(CACHE_NAME).clear();
 
         INTERCEPTED_OBJECTS.clear();
@@ -243,7 +244,7 @@ public abstract class ClientAbstractSelfTest extends GridCommonAbstractTest {
 
         cfg.setDiscoverySpi(disco);
 
-        cfg.setCacheConfiguration(cacheConfiguration(null), cacheConfiguration("replicated"),
+        cfg.setCacheConfiguration(cacheConfiguration(DEFAULT_CACHE_NAME), cacheConfiguration("replicated"),
             cacheConfiguration("partitioned"), cacheConfiguration(CACHE_NAME));
 
         clientCfg.setMessageInterceptor(new ConnectorMessageInterceptor() {
@@ -274,10 +275,10 @@ public abstract class ClientAbstractSelfTest extends GridCommonAbstractTest {
      * @throws Exception In case of error.
      */
     @SuppressWarnings("unchecked")
-    private  static CacheConfiguration cacheConfiguration(@Nullable final String cacheName) throws Exception {
+    private  static CacheConfiguration cacheConfiguration(@NotNull final String cacheName) throws Exception {
         CacheConfiguration cfg = defaultCacheConfiguration();
 
-        cfg.setCacheMode(cacheName == null || CACHE_NAME.equals(cacheName) ? LOCAL : "replicated".equals(cacheName) ?
+        cfg.setCacheMode(DEFAULT_CACHE_NAME.equals(cacheName) || CACHE_NAME.equals(cacheName) ? LOCAL : "replicated".equals(cacheName) ?
             REPLICATED : PARTITIONED);
         cfg.setName(cacheName);
         cfg.setWriteSynchronizationMode(FULL_SYNC);

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
index 90f52bd..6ef86d3 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
@@ -36,10 +36,10 @@ import static org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC;
  */
 public abstract class JdbcAbstractDmlStatementSelfTest extends GridCommonAbstractTest {
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=" + DEFAULT_CACHE_NAME + "@modules/clients/src/test/config/jdbc-config.xml";
 
     /** JDBC URL for tests involving binary objects manipulation. */
-    static final String BASE_URL_BIN = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-bin-config.xml";
+    static final String BASE_URL_BIN = CFG_URL_PREFIX + "cache=" + DEFAULT_CACHE_NAME + "@modules/clients/src/test/config/jdbc-bin-config.xml";
 
     /** SQL SELECT query for verification. */
     static final String SQL_SELECT = "select _key, id, firstName, lastName, age from Person";
@@ -64,9 +64,9 @@ public abstract class JdbcAbstractDmlStatementSelfTest extends GridCommonAbstrac
 
     /** {@inheritDoc} */
     @Override protected void beforeTest() throws Exception {
-        conn = DriverManager.getConnection(getCfgUrl());
-
         ignite(0).getOrCreateCache(cacheConfig());
+
+        conn = DriverManager.getConnection(getCfgUrl());
     }
 
     /**
@@ -129,7 +129,7 @@ public abstract class JdbcAbstractDmlStatementSelfTest extends GridCommonAbstrac
 
     /** {@inheritDoc} */
     @Override protected void afterTest() throws Exception {
-        grid(0).destroyCache(null);
+        grid(0).destroyCache(DEFAULT_CACHE_NAME);
 
         conn.close();
         assertTrue(conn.isClosed());

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcComplexQuerySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcComplexQuerySelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcComplexQuerySelfTest.java
index ebda604..725ec3a 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcComplexQuerySelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcComplexQuerySelfTest.java
@@ -32,6 +32,7 @@ import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 
 import static org.apache.ignite.IgniteJdbcDriver.CFG_URL_PREFIX;
 import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
@@ -46,7 +47,7 @@ public class JdbcComplexQuerySelfTest extends GridCommonAbstractTest {
     private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
 
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=pers@modules/clients/src/test/config/jdbc-config.xml";
 
     /** Statement. */
     private Statement stmt;
@@ -76,7 +77,7 @@ public class JdbcComplexQuerySelfTest extends GridCommonAbstractTest {
      * @param clsV Class v.
      * @return Cache configuration.
      */
-    protected CacheConfiguration cacheConfiguration(String name, Class<?> clsK, Class<?> clsV) {
+    protected CacheConfiguration cacheConfiguration(@NotNull String name, Class<?> clsK, Class<?> clsV) {
         CacheConfiguration<?,?> cache = defaultCacheConfiguration();
 
         cache.setName(name);

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcConnectionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcConnectionSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcConnectionSelfTest.java
index b999189..39a3648 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcConnectionSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcConnectionSelfTest.java
@@ -30,6 +30,7 @@ import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 import static org.apache.ignite.IgniteJdbcDriver.CFG_URL_PREFIX;
@@ -64,7 +65,7 @@ public class JdbcConnectionSelfTest extends GridCommonAbstractTest {
     @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);
 
-        cfg.setCacheConfiguration(cacheConfiguration(null), cacheConfiguration(CUSTOM_CACHE_NAME));
+        cfg.setCacheConfiguration(cacheConfiguration(DEFAULT_CACHE_NAME), cacheConfiguration(CUSTOM_CACHE_NAME));
 
         TcpDiscoverySpi disco = new TcpDiscoverySpi();
 
@@ -84,7 +85,7 @@ public class JdbcConnectionSelfTest extends GridCommonAbstractTest {
      * @return Cache configuration.
      * @throws Exception In case of error.
      */
-    private CacheConfiguration cacheConfiguration(@Nullable String name) throws Exception {
+    private CacheConfiguration cacheConfiguration(@NotNull String name) throws Exception {
         CacheConfiguration cfg = defaultCacheConfiguration();
 
         cfg.setName(name);

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
index c71ca94..6756a97 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
@@ -45,7 +45,7 @@ public class JdbcDistributedJoinsQueryTest extends GridCommonAbstractTest {
     private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
 
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "distributedJoins=true@modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=default:distributedJoins=true@modules/clients/src/test/config/jdbc-config.xml";
 
     /** Statement. */
     private Statement stmt;
@@ -79,14 +79,14 @@ public class JdbcDistributedJoinsQueryTest extends GridCommonAbstractTest {
     @Override protected void beforeTestsStarted() throws Exception {
         startGrids(3);
 
-        IgniteCache<String, Organization> orgCache = grid(0).cache(null);
+        IgniteCache<String, Organization> orgCache = grid(0).cache(DEFAULT_CACHE_NAME);
 
         assert orgCache != null;
 
         orgCache.put("o1", new Organization(1, "A"));
         orgCache.put("o2", new Organization(2, "B"));
 
-        IgniteCache<String, Person> personCache = grid(0).cache(null);
+        IgniteCache<String, Person> personCache = grid(0).cache(DEFAULT_CACHE_NAME);
 
         assert personCache != null;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
index 84ffc28..7bbda6f 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
@@ -148,14 +148,14 @@ public abstract class JdbcDynamicIndexAbstractSelfTest extends JdbcAbstractDmlSt
 
         // Test that local queries on all server nodes use new index.
         for (int i = 0 ; i < 3; i++) {
-            List<List<?>> locRes = ignite(i).cache(null).query(new SqlFieldsQuery("explain select id from " +
+            List<List<?>> locRes = ignite(i).cache(DEFAULT_CACHE_NAME).query(new SqlFieldsQuery("explain select id from " +
                 "Person where id = 5").setLocal(true)).getAll();
 
             assertEquals(F.asList(
                 Collections.singletonList("SELECT\n" +
                     "    ID\n" +
-                    "FROM \"\".PERSON\n" +
-                    "    /* \"\".IDX: ID = 5 */\n" +
+                    "FROM \"default\".PERSON\n" +
+                    "    /* \"default\".IDX: ID = 5 */\n" +
                     "WHERE ID = 5")
             ), locRes);
         }
@@ -203,14 +203,14 @@ public abstract class JdbcDynamicIndexAbstractSelfTest extends JdbcAbstractDmlSt
 
         // Test that no local queries on server nodes use new index.
         for (int i = 0 ; i < 3; i++) {
-            List<List<?>> locRes = ignite(i).cache(null).query(new SqlFieldsQuery("explain select id from " +
+            List<List<?>> locRes = ignite(i).cache(DEFAULT_CACHE_NAME).query(new SqlFieldsQuery("explain select id from " +
                 "Person where id = 5").setLocal(true)).getAll();
 
             assertEquals(F.asList(
                 Collections.singletonList("SELECT\n" +
                     "    ID\n" +
-                    "FROM \"\".PERSON\n" +
-                    "    /* \"\".PERSON.__SCAN_ */\n" +
+                    "FROM \"default\".PERSON\n" +
+                    "    /* \"default\".PERSON.__SCAN_ */\n" +
                     "WHERE ID = 5")
             ), locRes);
         }
@@ -305,7 +305,7 @@ public abstract class JdbcDynamicIndexAbstractSelfTest extends JdbcAbstractDmlSt
      * @return Cache.
      */
     private IgniteCache<String, Person> cache() {
-        return grid(0).cache(null);
+        return grid(0).cache(DEFAULT_CACHE_NAME);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcInsertStatementSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcInsertStatementSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcInsertStatementSelfTest.java
index 9e01bc7..b23f947 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcInsertStatementSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcInsertStatementSelfTest.java
@@ -108,9 +108,9 @@ public class JdbcInsertStatementSelfTest extends JdbcAbstractDmlStatementSelfTes
             }
         }
 
-        grid(0).cache(null).clear();
+        grid(0).cache(DEFAULT_CACHE_NAME).clear();
 
-        assertEquals(0, grid(0).cache(null).size(CachePeekMode.ALL));
+        assertEquals(0, grid(0).cache(DEFAULT_CACHE_NAME).size(CachePeekMode.ALL));
 
         super.afterTest();
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMergeStatementSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMergeStatementSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMergeStatementSelfTest.java
index 3c56c92..f4577f5 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMergeStatementSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMergeStatementSelfTest.java
@@ -103,9 +103,9 @@ public class JdbcMergeStatementSelfTest extends JdbcAbstractDmlStatementSelfTest
             }
         }
 
-        grid(0).cache(null).clear();
+        grid(0).cache(DEFAULT_CACHE_NAME).clear();
 
-        assertEquals(0, grid(0).cache(null).size(CachePeekMode.ALL));
+        assertEquals(0, grid(0).cache(DEFAULT_CACHE_NAME).size(CachePeekMode.ALL));
 
         super.afterTest();
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
index ebf8874..e382b9d 100755
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
@@ -37,6 +37,7 @@ import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 
 import static java.sql.Types.INTEGER;
 import static java.sql.Types.OTHER;
@@ -81,7 +82,7 @@ public class JdbcMetadataSelfTest extends GridCommonAbstractTest {
      * @param clsV Class v.
      * @return Cache configuration.
      */
-    protected CacheConfiguration cacheConfiguration(String name, Class<?> clsK, Class<?> clsV) {
+    protected CacheConfiguration cacheConfiguration(@NotNull String name, Class<?> clsK, Class<?> clsV) {
         CacheConfiguration<?,?> cache = defaultCacheConfiguration();
 
         cache.setName(name);

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcNoDefaultCacheTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcNoDefaultCacheTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcNoDefaultCacheTest.java
index 4bb2fe8..b28f9dd 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcNoDefaultCacheTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcNoDefaultCacheTest.java
@@ -20,7 +20,9 @@ package org.apache.ignite.internal.jdbc2;
 import java.sql.Connection;
 import java.sql.DriverManager;
 import java.sql.ResultSet;
+import java.sql.SQLException;
 import java.sql.Statement;
+import java.util.concurrent.Callable;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.configuration.CacheConfiguration;
@@ -28,7 +30,9 @@ import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 import static org.apache.ignite.IgniteJdbcDriver.CFG_URL_PREFIX;
@@ -72,7 +76,7 @@ public class JdbcNoDefaultCacheTest extends GridCommonAbstractTest {
      * @return Cache configuration.
      * @throws Exception In case of error.
      */
-    private CacheConfiguration cacheConfiguration(@Nullable String name) throws Exception {
+    private CacheConfiguration cacheConfiguration(@NotNull String name) throws Exception {
         CacheConfiguration cfg = defaultCacheConfiguration();
 
         cfg.setIndexedTypes(Integer.class, Integer.class);
@@ -125,39 +129,20 @@ public class JdbcNoDefaultCacheTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testNoCacheNameQuery() throws Exception {
-        Statement stmt;
-
-        try (Connection conn = DriverManager.getConnection(CFG_URL_PREFIX + CFG_URL)) {
-            stmt = conn.createStatement();
-
+        try (
+            Connection conn = DriverManager.getConnection(CFG_URL_PREFIX + CFG_URL);
+            final Statement stmt = conn.createStatement()) {
             assertNotNull(stmt);
             assertFalse(stmt.isClosed());
 
-            stmt.execute("select t._key, t._val from \"cache1\".Integer t");
-
-            ResultSet rs = stmt.getResultSet();
-
-            while(rs.next())
-                assertEquals(rs.getInt(2), rs.getInt(1) * 2);
-
-            stmt.execute("select t._key, t._val from \"cache2\".Integer t");
-
-            rs = stmt.getResultSet();
-
-            while(rs.next())
-                assertEquals(rs.getInt(2), rs.getInt(1) * 3);
-
-            stmt.execute("select t._key, t._val, v._val " +
-                "from \"cache1\".Integer t join \"cache2\".Integer v on t._key = v._key");
-
-            rs = stmt.getResultSet();
-
-            while(rs.next()) {
-                assertEquals(rs.getInt(2), rs.getInt(1) * 2);
-                assertEquals(rs.getInt(3), rs.getInt(1) * 3);
-            }
+            Throwable throwable = GridTestUtils.assertThrows(null, new Callable<Void>() {
+                @Override public Void call() throws Exception {
+                    stmt.execute("select t._key, t._val from \"cache1\".Integer t");
+                    return null;
+                }
+            }, SQLException.class, "Failed to query Ignite.");
 
-            stmt.close();
+            assertEquals(throwable.getCause().getMessage(), "Ouch! Argument is invalid: Cache name must not be null or empty.");
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcPreparedStatementSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcPreparedStatementSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcPreparedStatementSelfTest.java
index 67127b0..5e402ff 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcPreparedStatementSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcPreparedStatementSelfTest.java
@@ -63,7 +63,7 @@ public class JdbcPreparedStatementSelfTest extends GridCommonAbstractTest {
     private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
 
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=default@modules/clients/src/test/config/jdbc-config.xml";
 
     /** Connection. */
     private Connection conn;
@@ -101,7 +101,7 @@ public class JdbcPreparedStatementSelfTest extends GridCommonAbstractTest {
     @Override protected void beforeTestsStarted() throws Exception {
         startGridsMultiThreaded(3);
 
-        IgniteCache<Integer, TestObject> cache = grid(0).cache(null);
+        IgniteCache<Integer, TestObject> cache = grid(0).cache(DEFAULT_CACHE_NAME);
 
         assert cache != null;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcResultSetSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcResultSetSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcResultSetSelfTest.java
index 8fb651d..43cd586 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcResultSetSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcResultSetSelfTest.java
@@ -55,7 +55,7 @@ public class JdbcResultSetSelfTest extends GridCommonAbstractTest {
     private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
 
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=default@modules/clients/src/test/config/jdbc-config.xml";
 
     /** SQL query. */
     private static final String SQL =
@@ -97,7 +97,7 @@ public class JdbcResultSetSelfTest extends GridCommonAbstractTest {
     @Override protected void beforeTestsStarted() throws Exception {
         startGridsMultiThreaded(3);
 
-        IgniteCache<Integer, TestObject> cache = grid(0).cache(null);
+        IgniteCache<Integer, TestObject> cache = grid(0).cache(DEFAULT_CACHE_NAME);
 
         assert cache != null;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStatementSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStatementSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStatementSelfTest.java
index 7826987..99e813d 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStatementSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStatementSelfTest.java
@@ -45,7 +45,7 @@ public class JdbcStatementSelfTest extends GridCommonAbstractTest {
     private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
 
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=default@modules/clients/src/test/config/jdbc-config.xml";
 
     /** SQL query. */
     private static final String SQL = "select * from Person where age > 30";
@@ -86,7 +86,7 @@ public class JdbcStatementSelfTest extends GridCommonAbstractTest {
     @Override protected void beforeTestsStarted() throws Exception {
         startGridsMultiThreaded(3);
 
-        IgniteCache<String, Person> cache = grid(0).cache(null);
+        IgniteCache<String, Person> cache = grid(0).cache(DEFAULT_CACHE_NAME);
 
         assert cache != null;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStreamingSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStreamingSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStreamingSelfTest.java
index 6837a41..5c98b1a 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStreamingSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcStreamingSelfTest.java
@@ -41,7 +41,7 @@ import static org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC;
  */
 public class JdbcStreamingSelfTest extends GridCommonAbstractTest {
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL = CFG_URL_PREFIX + "cache=default@modules/clients/src/test/config/jdbc-config.xml";
 
     /** Connection. */
     protected Connection conn;
@@ -121,7 +121,7 @@ public class JdbcStreamingSelfTest extends GridCommonAbstractTest {
     @Override protected void afterTest() throws Exception {
         U.closeQuiet(conn);
 
-        ignite(0).cache(null).clear();
+        ignite(0).cache(DEFAULT_CACHE_NAME).clear();
 
         super.afterTest();
     }
@@ -133,7 +133,7 @@ public class JdbcStreamingSelfTest extends GridCommonAbstractTest {
         conn = createConnection(false);
 
         for (int i = 10; i <= 100; i += 10)
-            ignite(0).cache(null).put(i, i * 100);
+            ignite(0).cache(DEFAULT_CACHE_NAME).put(i, i * 100);
 
         PreparedStatement stmt = conn.prepareStatement("insert into Integer(_key, _val) values (?, ?)");
 
@@ -151,9 +151,9 @@ public class JdbcStreamingSelfTest extends GridCommonAbstractTest {
         // Now let's check it's all there.
         for (int i = 1; i <= 100; i++) {
             if (i % 10 != 0)
-                assertEquals(i, grid(0).cache(null).get(i));
+                assertEquals(i, grid(0).cache(DEFAULT_CACHE_NAME).get(i));
             else // All that divides by 10 evenly should point to numbers 100 times greater - see above
-                assertEquals(i * 100, grid(0).cache(null).get(i));
+                assertEquals(i * 100, grid(0).cache(DEFAULT_CACHE_NAME).get(i));
         }
     }
 
@@ -164,7 +164,7 @@ public class JdbcStreamingSelfTest extends GridCommonAbstractTest {
         conn = createConnection(true);
 
         for (int i = 10; i <= 100; i += 10)
-            ignite(0).cache(null).put(i, i * 100);
+            ignite(0).cache(DEFAULT_CACHE_NAME).put(i, i * 100);
 
         PreparedStatement stmt = conn.prepareStatement("insert into Integer(_key, _val) values (?, ?)");
 
@@ -182,6 +182,6 @@ public class JdbcStreamingSelfTest extends GridCommonAbstractTest {
         // Now let's check it's all there.
         // i should point to i at all times as we've turned overwrites on above.
         for (int i = 1; i <= 100; i++)
-            assertEquals(i, grid(0).cache(null).get(i));
+            assertEquals(i, grid(0).cache(DEFAULT_CACHE_NAME).get(i));
     }
 }

http://git-wip-us.apache.org/repos/asf/ignite/blob/8f9edebf/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/AbstractRestProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/AbstractRestProcessorSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/AbstractRestProcessorSelfTest.java
index 5baac62..712b71a 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/AbstractRestProcessorSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/AbstractRestProcessorSelfTest.java
@@ -100,6 +100,6 @@ abstract class AbstractRestProcessorSelfTest extends GridCommonAbstractTest {
      * @return Cache.
      */
     @Override protected <K, V> IgniteCache<K, V> jcache() {
-        return grid(0).cache(null);
+        return grid(0).cache(DEFAULT_CACHE_NAME);
     }
 }