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:13:52 UTC

[36/36] ignite git commit: Merge branch 'ignite-2.0' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-5094

Merge branch 'ignite-2.0' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-5094


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

Branch: refs/heads/ignite-5094
Commit: b3113adb79c5d34d46512584bbde74888bddf350
Parents: d58ca39 f5db974
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Thu Apr 27 10:13:35 2017 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Thu Apr 27 10:13:35 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 |  16 +-
 .../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    |  31 +-
 .../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     | 308 ++++++++++-----
 .../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/JdbcMetadataSelfTest.java       |   8 +-
 .../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 +-
 .../org/apache/ignite/cache/QueryEntity.java    |  81 ++++
 .../configuration/CacheConfiguration.java       |  18 +-
 .../configuration/DataPageEvictionMode.java     |  17 +-
 .../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 ++--
 .../cache/DynamicCacheDescriptor.java           |  24 ++
 .../processors/cache/GridCacheProcessor.java    | 203 +++++-----
 .../cache/GridCacheSharedContext.java           |  18 +-
 .../processors/cache/GridCacheUtils.java        |  30 +-
 .../cache/query/GridCacheQueryManager.java      |  14 +-
 .../cache/transactions/IgniteTxManager.java     |  20 +-
 .../cache/transactions/TxDeadlock.java          |  19 +-
 .../cache/transactions/TxLocksResponse.java     |  37 +-
 .../utils/PlatformConfigurationUtils.java       |  15 +-
 .../processors/query/GridQueryIndexing.java     |  23 +-
 .../query/GridQueryTypeDescriptor.java          |  12 +
 .../query/QueryTypeDescriptorImpl.java          |  34 +-
 .../internal/processors/query/QueryUtils.java   | 134 +++++--
 .../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 +-
 .../visor/binary/VisorBinaryMetadata.java       |   8 +-
 .../VisorBinaryMetadataCollectorTask.java       |  16 +-
 .../VisorBinaryMetadataCollectorTaskArg.java    |  71 ++++
 .../VisorBinaryMetadataCollectorTaskResult.java |   4 +-
 .../cache/VisorCacheAffinityConfiguration.java  |   8 +-
 .../visor/cache/VisorCacheClearTask.java        |  19 +-
 .../visor/cache/VisorCacheClearTaskArg.java     |  72 ++++
 .../visor/cache/VisorCacheConfiguration.java    | 149 +++++++
 .../VisorCacheConfigurationCollectorJob.java    |  12 +-
 .../VisorCacheConfigurationCollectorTask.java   |   5 +-
 ...VisorCacheConfigurationCollectorTaskArg.java |  74 ++++
 .../visor/cache/VisorCacheLoadTask.java         |   5 +-
 .../visor/cache/VisorCacheLoadTaskArg.java      |   2 +-
 .../visor/cache/VisorCacheMetadataTask.java     |  14 +-
 .../visor/cache/VisorCacheMetadataTaskArg.java  |  72 ++++
 .../visor/cache/VisorCacheNodesTask.java        |  12 +-
 .../visor/cache/VisorCacheNodesTaskArg.java     |  72 ++++
 .../cache/VisorCacheRebalanceConfiguration.java |  26 ++
 .../visor/cache/VisorCacheRebalanceTask.java    |  13 +-
 .../visor/cache/VisorCacheRebalanceTaskArg.java |  73 ++++
 .../visor/cache/VisorCacheResetMetricsTask.java |  14 +-
 .../cache/VisorCacheResetMetricsTaskArg.java    |  72 ++++
 .../visor/cache/VisorCacheStartArg.java         | 100 -----
 .../visor/cache/VisorCacheStopTask.java         |  17 +-
 .../visor/cache/VisorCacheStopTaskArg.java      |  72 ++++
 .../cache/VisorCacheStoreConfiguration.java     |  14 +
 .../internal/visor/cache/VisorPartitionMap.java |  24 +-
 .../compute/VisorComputeCancelSessionsTask.java |  13 +-
 .../VisorComputeCancelSessionsTaskArg.java      |  76 ++++
 .../visor/compute/VisorGatewayTask.java         |  87 +++-
 .../internal/visor/debug/VisorThreadInfo.java   |  64 +--
 .../visor/debug/VisorThreadMonitorInfo.java     |   8 +-
 .../internal/visor/file/VisorFileBlockArg.java  | 114 ------
 .../visor/igfs/VisorIgfsFormatTask.java         |  14 +-
 .../visor/igfs/VisorIgfsFormatTaskArg.java      |  72 ++++
 .../visor/igfs/VisorIgfsProfilerClearTask.java  |  24 +-
 .../igfs/VisorIgfsProfilerClearTaskArg.java     |  72 ++++
 .../igfs/VisorIgfsProfilerClearTaskResult.java  |   6 +-
 .../visor/igfs/VisorIgfsProfilerTask.java       |  18 +-
 .../visor/igfs/VisorIgfsProfilerTaskArg.java    |  72 ++++
 .../visor/igfs/VisorIgfsResetMetricsTask.java   |  13 +-
 .../igfs/VisorIgfsResetMetricsTaskArg.java      |  73 ++++
 .../internal/visor/log/VisorLogSearchArg.java   | 114 ------
 .../internal/visor/misc/VisorAckTask.java       |  14 +-
 .../internal/visor/misc/VisorAckTaskArg.java    |  72 ++++
 .../misc/VisorChangeGridActiveStateTask.java    |  12 +-
 .../misc/VisorChangeGridActiveStateTaskArg.java |  71 ++++
 .../visor/node/VisorBasicConfiguration.java     | 224 ++++++++++-
 .../visor/node/VisorBinaryConfiguration.java    | 131 +++++++
 .../node/VisorBinaryTypeConfiguration.java      | 150 +++++++
 .../visor/node/VisorCacheKeyConfiguration.java  | 108 +++++
 .../visor/node/VisorExecutorConfiguration.java  | 108 +++++
 .../node/VisorExecutorServiceConfiguration.java | 115 ++++++
 .../visor/node/VisorGridConfiguration.java      | 110 ++++++
 .../visor/node/VisorHadoopConfiguration.java    | 145 +++++++
 .../visor/node/VisorIgfsConfiguration.java      |  42 +-
 .../node/VisorMemoryPolicyConfiguration.java    |  41 ++
 .../internal/visor/node/VisorNodePingTask.java  |  13 +-
 .../visor/node/VisorNodePingTaskArg.java        |  73 ++++
 .../visor/node/VisorNodeSuppressedErrors.java   |   6 +-
 .../node/VisorNodeSuppressedErrorsTask.java     |  12 +-
 .../node/VisorNodeSuppressedErrorsTaskArg.java  |  74 ++++
 .../visor/node/VisorOdbcConfiguration.java      | 114 ++++++
 .../visor/node/VisorRestConfiguration.java      | 207 +++++++++-
 .../node/VisorSegmentationConfiguration.java    |  13 +
 .../visor/node/VisorServiceConfiguration.java   | 176 +++++++++
 .../internal/visor/query/VisorQueryArg.java     | 155 --------
 .../visor/query/VisorQueryCancelTask.java       |  12 +-
 .../visor/query/VisorQueryCancelTaskArg.java    |  71 ++++
 .../visor/query/VisorQueryCleanupTask.java      |  10 +-
 .../visor/query/VisorQueryCleanupTaskArg.java   |  75 ++++
 .../VisorQueryDetailMetricsCollectorTask.java   |  17 +-
 ...VisorQueryDetailMetricsCollectorTaskArg.java |  71 ++++
 .../query/VisorQueryResetDetailMetricsTask.java |   6 +-
 .../visor/query/VisorQueryResetMetricsTask.java |  18 +-
 .../query/VisorQueryResetMetricsTaskArg.java    |  72 ++++
 .../query/VisorRunningQueriesCollectorTask.java |  16 +-
 .../VisorRunningQueriesCollectorTaskArg.java    |  71 ++++
 .../internal/visor/query/VisorScanQueryArg.java | 157 --------
 .../visor/service/VisorCancelServiceTask.java   |  12 +-
 .../service/VisorCancelServiceTaskArg.java      |  72 ++++
 .../internal/visor/util/VisorTaskUtils.java     |  23 ++
 .../spi/indexing/IndexingQueryFilter.java       |   2 +-
 .../resources/META-INF/classnames.properties    |  39 +-
 .../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 +-
 ...ryConfigurationCustomSerializerSelfTest.java |   4 +-
 .../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 +-
 ...DeadlockDetectionMessageMarshallingTest.java | 116 ++++++
 .../TxDeadlockDetectionUnmasrhalErrorsTest.java | 225 +++++++++++
 ...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 +-
 .../GridInternalTasksLoadBalancingSelfTest.java |   7 +-
 .../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 +-
 .../TxDeadlockDetectionTestSuite.java           |   4 +
 .../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 +-
 .../query/h2/DmlStatementsProcessor.java        |  17 +-
 .../processors/query/h2/IgniteH2Indexing.java   | 223 +++++++++--
 .../query/h2/dml/UpdatePlanBuilder.java         |  32 +-
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |  78 ++--
 .../query/h2/opt/GridH2CollocationModel.java    |   4 +-
 .../query/h2/opt/GridH2IndexBase.java           |  15 +-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   6 +-
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |   6 +-
 .../query/h2/opt/GridH2ProxyIndex.java          | 204 ++++++++++
 .../query/h2/opt/GridH2ProxySpatialIndex.java   |  70 ++++
 .../query/h2/opt/GridH2RowDescriptor.java       |  67 ++++
 .../processors/query/h2/opt/GridH2Table.java    | 114 +++++-
 .../query/h2/opt/GridLuceneIndex.java           |   4 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |  36 +-
 .../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   |   8 +-
 ...eBinaryWrappedObjectFieldsQuerySelfTest.java |   3 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |  17 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |   2 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   6 +-
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java |   2 +-
 .../IgniteCacheCollocatedQuerySelfTest.java     |   6 +-
 ...acheConfigurationPrimitiveTypesSelfTest.java |  14 +-
 .../IgniteCacheCrossCacheJoinRandomTest.java    |   2 +-
 .../IgniteCacheDeleteSqlQuerySelfTest.java      |   6 +-
 ...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 +-
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |   8 +-
 ...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 +-
 .../cache/index/AbstractSchemaSelfTest.java     |   3 +
 .../DynamicIndexAbstractConcurrentSelfTest.java |   5 +-
 .../index/DynamicIndexAbstractSelfTest.java     |   3 +
 ...eCacheLocalQueryCancelOrTimeoutSelfTest.java |   6 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java     |   6 +-
 .../query/IgniteQueryDedicatedPoolTest.java     |   2 +-
 .../query/IgniteSqlDistributedJoinSelfTest.java |   2 +-
 .../query/IgniteSqlKeyValueFieldsTest.java      | 392 +++++++++++++++++++
 .../query/IgniteSqlSchemaIndexingTest.java      |   2 +-
 .../query/IgniteSqlSplitterSelfTest.java        |  10 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  14 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java      |   4 +-
 .../query/h2/sql/GridQueryParsingTest.java      |   9 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   2 +
 .../stream/jms11/IgniteJmsStreamerTest.java     |  28 +-
 ...CacheJtaConfigurationValidationSelfTest.java |   2 +-
 ...CacheJtaFactoryConfigValidationSelfTest.java |   2 +-
 ...titionedCacheJtaLookupClassNameSelfTest.java |   2 +-
 .../kafka/KafkaIgniteStreamerSelfTest.java      |   8 +-
 .../stream/mqtt/IgniteMqttStreamerTest.java     |  12 +-
 modules/osgi/README.txt                         |  30 --
 .../core-test/config/cache-query-default.xml    |   6 +
 .../cpp/core-test/src/cache_query_test.cpp      |  82 ++++
 .../cpp/odbc-test/config/queries-default.xml    |   5 +
 .../cpp/odbc-test/include/complex_type.h        |  25 ++
 .../cpp/odbc-test/src/queries_test.cpp          | 148 +++++++
 .../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                |  30 +-
 .../Cache/Query/CacheQueriesTest.cs             |  52 +++
 .../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 +-
 .../IgniteConfigurationSerializerTest.cs        |   7 +-
 .../IgniteConfigurationTest.cs                  |   8 +-
 .../IgniteStartStopTest.cs                      |   2 +-
 .../Apache.Ignite.Core.Tests/MarshallerTest.cs  |  24 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   4 +-
 .../Cache/Configuration/QueryEntity.cs          |  20 +
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |  28 --
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   3 +-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  21 +
 .../IgniteConfigurationSection.xsd              |  31 +-
 .../Apache.Ignite.Core/Impl/Compute/Compute.cs  |  12 +
 .../Impl/Compute/ComputeImpl.cs                 |   2 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |  14 +
 .../Impl/CacheQueryExpressionVisitor.cs         |  14 +-
 .../Impl/CacheQueryModelVisitor.cs              |  12 +-
 .../stream/rocketmq/RocketMQStreamerTest.java   |   8 +-
 .../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 +-
 .../visor/commands/ack/VisorAckCommand.scala    |   5 +-
 .../commands/cache/VisorCacheClearCommand.scala |   5 +-
 .../commands/cache/VisorCacheResetCommand.scala |   4 +-
 .../commands/cache/VisorCacheStopCommand.scala  |   4 +-
 .../config/VisorConfigurationCommand.scala      |   2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   5 +-
 .../cache/VisorCacheClearCommandSpec.scala      |  24 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |   2 +-
 .../cache/VisorCacheResetCommandSpec.scala      |   8 +-
 .../web-console/backend/app/browsersHandler.js  |   3 +-
 modules/web-console/backend/app/mongo.js        |   4 +-
 .../app/modules/agent/AgentManager.service.js   |   3 +-
 .../generator/ConfigurationGenerator.js         |   7 +-
 .../generator/PlatformGenerator.js              |   5 +-
 .../generator/defaults/Cluster.service.js       |   4 +-
 .../frontend/app/modules/sql/sql.controller.js  |   2 +-
 .../states/configuration/clusters/discovery.pug |   8 +-
 .../stream/zeromq/IgniteZeroMqStreamerTest.java |  12 +-
 parent/pom.xml                                  |   1 +
 812 files changed, 9545 insertions(+), 4318 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/b3113adb/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/paged/PageEvictionAbstractTest.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/paged/PageEvictionAbstractTest.java
index 6709211,3aee941..39927be
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/paged/PageEvictionAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/eviction/paged/PageEvictionAbstractTest.java
@@@ -109,8 -102,8 +110,8 @@@ public class PageEvictionAbstractTest e
       * @param memoryPlcName Memory policy name.
       * @return Cache configuration.
       */
 -    protected static CacheConfiguration<Object, Object> cacheConfig(
 +    protected CacheConfiguration<Object, Object> cacheConfig(
-         String name,
+         @NotNull String name,
          String memoryPlcName,
          CacheMode cacheMode,
          CacheAtomicityMode atomicityMode,