You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by dp...@apache.org on 2019/01/31 15:05:18 UTC

[ignite] branch ignite-11155 updated (0f573de -> 71f567f)

This is an automated email from the ASF dual-hosted git repository.

dpavlov pushed a change to branch ignite-11155
in repository https://gitbox.apache.org/repos/asf/ignite.git.


    from 0f573de  IGNITE-11155 Output warning in case JDK internals access is not enabled
     add 048d74e  IGNITE-10160: SQL: Code to generate cluster-wide unique query ID. This closes #5872.
     add 29b5086  IGNITE-11119: Fixed flaky IgniteCacheQueryH2IndexingLeakTest. This closes #5958.
     add 6821ef9  IGNITE-11134: SQL: Do not wrap key and value objects in GridH2KeyValueRowOnheap. This closes #5975.
     add 4fde445  IGNITE-10758 Removed scaffolding annotations from tests - Fixes #5867.
     add fed1591  IGNITE-11037: [ML] Add parser for Spark KMeans clustering model
     add 15bf6cf  IGNITE-10377: MVCC: Incorrect exception on no data nodes found for a partition fixed. This closes #5823.
     add 2b8b721  IGNITE-10750: MVCC: Unmute tests. This closes #5900.
     add 923e550  IGNITE-11122: [ML] Extend DatasetBuilder API with ability to extract features and labels depending on each other
     add 5b2b359  IGNITE-10520: MVCC: Exclude non-relevant test scenarios. This closes #5885.
     add 9af6e92  IGNITE-10359: MVCC: P2P deployment for EntryProcessor fixed. This closes #5626.
     add 67acdfd  IGNITE-10921 Add IGNITE_OVERRIDE_CONSISTENT_ID system property.
     add e59ecc2  IGNITE-11145: [ML] Add vector projection
     add 0836fc2  IGNITE-10179 use @BeforeClass and @AfterClass instead of isFirstTest() and isLastTest() - Fixes #5925.
     add f4acd88  IGNITE-11114 Web console: Fixed left navigation menu item hover state color. Fixes #5954.
     add 977108a  IGNITE-11033 Fixed IllegalStateException in VisorBaselineTask on set new baseline.
     add 24ff65b  IGNITE-11101 Web console: Fixed scroll to element in Firefox and Safari. Fixes #5957.
     add 2861851  IGNITE-11136: @Ignore test MultiThreadedFailover for MVCC, until IGNITE-11148 isn't fixed. - Fixes #5976.
     add 332103e  IGNITE-11140 Fix Ignite examples compilation, support of Nightly builds (#5978)
     add 2a5c3d3  IGNITE-11158 Accommodate some of the recent tests to changes made per IGNITE-10179 (#5989)
     new 71f567f  Merge branch 'master' into ignite-11155

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 examples/README.md                                 |  30 ++
 examples/pom-standalone.xml                        |  45 ++
 ...arkExample.java => KMeansFromSparkExample.java} |  37 +-
 .../{svm/metadata => kmeans/data}/._SUCCESS.crc    | Bin
 ...-4b9e-879e-de4afd4f65bc-c000.snappy.parquet.crc | Bin 0 -> 24 bytes
 .../{svm/metadata => kmeans/data}/_SUCCESS         |   0
 ...c65a-4b9e-879e-de4afd4f65bc-c000.snappy.parquet | Bin 0 -> 1622 bytes
 .../{svm => kmeans}/metadata/._SUCCESS.crc         | Bin
 .../serialized/kmeans/metadata/.part-00000.crc     | Bin 0 -> 12 bytes
 .../serialized/{svm => kmeans}/metadata/_SUCCESS   |   0
 .../spark/serialized/kmeans/metadata/part-00000    |   1 +
 .../org/apache/ignite/gridify/AbstractAopTest.java |   3 -
 .../apache/ignite/gridify/BasicAopSelfTest.java    |   3 -
 .../GridifySetToXXXNonSpringAopSelfTest.java       |   3 -
 .../gridify/GridifySetToXXXSpringAopSelfTest.java  |   3 -
 .../gridify/hierarchy/GridifyHierarchyTest.java    |   3 -
 .../optimized/OptimizedMarshallerAopTest.java      |   3 -
 .../org/apache/ignite/p2p/P2PGridifySelfTest.java  |   3 -
 .../direct/singlesplit/SingleSplitsLoadTest.java   |   3 -
 .../gridify/GridifySingleSplitLoadTest.java        |   3 -
 .../test/gridify/ExternalNonSpringAopSelfTest.java |   3 -
 .../checkpoint/s3/S3CheckpointManagerSelfTest.java |   3 -
 .../s3/S3CheckpointSpiConfigSelfTest.java          |   3 -
 .../spi/checkpoint/s3/S3CheckpointSpiSelfTest.java |   4 +-
 ...eckpointSpiStartStopBucketEndpointSelfTest.java |   3 -
 ...CheckpointSpiStartStopSSEAlgorithmSelfTest.java |   3 -
 .../s3/S3CheckpointSpiStartStopSelfTest.java       |   3 -
 .../checkpoint/s3/S3SessionCheckpointSelfTest.java |   3 -
 .../elb/TcpDiscoveryElbIpFinderSelfTest.java       |   3 -
 .../s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java |   3 -
 ...ryS3IpFinderAwsCredentialsProviderSelfTest.java |   3 -
 ...pDiscoveryS3IpFinderAwsCredentialsSelfTest.java |   3 -
 ...pDiscoveryS3IpFinderBucketEndpointSelfTest.java |   3 -
 .../TcpDiscoveryS3IpFinderKeyPrefixSelfTest.java   |   3 -
 ...TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java |   3 -
 .../ipfinder/s3/client/DummyObjectListingTest.java |   3 -
 .../tcp/ipfinder/s3/client/DummyS3ClientTest.java  |   3 -
 .../AsymmetricKeyEncryptionServiceTest.java        |   3 -
 .../s3/encrypt/AwsKmsEncryptionServiceTest.java    |   3 -
 .../s3/encrypt/MockEncryptionServiceTest.java      |   3 -
 .../encrypt/SymmetricKeyEncryptionServiceTest.java |   3 -
 .../stream/camel/IgniteCamelStreamerTest.java      |   3 -
 .../internal/TaskEventSubjectIdSelfTest.java       |   3 -
 .../ClientAbstractMultiThreadedSelfTest.java       |   3 -
 .../client/ClientDefaultCacheSelfTest.java         |   3 -
 .../client/ClientReconnectionSelfTest.java         |   3 -
 .../internal/client/ClientSslParametersTest.java   |   3 -
 .../client/ClientTcpSslAuthenticationSelfTest.java |   3 -
 ...pTaskExecutionAfterTopologyRestartSelfTest.java |   3 -
 .../client/impl/ClientComputeImplSelfTest.java     |   3 -
 .../client/impl/ClientDataImplSelfTest.java        |   3 -
 .../client/impl/ClientFutureAdapterSelfTest.java   |   3 -
 .../ClientPropertiesConfigurationSelfTest.java     |   3 -
 .../ClientAbstractConnectivitySelfTest.java        |   3 -
 .../ClientAbstractMultiNodeSelfTest.java           |   3 -
 .../client/integration/ClientAbstractSelfTest.java |   3 -
 .../integration/ClientPreferDirectSelfTest.java    |   3 -
 .../client/router/ClientFailedInitSelfTest.java    |   3 -
 .../client/router/RouterFactorySelfTest.java       |   3 -
 .../client/router/TcpRouterAbstractSelfTest.java   |   3 -
 .../internal/client/util/ClientByteUtilsTest.java  |   3 -
 .../client/util/ClientConsistentHashSelfTest.java  |   3 -
 .../client/util/ClientJavaHasherSelfTest.java      |   3 -
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java       |   3 -
 .../internal/jdbc2/JdbcComplexQuerySelfTest.java   |   3 -
 .../internal/jdbc2/JdbcConnectionReopenTest.java   |   3 -
 .../internal/jdbc2/JdbcConnectionSelfTest.java     |   3 -
 .../jdbc2/JdbcDeleteStatementSelfTest.java         |   3 -
 .../jdbc2/JdbcDistributedJoinsQueryTest.java       |   3 -
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java    |   3 -
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java     |   3 -
 .../ignite/internal/jdbc2/JdbcErrorsSelfTest.java  |   3 -
 .../jdbc2/JdbcInsertStatementSelfTest.java         |   3 -
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java    |   3 -
 .../internal/jdbc2/JdbcMergeStatementSelfTest.java |   3 -
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |   3 -
 .../jdbc2/JdbcNoCacheStreamingSelfTest.java        |   3 -
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java     |   3 -
 .../jdbc2/JdbcPreparedStatementSelfTest.java       |   3 -
 .../internal/jdbc2/JdbcResultSetSelfTest.java      |   3 -
 .../ignite/internal/jdbc2/JdbcSpringSelfTest.java  |   3 -
 .../jdbc2/JdbcStatementBatchingSelfTest.java       |   3 -
 .../internal/jdbc2/JdbcStatementSelfTest.java      |   3 -
 .../internal/jdbc2/JdbcStreamingSelfTest.java      |   3 -
 .../jdbc2/JdbcStreamingToPublicCacheTest.java      |   3 -
 .../jdbc2/JdbcUpdateStatementSelfTest.java         |   3 -
 .../rest/ChangeStateCommandHandlerTest.java        |   3 -
 .../rest/ClientMemcachedProtocolSelfTest.java      |   3 -
 .../rest/JettyRestProcessorAbstractSelfTest.java   |   3 -
 ...ttyRestProcessorAuthenticationAbstractTest.java |   3 -
 ...stProcessorAuthenticationWithTokenSelfTest.java |   3 -
 .../rest/JettyRestProcessorBaselineSelfTest.java   |  13 +-
 .../rest/JettyRestProcessorGetAllAsArrayTest.java  |   3 -
 .../rest/JettyRestProcessorSignedSelfTest.java     |   3 -
 .../rest/RestBinaryProtocolSelfTest.java           |   3 -
 .../rest/RestMemcacheProtocolSelfTest.java         |   3 -
 .../rest/RestProcessorMultiStartSelfTest.java      |   3 -
 .../rest/RestProcessorStartSelfTest.java           |   3 -
 .../rest/TaskCommandHandlerSelfTest.java           |   3 -
 .../rest/TcpRestUnmarshalVulnerabilityTest.java    |   3 -
 .../rest/protocols/tcp/TcpRestParserSelfTest.java  |   3 -
 .../tcp/redis/RedisProtocolConnectSelfTest.java    |   3 -
 .../tcp/redis/RedisProtocolServerSelfTest.java     |   3 -
 ...ProtocolStringAtomicDatastructuresSelfTest.java |   3 -
 .../tcp/redis/RedisProtocolStringSelfTest.java     |   3 -
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java      |   3 -
 .../apache/ignite/jdbc/JdbcConnectionSelfTest.java |   3 -
 .../apache/ignite/jdbc/JdbcEmptyCacheSelfTest.java |   3 -
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |   3 -
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java       |   3 -
 .../apache/ignite/jdbc/JdbcMetadataSelfTest.java   |   3 -
 .../apache/ignite/jdbc/JdbcNoDefaultCacheTest.java |   3 -
 .../ignite/jdbc/JdbcPojoLegacyQuerySelfTest.java   |   3 -
 .../apache/ignite/jdbc/JdbcPojoQuerySelfTest.java  |   3 -
 .../ignite/jdbc/JdbcPreparedStatementSelfTest.java |   3 -
 .../apache/ignite/jdbc/JdbcResultSetSelfTest.java  |   3 -
 .../apache/ignite/jdbc/JdbcStatementSelfTest.java  |   3 -
 .../ignite/jdbc/JdbcThinMetadataSqlMatchTest.java  |   5 +-
 .../ignite/jdbc/JdbcVersionMismatchSelfTest.java   |   3 -
 .../JdbcThinAuthenticateConnectionSelfTest.java    |   3 -
 .../thin/JdbcThinAutoCloseServerCursorTest.java    |   3 -
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java    |   3 -
 .../thin/JdbcThinBulkLoadAbstractSelfTest.java     |   3 -
 .../JdbcThinComplexDmlDdlCustomSchemaSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinComplexDmlDdlSelfTest.java   |   3 -
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java    |   3 -
 .../JdbcThinConnectionMultipleAddressesTest.java   |   3 -
 .../JdbcThinConnectionMvccEnabledSelfTest.java     |   3 -
 .../jdbc/thin/JdbcThinConnectionSSLTest.java       |   3 -
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |   3 -
 .../thin/JdbcThinConnectionTimeoutSelfTest.java    |   5 +-
 .../jdbc/thin/JdbcThinDataSourceSelfTest.java      |   3 -
 .../jdbc/thin/JdbcThinDeleteStatementSelfTest.java |   3 -
 .../thin/JdbcThinDynamicIndexAbstractSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java      |   3 -
 .../ignite/jdbc/thin/JdbcThinErrorsSelfTest.java   |   3 -
 .../jdbc/thin/JdbcThinInsertStatementSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinLocalQueriesSelfTest.java    |   3 -
 .../jdbc/thin/JdbcThinMergeStatementSelfTest.java  |   3 -
 .../thin/JdbcThinMetadataPrimaryKeysSelfTest.java  |   3 -
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |   3 -
 .../thin/JdbcThinMissingLongArrayResultsTest.java  |   3 -
 .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java     |   3 -
 .../thin/JdbcThinPreparedStatementSelfTest.java    |   3 -
 .../jdbc/thin/JdbcThinResultSetSelfTest.java       |   3 -
 .../ignite/jdbc/thin/JdbcThinSchemaCaseTest.java   |   3 -
 .../jdbc/thin/JdbcThinSelectAfterAlterTable.java   |   3 -
 .../jdbc/thin/JdbcThinStatementCancelSelfTest.java |   5 +-
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |   3 -
 .../thin/JdbcThinStatementTimeoutSelfTest.java     |   5 +-
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |   3 -
 .../apache/ignite/jdbc/thin/JdbcThinTcpIoTest.java |   3 -
 ...dbcThinTransactionsAbstractComplexSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinTransactionsSelfTest.java    |   3 -
 ...dbcThinTransactionsWithMvccEnabledSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinUpdateStatementSelfTest.java |   3 -
 ...nsactionFinishOnDeactivatedClusterSelfTest.java |   3 -
 .../client/ClientMarshallerBenchmarkTest.java      |   3 -
 .../loadtests/client/ClientTcpSslLoadTest.java     |   3 -
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |   3 -
 .../compatibility/PdsWithTtlCompatibilityTest.java |   3 -
 .../persistence/FoldersReuseCompatibilityTest.java |   3 -
 .../IgnitePKIndexesMigrationToUnwrapPkTest.java    |   3 -
 ...gratingToWalV2SerializerWithCompactionTest.java |   3 -
 .../PersistenceBasicCompatibilityTest.java         |   3 -
 .../compress/CompressionConfigurationTest.java     |   3 -
 .../compress/CompressionProcessorTest.java         |   3 -
 .../DiskPageCompressionIntegrationTest.java        |   3 -
 .../org/apache/ignite/IgniteSystemProperties.java  |   8 +
 .../org/apache/ignite/internal/IgnitionEx.java     |   6 +
 .../processors/cache/GridCacheDeployable.java      |   2 +-
 .../processors/cache/GridCacheEntryEx.java         |   8 +-
 .../processors/cache/GridCacheMapEntry.java        |  14 +-
 .../internal/processors/cache/GridCacheUtils.java  |   2 +-
 .../cache/IgniteCacheOffheapManager.java           |   8 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |  26 +-
 .../dht/GridDhtTransactionalCacheAdapter.java      |   3 +-
 .../dht/GridDhtTxAbstractEnlistFuture.java         |  11 +-
 .../distributed/dht/GridDhtTxEnlistFuture.java     |  11 +-
 .../dht/GridDhtTxQueryAbstractEnlistFuture.java    |   3 +-
 .../dht/GridDhtTxQueryEnlistRequest.java           |  32 +-
 .../dht/GridDhtTxQueryFirstEnlistRequest.java      |   5 -
 .../cache/distributed/dht/GridInvokeValue.java     |  68 ++-
 .../cache/distributed/near/GridNearGetFuture.java  |   6 +
 .../distributed/near/GridNearTxEnlistFuture.java   |  12 +-
 .../distributed/near/GridNearTxEnlistRequest.java  | 108 +++--
 .../distributed/near/GridNearTxEnlistResponse.java |   2 +-
 .../cache/distributed/near/GridNearTxLocal.java    |  15 +-
 .../cache/persistence/GridCacheOffheapManager.java |   5 +-
 .../cache/transactions/IgniteTxHandler.java        |   1 +
 .../processors/query/GridRunningQueryInfo.java     |  28 +-
 .../internal/processors/query/QueryUtils.java      |  11 +
 .../processors/query/RunningQueryManager.java      |  13 +-
 .../internal/visor/baseline/VisorBaselineTask.java |  11 +-
 .../ignite/GridCacheAffinityBackupsSelfTest.java   |   3 -
 .../apache/ignite/IgniteCacheAffinitySelfTest.java |   3 -
 ...gniteCacheEntryProcessorSequentialCallTest.java |   3 -
 .../ignite/cache/IgniteWarmupClosureSelfTest.java  |   3 -
 .../apache/ignite/cache/LargeEntryUpdateTest.java  |   3 -
 .../ignite/cache/ResetLostPartitionTest.java       |   3 -
 .../affinity/AbstractAffinityFunctionSelfTest.java |   3 -
 .../cache/affinity/AffinityClientNodeSelfTest.java |   3 -
 .../affinity/AffinityDistributionLoggingTest.java  |   3 -
 ...finityFunctionBackupFilterAbstractSelfTest.java |   3 -
 ...tyFunctionExcludeNeighborsAbstractSelfTest.java |   3 -
 .../cache/affinity/AffinityHistoryCleanupTest.java |   3 -
 .../affinity/local/LocalAffinityFunctionTest.java  |   3 -
 .../RendezvousAffinityFunctionSimpleBenchmark.java |   3 -
 ...nerRWThroughDisabledTransactionalCacheTest.java |  17 +-
 .../cache/store/CacheStoreReadFromBackupTest.java  |   3 -
 .../CacheStoreSessionListenerAbstractSelfTest.java |   3 -
 ...CacheStoreSessionListenerLifecycleSelfTest.java |  13 +-
 ...stenerReadWriteThroughDisabledAbstractTest.java |   3 -
 ...StoreSessionListenerWriteBehindEnabledTest.java |  19 +-
 .../cache/store/CacheStoreWriteErrorTest.java      |   3 -
 .../CacheTransactionalStoreReadFromBackupTest.java |   2 +-
 .../store/GridCacheBalancingStoreSelfTest.java     |   3 -
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java     |   7 +-
 .../ignite/cache/store/GridStoreLoadCacheTest.java |   3 -
 .../store/IgniteCacheExpiryStoreLoadSelfTest.java  |   3 -
 .../store/StoreResourceInjectionSelfTest.java      |   3 -
 .../jdbc/CacheJdbcPojoStoreAbstractSelfTest.java   |   7 +-
 ...CacheJdbcPojoStoreBinaryMarshallerSelfTest.java |   3 -
 .../cache/store/jdbc/CacheJdbcPojoStoreTest.java   |   3 -
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |   3 -
 ...acheJdbcStoreAbstractMultithreadedSelfTest.java |   3 -
 .../CacheJdbcStoreSessionListenerSelfTest.java     |  12 +-
 ...ridCacheJdbcBlobStoreMultithreadedSelfTest.java |   7 +-
 .../jdbc/JdbcTypesDefaultTransformerTest.java      |   3 -
 .../apache/ignite/client/SslParametersTest.java    |   3 -
 .../failure/FailureHandlerTriggeredTest.java       |   3 -
 .../failure/FailureHandlingConfigurationTest.java  |   3 -
 .../ignite/failure/IoomFailureHandlerTest.java     |   3 -
 .../ignite/failure/OomFailureHandlerTest.java      |   3 -
 .../ignite/failure/StopNodeFailureHandlerTest.java |   3 -
 .../failure/StopNodeOrHaltFailureHandlerTest.java  |   3 -
 .../ignite/failure/SystemWorkersBlockingTest.java  |   3 -
 .../failure/SystemWorkersTerminationTest.java      |   3 -
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java    |   3 -
 .../ignite/igfs/IgfsFragmentizerSelfTest.java      |   3 -
 .../igfs/IgfsFragmentizerTopologySelfTest.java     |   3 -
 .../org/apache/ignite/igfs/IgfsPathSelfTest.java   |   3 -
 .../ClusterBaselineNodesMetricsSelfTest.java       |   3 -
 .../ignite/internal/ClusterGroupAbstractTest.java  |   3 -
 .../ignite/internal/ClusterGroupHostsSelfTest.java |   3 -
 .../ignite/internal/ClusterGroupSelfTest.java      |   3 -
 .../ignite/internal/ClusterMetricsSelfTest.java    |   3 -
 .../internal/ClusterNodeMetricsSelfTest.java       |   3 -
 .../internal/ClusterNodeMetricsUpdateTest.java     |   3 -
 .../ComputeJobCancelWithServiceSelfTest.java       |   3 -
 .../ConsistentIdImplicitlyExplicitlyTest.java      | 186 +++++++++
 .../ignite/internal/GridAffinityMappedTest.java    |   3 -
 .../internal/GridAffinityNoCacheSelfTest.java      |   3 -
 .../ignite/internal/GridAffinityP2PSelfTest.java   |   3 -
 .../ignite/internal/GridAffinitySelfTest.java      |   3 -
 .../GridAlwaysFailoverSpiFailSelfTest.java         |  31 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |   3 -
 .../internal/GridCancelOnGridStopSelfTest.java     |   3 -
 .../internal/GridCancelUnusedJobSelfTest.java      |   3 -
 .../internal/GridCancelledJobsMetricsSelfTest.java |   3 -
 .../internal/GridCollisionJobsContextSelfTest.java |   3 -
 .../ignite/internal/GridCommunicationSelfTest.java |   3 -
 ...idComputationBinarylizableClosuresSelfTest.java |   3 -
 .../GridContinuousJobAnnotationSelfTest.java       |   3 -
 .../GridContinuousJobSiblingsSelfTest.java         |   3 -
 .../internal/GridContinuousTaskSelfTest.java       |   3 -
 .../GridDeploymentMultiThreadedSelfTest.java       |   3 -
 .../ignite/internal/GridDeploymentSelfTest.java    |   3 -
 .../internal/GridDiscoveryEventSelfTest.java       |   3 -
 .../ignite/internal/GridDiscoverySelfTest.java     |   3 -
 .../GridEventStorageCheckAllEventsSelfTest.java    |   3 -
 .../GridEventStorageDefaultExceptionTest.java      |   3 -
 ...idEventStorageRuntimeConfigurationSelfTest.java |   3 -
 .../ignite/internal/GridEventStorageSelfTest.java  |   3 -
 .../GridFailFastNodeFailureDetectionSelfTest.java  |   3 -
 .../GridFailedInputParametersSelfTest.java         |   3 -
 .../GridFailoverCustomTopologySelfTest.java        |   3 -
 .../ignite/internal/GridFailoverSelfTest.java      |   3 -
 .../GridFailoverTaskWithPredicateSelfTest.java     |   3 -
 .../internal/GridFailoverTopologySelfTest.java     |   3 -
 .../ignite/internal/GridGetOrStartSelfTest.java    |   3 -
 .../ignite/internal/GridHomePathSelfTest.java      |   3 -
 .../internal/GridJobCheckpointCleanupSelfTest.java |   3 -
 .../internal/GridJobCollisionCancelSelfTest.java   |   3 -
 .../ignite/internal/GridJobContextSelfTest.java    |   3 -
 .../internal/GridJobMasterLeaveAwareSelfTest.java  |   3 -
 .../internal/GridJobServicesAddNodeTest.java       |   3 -
 .../ignite/internal/GridJobStealingSelfTest.java   |   3 -
 .../GridJobStealingZeroActiveJobsSelfTest.java     |   3 -
 .../ignite/internal/GridJobSubjectIdSelfTest.java  |   3 -
 .../GridKernalConcurrentAccessStopSelfTest.java    |   3 -
 .../ignite/internal/GridLifecycleBeanSelfTest.java |   3 -
 .../ignite/internal/GridListenActorSelfTest.java   |   3 -
 .../internal/GridLocalEventListenerSelfTest.java   |   3 -
 .../org/apache/ignite/internal/GridMBeansTest.java |   3 -
 .../ignite/internal/GridMultipleJobsSelfTest.java  |   3 -
 .../ignite/internal/GridMultipleSpisSelfTest.java  |   3 -
 .../GridMultipleVersionsDeploymentSelfTest.java    |   3 -
 .../GridMultithreadedJobStealingSelfTest.java      |   3 -
 .../ignite/internal/GridNodeFilterSelfTest.java    |  14 +-
 .../ignite/internal/GridNodeLocalSelfTest.java     |   3 -
 .../internal/GridNodeMetricsLogSelfTest.java       |   3 -
 .../internal/GridNodeVisorAttributesSelfTest.java  |   3 -
 .../internal/GridNonHistoryMetricsSelfTest.java    |   3 -
 .../internal/GridProjectionForCachesSelfTest.java  |   3 -
 ...rojectionLocalJobMultipleArgumentsSelfTest.java |   3 -
 .../apache/ignite/internal/GridReduceSelfTest.java |   3 -
 .../ignite/internal/GridReleaseTypeSelfTest.java   |   3 -
 .../internal/GridRuntimeExceptionSelfTest.java     |   3 -
 .../ignite/internal/GridSameVmStartupSelfTest.java |   3 -
 .../org/apache/ignite/internal/GridSelfTest.java   |   3 -
 .../ignite/internal/GridSpiExceptionSelfTest.java  |   3 -
 .../ignite/internal/GridStartStopSelfTest.java     |   3 -
 .../internal/GridStopWithCancelSelfTest.java       |   3 -
 .../ignite/internal/GridStopWithWaitSelfTest.java  |   3 -
 .../internal/GridTaskCancelSingleNodeSelfTest.java |   3 -
 .../internal/GridTaskContinuousMapperSelfTest.java |   3 -
 .../internal/GridTaskExecutionContextSelfTest.java |   3 -
 .../ignite/internal/GridTaskExecutionSelfTest.java |   3 -
 .../internal/GridTaskFailoverAffinityRunTest.java  |   3 -
 .../ignite/internal/GridTaskFailoverSelfTest.java  |   3 -
 .../GridTaskFutureImplStopGridSelfTest.java        |   3 -
 .../GridTaskInstanceExecutionSelfTest.java         |   3 -
 .../internal/GridTaskInstantiationSelfTest.java    |   3 -
 .../ignite/internal/GridTaskJobRejectSelfTest.java |   3 -
 .../ignite/internal/GridTaskListenerSelfTest.java  |   3 -
 .../ignite/internal/GridTaskMapAsyncSelfTest.java  |   3 -
 .../internal/GridTaskNameAnnotationSelfTest.java   |   3 -
 .../internal/GridTaskResultCacheSelfTest.java      |   3 -
 .../ignite/internal/GridTaskTimeoutSelfTest.java   |   3 -
 .../internal/GridTopicExternalizableSelfTest.java  |   3 -
 .../ignite/internal/GridVersionSelfTest.java       |   3 -
 ...ClientConnectAfterCommunicationFailureTest.java |   3 -
 .../IgniteClientReconnectApiExceptionTest.java     |   3 -
 .../internal/IgniteClientReconnectAtomicsTest.java |   3 -
 .../IgniteClientReconnectBinaryContexTest.java     |   3 -
 .../internal/IgniteClientReconnectCacheTest.java   |   3 -
 .../IgniteClientReconnectCollectionsTest.java      |   3 -
 .../internal/IgniteClientReconnectComputeTest.java |   3 -
 ...niteClientReconnectContinuousProcessorTest.java |   3 -
 .../IgniteClientReconnectDelayedSpiTest.java       |   3 -
 .../IgniteClientReconnectDiscoveryStateTest.java   |   3 -
 .../IgniteClientReconnectFailoverTest.java         |   3 -
 .../IgniteClientReconnectServicesTest.java         |   3 -
 .../internal/IgniteClientReconnectStopTest.java    |   3 -
 .../IgniteClientReconnectStreamerTest.java         |   3 -
 .../ignite/internal/IgniteClientRejoinTest.java    |   3 -
 .../IgniteComputeEmptyClusterGroupTest.java        |   3 -
 .../internal/IgniteComputeJobOneThreadTest.java    |   3 -
 .../internal/IgniteComputeResultExceptionTest.java |   3 -
 .../IgniteComputeTopologyExceptionTest.java        |   3 -
 ...niteConcurrentEntryProcessorAccessStopTest.java |   3 -
 ...teConnectionConcurrentReserveAndRemoveTest.java |   3 -
 .../IgniteDiscoveryMassiveNodeFailTest.java        |   3 -
 .../ignite/internal/IgniteExecutorServiceTest.java |   3 -
 .../IgniteExplicitImplicitDeploymentSelfTest.java  |   3 -
 .../internal/IgniteInternalCacheRemoveTest.java    |   3 -
 .../IgniteLocalNodeMapBeforeStartTest.java         |   3 -
 ...iteRoundRobinErrorAfterClientReconnectTest.java |   3 -
 .../IgniteSlowClientDetectionSelfTest.java         |   3 -
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |   3 -
 .../internal/IgniteVersionUtilsSelfTest.java       |   3 -
 .../ignite/internal/LongJVMPauseDetectorTest.java  |   3 -
 .../internal/MarshallerContextLockingSelfTest.java |   7 +-
 .../internal/MemoryLeaksOnRestartNodeTest.java     |   3 -
 .../ignite/internal/TaskNodeRestartTest.java       |   3 -
 .../internal/TransactionMetricsMxBeanImplTest.java |   7 +-
 .../internal/TransactionsMXBeanImplTest.java       |   3 -
 .../internal/VisorManagementEventSelfTest.java     |   3 -
 .../BinaryArrayIdentityResolverSelfTest.java       |   3 -
 .../binary/BinaryBasicIdMapperSelfTest.java        |   3 -
 .../binary/BinaryBasicNameMapperSelfTest.java      |   3 -
 .../BinaryConfigurationConsistencySelfTest.java    |   3 -
 ...inaryConfigurationCustomSerializerSelfTest.java |   3 -
 .../internal/binary/BinaryEnumsSelfTest.java       |   3 -
 .../binary/BinaryFieldExtractionSelfTest.java      |   3 -
 .../binary/BinaryFieldsAbstractSelfTest.java       |   3 -
 .../BinaryFooterOffsetsAbstractSelfTest.java       |   3 -
 .../internal/binary/BinaryMarshallerSelfTest.java  |   3 -
 .../BinaryObjectBuilderAdditionalSelfTest.java     |   3 -
 .../BinaryObjectBuilderDefaultMappersSelfTest.java |   3 -
 .../binary/BinaryObjectExceptionSelfTest.java      |   3 -
 .../binary/BinaryObjectToStringSelfTest.java       |   3 -
 .../binary/BinaryObjectTypeCompatibilityTest.java  |   3 -
 .../BinarySerialiedFieldComparatorSelfTest.java    |   3 -
 .../BinarySimpleNameTestPropertySelfTest.java      |   3 -
 .../ignite/internal/binary/BinaryTreeSelfTest.java |   3 -
 .../binary/GridBinaryAffinityKeySelfTest.java      |   3 -
 .../GridBinaryMarshallerCtxDisabledSelfTest.java   |   3 -
 .../binary/GridBinaryWildcardsSelfTest.java        |   3 -
 ...DefaultBinaryMappersBinaryMetaDataSelfTest.java |   3 -
 .../AbstractBinaryStreamByteOrderSelfTest.java     |   3 -
 .../streams/BinaryAbstractOutputStreamTest.java    |   3 -
 .../encryption/EncryptedCacheBigEntryTest.java     |   3 -
 .../encryption/EncryptedCacheCreateTest.java       |   3 -
 .../encryption/EncryptedCacheDestroyTest.java      |   3 -
 .../encryption/EncryptedCacheGroupCreateTest.java  |   3 -
 .../encryption/EncryptedCacheNodeJoinTest.java     |   3 -
 .../EncryptedCachePreconfiguredRestartTest.java    |   3 -
 .../encryption/EncryptedCacheRestartTest.java      |   3 -
 .../GridManagerLocalMessageListenerSelfTest.java   |   3 -
 .../internal/managers/GridManagerStopSelfTest.java |   3 -
 .../internal/managers/GridNoopManagerSelfTest.java |   3 -
 .../managers/IgniteDiagnosticMessagesTest.java     |   3 -
 .../checkpoint/GridCheckpointManagerSelfTest.java  |   3 -
 .../checkpoint/GridCheckpointTaskSelfTest.java     |   3 -
 .../GridCommunicationManagerListenersSelfTest.java |   3 -
 .../GridCommunicationSendMessageSelfTest.java      |   3 -
 .../communication/GridIoManagerSelfTest.java       |   3 -
 .../IgniteCommunicationBalanceTest.java            |   3 -
 .../communication/IgniteIoTestMessagesTest.java    |   3 -
 .../IgniteVariousConnectionNumberTest.java         |   3 -
 ...loymentRequestOfUnknownClassProcessingTest.java |   3 -
 .../GridDeploymentManagerStopSelfTest.java         |   3 -
 .../GridDeploymentMessageCountSelfTest.java        |   3 -
 .../GridDiscoveryManagerAliveCacheSelfTest.java    |   3 -
 .../GridDiscoveryManagerAttributesSelfTest.java    |   3 -
 .../IgniteTopologyPrintFormatSelfTest.java         |   3 -
 .../events/GridEventStorageManagerSelfTest.java    |   3 -
 .../OptimizedMarshallerNodeFailoverTest.java       |   3 -
 .../optimized/OptimizedMarshallerSelfTest.java     |   3 -
 ...edMarshallerSerialPersistentFieldsSelfTest.java |   3 -
 .../optimized/OptimizedMarshallerTest.java         |   3 -
 .../optimized/OptimizedObjectStreamSelfTest.java   |   3 -
 .../internal/pagemem/impl/PageIdUtilsSelfTest.java |   3 -
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java     |   3 -
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java    |  13 +-
 .../affinity/GridAffinityAssignmentV2Test.java     |   3 -
 ...ridAffinityAssignmentV2TestNoOptimizations.java |   3 -
 .../GridAffinityProcessorAbstractSelfTest.java     |   3 -
 .../GridAffinityProcessorMemoryLeakTest.java       |   3 -
 .../Authentication1kUsersNodeRestartTest.java      |   3 -
 .../AuthenticationConfigurationClusterTest.java    |   3 -
 .../AuthenticationOnNotActiveClusterTest.java      |   3 -
 .../AuthenticationProcessorNPEOnStartTest.java     |   3 -
 .../AuthenticationProcessorNodeRestartTest.java    |   3 -
 .../AuthenticationProcessorSelfTest.java           |   3 -
 .../AtomicCacheAffinityConfigurationTest.java      |   3 -
 ...tadataRegistrationInsideEntryProcessorTest.java |   3 -
 .../cache/CacheAffinityCallSelfTest.java           |   3 -
 .../CacheAtomicSingleMessageCountSelfTest.java     |   3 -
 .../processors/cache/CacheClientStoreSelfTest.java |  13 +-
 .../cache/CacheConcurrentReadThroughTest.java      |  15 +-
 .../cache/CacheConfigurationLeakTest.java          |   3 -
 .../cache/CacheConnectionLeakStoreTxTest.java      |   3 -
 .../cache/CacheDataRegionConfigurationTest.java    |   3 -
 .../cache/CacheDeferredDeleteQueueTest.java        |   3 -
 .../cache/CacheDeferredDeleteSanitySelfTest.java   |   3 -
 .../CacheDhtLocalPartitionAfterRemoveSelfTest.java |   3 -
 .../cache/CacheEntryProcessorCopySelfTest.java     |   3 -
 .../cache/CacheEnumOperationsAbstractTest.java     |   3 -
 .../cache/CacheEventWithTxLabelTest.java           |   3 -
 .../CacheExchangeMessageDuplicatedStateTest.java   |   3 -
 .../cache/CacheFutureExceptionSelfTest.java        |   3 -
 .../cache/CacheGetEntryAbstractTest.java           |   3 -
 ...eGetEntryPessimisticRepeatableReadSelfTest.java |   3 -
 .../processors/cache/CacheGetFromJobTest.java      |   3 -
 .../cache/CacheGetsDistributionAbstractTest.java   |   3 -
 .../CacheGroupLocalConfigurationSelfTest.java      |   3 -
 .../cache/CacheGroupMetricsMBeanTest.java          |   3 -
 .../cache/CacheGroupsMetricsRebalanceTest.java     |   3 -
 ...InterceptorPartitionCounterLocalSanityTest.java |   3 -
 ...ceptorPartitionCounterRandomOperationsTest.java |   3 -
 .../cache/CacheKeepBinaryTransactionTest.java      |   3 -
 .../cache/CacheLocalGetSerializationTest.java      |   3 -
 .../cache/CacheMetricsCacheSizeTest.java           |   3 -
 .../cache/CacheMetricsEntitiesCountTest.java       |   3 -
 .../cache/CacheMetricsForClusterGroupSelfTest.java |   5 +-
 .../processors/cache/CacheMetricsManageTest.java   |   3 -
 .../processors/cache/CacheNamesSelfTest.java       |   3 -
 .../cache/CacheNamesWithSpecialCharactersTest.java |   3 -
 .../cache/CacheNearReaderUpdateTest.java           |  13 +-
 .../CacheNearUpdateTopologyChangeAbstractTest.java |   3 -
 .../cache/CacheNoAffinityExchangeTest.java         |   3 -
 .../cache/CacheOffheapMapEntrySelfTest.java        |   3 -
 .../CacheOptimisticTransactionsWithFilterTest.java |   3 -
 .../cache/CachePutEventListenerErrorSelfTest.java  |   7 +-
 .../processors/cache/CachePutIfAbsentTest.java     |   3 -
 .../CacheReadThroughLocalRestartSelfTest.java      |  16 +-
 .../cache/CacheReadThroughRestartSelfTest.java     |  13 +-
 .../cache/CacheRebalanceConfigValidationTest.java  |   3 -
 .../processors/cache/CacheRebalancingSelfTest.java |   3 -
 .../processors/cache/CacheRemoveAllSelfTest.java   |   3 -
 .../cache/CacheSerializableTransactionsTest.java   |   3 -
 .../cache/CacheStartupInDeploymentModesTest.java   |   3 -
 .../cache/CacheStopAndDestroySelfTest.java         |  15 +-
 ...toreUsageMultinodeDynamicStartAbstractTest.java |   3 -
 ...CacheStoreUsageMultinodeDynamicStartTxTest.java |  12 +-
 ...StoreUsageMultinodeStaticStartAbstractTest.java |   3 -
 .../CacheStoreUsageMultinodeStaticStartTxTest.java |  12 +-
 .../processors/cache/CacheTxFastFinishTest.java    |   3 -
 .../cache/CacheTxNotAllowReadFromBackupTest.java   |   3 -
 .../cache/CacheValidatorMetricsTest.java           |   3 -
 .../processors/cache/ClusterReadOnlyModeTest.java  |   3 -
 .../processors/cache/ClusterStateAbstractTest.java |   3 -
 .../processors/cache/ConcurrentCacheStartTest.java |   3 -
 .../processors/cache/CrossCacheLockTest.java       |  13 +-
 .../cache/CrossCacheTxRandomOperationsTest.java    |  14 +-
 .../EntryVersionConsistencyReadThroughTest.java    |   3 -
 .../GridAbstractCacheInterceptorRebalanceTest.java |   3 -
 .../cache/GridCacheAbstractFailoverSelfTest.java   |   3 -
 .../cache/GridCacheAbstractFailoverTxSelfTest.java |   3 -
 ...dCacheAbstractFullApiMultithreadedSelfTest.java |   3 -
 .../cache/GridCacheAbstractFullApiSelfTest.java    |  20 +-
 .../cache/GridCacheAbstractIteratorsSelfTest.java  |   3 -
 .../cache/GridCacheAbstractLocalStoreSelfTest.java |   3 -
 .../cache/GridCacheAbstractMetricsSelfTest.java    |   3 -
 .../cache/GridCacheAbstractRemoveFailureTest.java  |   3 -
 .../cache/GridCacheAbstractTxReadTest.java         |   3 -
 ...idCacheAbstractUsersAffinityMapperSelfTest.java |   3 -
 .../cache/GridCacheAffinityApiSelfTest.java        |   3 -
 .../cache/GridCacheAffinityMapperSelfTest.java     |   3 -
 .../cache/GridCacheAffinityRoutingSelfTest.java    |   3 -
 .../GridCacheAsyncOperationsLimitSelfTest.java     |   3 -
 ...acheAtomicEntryProcessorDeploymentSelfTest.java |  13 -
 .../cache/GridCacheAtomicMessageCountSelfTest.java |   3 -
 .../cache/GridCacheBasicApiAbstractTest.java       |   3 -
 .../cache/GridCacheBasicStoreAbstractTest.java     |  17 +-
 ...idCacheBasicStoreMultithreadedAbstractTest.java |   3 -
 .../cache/GridCacheClearAllSelfTest.java           |   3 -
 .../cache/GridCacheClearLocallySelfTest.java       |   3 -
 .../processors/cache/GridCacheClearSelfTest.java   |   3 -
 .../GridCacheConcurrentGetCacheOnClientTest.java   |   3 -
 .../cache/GridCacheConcurrentMapSelfTest.java      |   3 -
 .../GridCacheConcurrentTxMultiNodeLoadTest.java    |   3 -
 .../GridCacheConditionalDeploymentSelfTest.java    |   3 -
 .../GridCacheConfigurationConsistencySelfTest.java |   3 -
 .../GridCacheConfigurationValidationSelfTest.java  |   3 -
 .../cache/GridCacheDaemonNodeAbstractSelfTest.java |   3 -
 .../cache/GridCacheDeploymentSelfTest.java         |   3 -
 .../cache/GridCacheEntryMemorySizeSelfTest.java    |   3 -
 .../cache/GridCacheEntryVersionSelfTest.java       |   3 -
 .../cache/GridCacheEvictionEventAbstractTest.java  |  18 +-
 .../cache/GridCacheFinishPartitionsSelfTest.java   |  13 +-
 ...ridCacheFullTextQueryMultithreadedSelfTest.java |   3 -
 .../GridCacheGetAndTransformStoreAbstractTest.java |  21 +-
 .../cache/GridCacheIncrementTransformTest.java     |   3 -
 .../GridCacheInterceptorAbstractSelfTest.java      |  36 +-
 .../cache/GridCacheInterceptorLocalSelfTest.java   |  14 +-
 ...GridCacheInterceptorLocalWithStoreSelfTest.java |  14 +-
 .../cache/GridCacheIteratorPerformanceTest.java    |   3 -
 .../cache/GridCacheKeyCheckSelfTest.java           |   3 -
 .../processors/cache/GridCacheLeakTest.java        |   3 -
 .../cache/GridCacheLifecycleAwareSelfTest.java     |   3 -
 .../GridCacheLocalTxStoreExceptionSelfTest.java    |   4 +-
 .../cache/GridCacheMarshallerTxAbstractTest.java   |   3 -
 .../GridCacheMarshallingNodeJoinSelfTest.java      |  17 +-
 .../GridCacheMissingCommitVersionSelfTest.java     |   3 -
 .../GridCacheMixedPartitionExchangeSelfTest.java   |   3 -
 .../cache/GridCacheMultiUpdateLockSelfTest.java    |   3 -
 .../GridCacheMultinodeUpdateAbstractSelfTest.java  |   3 -
 ...ultinodeUpdateNearEnabledNoBackupsSelfTest.java |   3 -
 ...ridCacheMultinodeUpdateNearEnabledSelfTest.java |  13 +-
 .../processors/cache/GridCacheMvccFlagsTest.java   |   3 -
 .../cache/GridCacheMvccManagerSelfTest.java        |   3 -
 .../cache/GridCacheMvccPartitionedSelfTest.java    |   3 -
 .../processors/cache/GridCacheMvccSelfTest.java    |   3 -
 .../cache/GridCacheNestedTxAbstractTest.java       |   3 -
 .../cache/GridCacheObjectToStringSelfTest.java     |   7 +-
 ...OffHeapMultiThreadedUpdateAbstractSelfTest.java |   3 -
 ...ridCacheOffHeapMultiThreadedUpdateSelfTest.java |   3 -
 .../cache/GridCacheOffheapUpdateSelfTest.java      |   3 -
 .../cache/GridCacheOnCopyFlagAbstractSelfTest.java |   3 -
 .../cache/GridCacheOrderedPreloadingSelfTest.java  |   3 -
 .../cache/GridCacheP2PUndeploySelfTest.java        |   3 -
 .../cache/GridCachePartitionedGetSelfTest.java     |   3 -
 ...CachePartitionedProjectionAffinitySelfTest.java |   3 -
 .../cache/GridCachePartitionedWritesTest.java      |   3 -
 .../GridCachePreloadingEvictionsSelfTest.java      |   3 -
 .../cache/GridCachePutAllFailoverSelfTest.java     |   3 -
 .../GridCacheQueryIndexingDisabledSelfTest.java    |   3 -
 .../cache/GridCacheQueryInternalKeysSelfTest.java  |   3 -
 .../GridCacheQuerySqlFieldInlineSizeSelfTest.java  |   3 -
 .../cache/GridCacheReferenceCleanupSelfTest.java   |   3 -
 .../processors/cache/GridCacheReloadSelfTest.java  |  34 +-
 .../GridCacheReplicatedSynchronousCommitTest.java  |   3 -
 .../GridCacheReturnValueTransferSelfTest.java      |   3 -
 .../processors/cache/GridCacheSlowTxWarnTest.java  |   3 -
 .../processors/cache/GridCacheStopSelfTest.java    |   3 -
 .../GridCacheStoreManagerDeserializationTest.java  |  15 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java    |   3 -
 ...idCacheTcpClientDiscoveryMultiThreadedTest.java |   3 -
 .../processors/cache/GridCacheTestEntryEx.java     |   5 +-
 ...dCacheTransactionalAbstractMetricsSelfTest.java |   3 -
 .../cache/GridCacheTtlManagerEvictionSelfTest.java |   3 -
 .../cache/GridCacheTtlManagerLoadTest.java         |   3 -
 .../cache/GridCacheTtlManagerNotificationTest.java |   3 -
 .../cache/GridCacheTtlManagerSelfTest.java         |   7 +-
 .../GridCacheTxPartitionedLocalStoreSelfTest.java  |   6 +-
 .../processors/cache/GridCacheUtilsSelfTest.java   |   3 -
 .../GridCacheValueBytesPreloadingSelfTest.java     |   3 -
 .../GridCacheValueConsistencyAbstractSelfTest.java |   3 -
 .../cache/GridCacheVariableTopologySelfTest.java   |   3 -
 .../cache/GridCacheVersionMultinodeTest.java       |   3 -
 .../processors/cache/GridCacheVersionSelfTest.java |   3 -
 .../cache/GridCacheVersionTopologyChangeTest.java  |   3 -
 ...ataStorageConfigurationConsistencySelfTest.java |   3 -
 .../cache/GridEvictionPolicyMBeansTest.java        |   5 +-
 ...dLocalCacheStoreManagerDeserializationTest.java |   3 -
 .../cache/GridLocalIgniteSerializationTest.java    |   3 -
 ...ridProjectionForCachesOnDaemonNodeSelfTest.java |   3 -
 .../IgniteAbstractDynamicCacheStartFailTest.java   |   3 -
 .../cache/IgniteCacheAbstractStopBusySelfTest.java |   3 -
 .../cache/IgniteCacheAtomicStopBusySelfTest.java   |   3 -
 .../IgniteCacheBinaryEntryProcessorSelfTest.java   |   3 -
 .../IgniteCacheBinaryObjectsScanSelfTest.java      |   3 -
 .../IgniteCacheConfigVariationsFullApiTest.java    |   3 -
 ...gniteCacheConfigurationDefaultTemplateTest.java |   3 -
 .../IgniteCacheConfigurationTemplateTest.java      |   3 -
 .../IgniteCacheContainsKeyAbstractSelfTest.java    |   3 -
 .../cache/IgniteCacheContainsKeyAtomicTest.java    |   3 -
 .../IgniteCacheCopyOnReadDisabledAbstractTest.java |   3 -
 .../cache/IgniteCacheCreateRestartSelfTest.java    |   3 -
 .../cache/IgniteCacheDynamicStopSelfTest.java      |   3 -
 .../IgniteCacheEntryListenerAbstractTest.java      |   7 +-
 ...niteCacheEntryListenerEagerTtlDisabledTest.java |   4 +-
 .../IgniteCacheEntryListenerExpiredEventsTest.java |   3 -
 .../cache/IgniteCacheEntryListenerTxLocalTest.java |   4 +-
 .../cache/IgniteCacheEntryProcessorCallTest.java   |   3 -
 .../IgniteCacheEntryProcessorNodeJoinTest.java     |   3 -
 .../IgniteCacheExpireAndUpdateConsistencyTest.java |   3 -
 .../IgniteCacheGetCustomCollectionsSelfTest.java   |   3 -
 .../processors/cache/IgniteCacheGroupsTest.java    |   4 -
 .../cache/IgniteCacheIncrementTxTest.java          |   3 -
 .../cache/IgniteCacheInvokeAbstractTest.java       |   3 -
 ...IgniteCacheInvokeReadThroughSingleNodeTest.java |   3 -
 .../cache/IgniteCacheInvokeReadThroughTest.java    |   3 -
 .../IgniteCacheLoadRebalanceEvictionSelfTest.java  |   3 -
 .../cache/IgniteCacheManyAsyncOperationsTest.java  |   3 -
 .../cache/IgniteCacheNearLockValueSelfTest.java    |   7 +-
 .../cache/IgniteCacheNoSyncForGetTest.java         |   3 -
 .../cache/IgniteCacheObjectPutSelfTest.java        |   3 -
 .../IgniteCacheP2pUnmarshallingErrorTest.java      |   3 -
 .../IgniteCacheP2pUnmarshallingNearErrorTest.java  |   3 -
 ...iteCacheP2pUnmarshallingRebalanceErrorTest.java |   3 -
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java    |   3 -
 .../cache/IgniteCachePartitionMapUpdateTest.java   |   3 -
 .../cache/IgniteCachePeekModesAbstractTest.java    |   3 -
 .../cache/IgniteCachePutAllRestartTest.java        |   3 -
 .../cache/IgniteCachePutStackOverflowSelfTest.java |   3 -
 .../IgniteCacheReadThroughEvictionSelfTest.java    |   3 -
 .../cache/IgniteCacheReadThroughStoreCallTest.java |  13 +-
 ...IgniteCacheScanPredicateDeploymentSelfTest.java |   3 -
 .../cache/IgniteCacheSerializationSelfTest.java    |   3 -
 .../cache/IgniteCacheStartStopLoadTest.java        |   3 -
 .../processors/cache/IgniteCacheStartTest.java     |   3 -
 .../cache/IgniteCacheStoreCollectionTest.java      |   3 -
 .../cache/IgniteCacheStoreValueAbstractTest.java   |   3 -
 .../IgniteCacheTransactionalStopBusySelfTest.java  |   3 -
 .../cache/IgniteCacheTxCopyOnReadDisabledTest.java |  10 +-
 .../cache/IgniteCacheTxLocalInvokeTest.java        |   4 +-
 .../cache/IgniteCacheTxLocalPeekModesTest.java     |  14 +-
 .../cache/IgniteCacheTxLocalStoreValueTest.java    |  10 +-
 .../IgniteCacheTxNearEnabledStoreValueTest.java    |  10 +-
 .../cache/IgniteCacheTxNearPeekModesTest.java      |  13 +-
 .../cache/IgniteCacheTxPreloadNoWriteTest.java     |   3 -
 .../cache/IgniteCacheTxStoreValueTest.java         |  10 +-
 .../cache/IgniteCachingProviderSelfTest.java       |   3 -
 .../IgniteClientAffinityAssignmentSelfTest.java    |   3 -
 .../IgniteClientCacheInitializationFailTest.java   |   3 -
 .../cache/IgniteClientCacheStartFailoverTest.java  |   3 -
 .../cache/IgniteClusterActivateDeactivateTest.java |   3 -
 ...usterActivateDeactivateTestWithPersistence.java |  13 -
 ...eactivateTestWithPersistenceAndMemoryReuse.java |  27 --
 .../cache/IgniteDaemonNodeMarshallerCacheTest.java |   3 -
 ...gniteDiscoveryDataHandlingInNewClusterTest.java |   3 -
 .../cache/IgniteDynamicCacheAndNodeStop.java       |   3 -
 .../cache/IgniteDynamicCacheFilterTest.java        |   3 -
 .../cache/IgniteDynamicCacheMultinodeTest.java     |   3 -
 ...teDynamicCacheStartCoordinatorFailoverTest.java |   3 -
 ...niteDynamicCacheStartNoExchangeTimeoutTest.java |   3 -
 .../cache/IgniteDynamicCacheStartSelfTest.java     |   3 -
 .../IgniteDynamicCacheStartStopConcurrentTest.java |   3 -
 .../IgniteDynamicCacheWithConfigStartSelfTest.java |   3 -
 .../IgniteDynamicClientCacheStartSelfTest.java     |   3 -
 .../cache/IgniteExchangeFutureHistoryTest.java     |   3 -
 .../IgniteGetNonPlainKeyReadThroughSelfTest.java   |   3 -
 .../cache/IgniteIncompleteCacheObjectSelfTest.java |   3 -
 .../cache/IgniteInternalCacheTypesTest.java        |   3 -
 ...IgniteMarshallerCacheClassNameConflictTest.java |   3 -
 ...hallerCacheClientRequestsMappingOnMissTest.java |   3 -
 ...niteMarshallerCacheConcurrentReadWriteTest.java |   3 -
 .../cache/IgniteMarshallerCacheFSRestoreTest.java  |   3 -
 .../IgniteMvccTxMultiThreadedAbstractTest.java     |   3 -
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |   3 -
 .../cache/IgniteNearClientCacheCloseTest.java      |   3 -
 .../cache/IgniteOnePhaseCommitInvokeTest.java      |   3 -
 .../cache/IgniteOnePhaseCommitNearReadersTest.java |   3 -
 .../cache/IgniteOnePhaseCommitNearSelfTest.java    |   3 -
 .../cache/IgniteOutOfMemoryPropagationTest.java    |   3 -
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |   3 -
 .../cache/IgnitePutAllLargeBatchSelfTest.java      |   7 +-
 ...ePutAllUpdateNonPreloadedPartitionSelfTest.java |   7 +-
 .../IgniteStartCacheInTransactionSelfTest.java     |   5 +-
 .../cache/IgniteStaticCacheStartSelfTest.java      |   3 -
 .../cache/IgniteSystemCacheOnClientTest.java       |   3 -
 .../IgniteTopologyValidatorAbstractCacheTest.java  |   3 -
 ...TopologyValidatorAbstractTxCacheGroupsTest.java |   3 -
 ...IgniteTopologyValidatorAbstractTxCacheTest.java |   3 -
 ...teTopologyValidatorCacheGroupsAbstractTest.java |   3 -
 .../IgniteTopologyValidatorGridSplitCacheTest.java |   3 -
 ...yValidatorNearPartitionedTxCacheGroupsTest.java |   4 +-
 ...opologyValidatorNearPartitionedTxCacheTest.java |   4 +-
 .../cache/IgniteTxConcurrentGetAbstractTest.java   |   3 -
 .../cache/IgniteTxConfigCacheSelfTest.java         |   3 -
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |   9 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java       |   3 -
 .../cache/IgniteTxMultiThreadedAbstractTest.java   |   3 -
 .../cache/IgniteTxReentryAbstractSelfTest.java     |   3 -
 .../cache/IgniteTxSingleThreadedAbstractTest.java  |   3 -
 .../IgniteTxStoreExceptionAbstractSelfTest.java    |   7 +-
 ...nterceptorCacheConfigVariationsFullApiTest.java |   3 -
 .../MarshallerCacheJobRunNodeRestartTest.java      |   3 -
 .../cache/MemoryPolicyConfigValidationTest.java    |   3 -
 ...NonAffinityCoordinatorDynamicStartStopTest.java |   3 -
 ...OffheapCacheMetricsForClusterGroupSelfTest.java |   3 -
 .../PartitionsExchangeCoordinatorFailoverTest.java |   3 -
 ...ionsExchangeOnDiscoveryHistoryOverflowTest.java |   3 -
 .../SetTxTimeoutOnPartitionMapExchangeTest.java    |   3 -
 .../cache/WalModeChangeAbstractSelfTest.java       |   3 -
 .../cache/WalModeChangeAdvancedSelfTest.java       |   3 -
 .../cache/WithKeepBinaryCacheFullApiTest.java      |   3 -
 .../binary/BinaryMetadataUpdatesFlowTest.java      |   3 -
 .../binary/BinaryTxCacheLocalEntriesSelfTest.java  |   3 -
 .../binary/CacheKeepBinaryWithInterceptorTest.java |   3 -
 ...naryAtomicEntryProcessorDeploymentSelfTest.java |   9 +-
 ...eBinaryObjectMetadataExchangeMultinodeTest.java |   3 -
 ...idCacheBinaryObjectUserClassloaderSelfTest.java |   3 -
 ...eBinaryObjectsAbstractDataStreamerSelfTest.java |   3 -
 ...BinaryObjectsAbstractMultiThreadedSelfTest.java |   3 -
 .../GridCacheBinaryObjectsAbstractSelfTest.java    |   3 -
 .../GridCacheBinaryStoreAbstractSelfTest.java      |   3 -
 ...lientNodeBinaryObjectMetadataMultinodeTest.java |   3 -
 ...ridCacheClientNodeBinaryObjectMetadataTest.java |   3 -
 .../GridDataStreamerImplSelfTest.java              |   3 -
 .../IgniteCacheAbstractExecutionContextTest.java   |   3 -
 ...acheAbstractDataStructuresFailoverSelfTest.java |   3 -
 ...stractQueueFailoverDataConsistencySelfTest.java |   3 -
 ...ridCacheAtomicReferenceApiSelfAbstractTest.java |   3 -
 ...dCacheAtomicReferenceMultiNodeAbstractTest.java |   3 -
 .../GridCacheAtomicStampedApiSelfAbstractTest.java |   3 -
 .../GridCacheQueueApiSelfAbstractTest.java         |   3 -
 .../GridCacheQueueCleanupSelfTest.java             |   3 -
 .../GridCacheQueueClientDisconnectTest.java        |   3 -
 .../GridCacheQueueJoinedNodeSelfAbstractTest.java  |   3 -
 .../GridCacheQueueMultiNodeAbstractSelfTest.java   |   3 -
 ...GridCacheQueueMultiNodeConsistencySelfTest.java |   3 -
 ...ridCacheQueueRotativeMultiNodeAbstractTest.java |   3 -
 .../GridCacheSequenceApiSelfAbstractTest.java      |   3 -
 ...GridCacheSequenceMultiNodeAbstractSelfTest.java |   3 -
 .../GridCacheSetAbstractSelfTest.java              |   3 -
 .../GridCacheSetFailoverAbstractSelfTest.java      |   3 -
 .../IgniteAtomicLongApiAbstractSelfTest.java       |   3 -
 .../IgniteClientDataStructuresAbstractTest.java    |   3 -
 .../IgniteCountDownLatchAbstractSelfTest.java      |   3 -
 .../IgniteDataStructureUniqueNameTest.java         |   3 -
 .../IgniteDataStructureWithJobTest.java            |   3 -
 ...iteExchangeLatchManagerCoordinatorFailTest.java |   3 -
 .../datastructures/IgniteLockAbstractSelfTest.java |   3 -
 .../IgniteSemaphoreAbstractSelfTest.java           |   3 -
 .../IgniteSequenceInternalCleanupTest.java         |   3 -
 .../SemaphoreFailoverNoWaitingAcquirerTest.java    |   3 -
 .../SemaphoreFailoverSafeReleasePermitsTest.java   |   3 -
 .../local/IgniteLocalCountDownLatchSelfTest.java   |   3 -
 .../local/IgniteLocalLockSelfTest.java             |   3 -
 .../local/IgniteLocalSemaphoreSelfTest.java        |   3 -
 ...PartitionedAtomicSequenceMultiThreadedTest.java |   3 -
 ...idCachePartitionedAtomicSequenceTxSelfTest.java |   3 -
 ...dCachePartitionedAtomicSetFailoverSelfTest.java |   3 -
 .../GridCachePartitionedNodeRestartTxSelfTest.java |   3 -
 ...chePartitionedQueueCreateMultiNodeSelfTest.java |   3 -
 ...GridCachePartitionedQueueEntryMoveSelfTest.java |   3 -
 .../GridCachePartitionedSetFailoverSelfTest.java   |   3 -
 .../IgnitePartitionedQueueNoBackupsTest.java       |   3 -
 .../IgnitePartitionedSetNoBackupsSelfTest.java     |   3 -
 .../cache/distributed/Cache64kPartitionsTest.java  |   3 -
 .../distributed/CacheAbstractRestartSelfTest.java  |   3 -
 .../cache/distributed/CacheAffinityEarlyTest.java  |   3 -
 .../CacheAsyncOperationsFailoverAbstractTest.java  |   3 -
 .../distributed/CacheAsyncOperationsTest.java      |   3 -
 .../CacheAtomicPrimarySyncBackPressureTest.java    |   3 -
 .../distributed/CacheBaselineTopologyTest.java     |   3 -
 .../cache/distributed/CacheBlockOnGetAllTest.java  |   3 -
 .../distributed/CacheBlockOnReadAbstractTest.java  |   3 -
 .../cache/distributed/CacheBlockOnScanTest.java    |   3 -
 .../distributed/CacheBlockOnSingleGetTest.java     |   3 -
 .../CacheClientsConcurrentStartTest.java           |   3 -
 .../CacheDataLossOnPartitionMoveTest.java          |   3 -
 .../CacheDiscoveryDataConcurrentJoinTest.java      |   3 -
 .../cache/distributed/CacheExchangeMergeTest.java  |   3 -
 .../distributed/CacheGetFutureHangsSelfTest.java   |   3 -
 .../CacheGetInsideLockChangingTopologyTest.java    |   3 -
 .../cache/distributed/CacheGroupsPreloadTest.java  |   3 -
 ...teAffinityAssignmentNodeJoinValidationTest.java |   3 -
 .../CacheLateAffinityAssignmentTest.java           |   3 -
 .../CacheLoadingConcurrentGridStartSelfTest.java   |   3 -
 .../distributed/CacheLockReleaseNodeLeaveTest.java |   3 -
 .../distributed/CacheOperationsInterruptTest.java  |   3 -
 .../distributed/CachePageWriteLockUnlockTest.java  |   3 -
 .../cache/distributed/CacheParallelStartTest.java  |   3 -
 .../cache/distributed/CachePartitionStateTest.java |   3 -
 .../CachePutAllFailoverAbstractTest.java           |   3 -
 .../distributed/CacheRentingStateRepairTest.java   |   3 -
 .../CacheResultIsNotNullOnPartitionLossTest.java   |   3 -
 .../cache/distributed/CacheStartOnJoinTest.java    |   3 -
 .../distributed/CacheTryLockMultithreadedTest.java |   3 -
 .../CacheTxNearUpdateTopologyChangeTest.java       |   4 +-
 ...AbstractDistributedByteArrayValuesSelfTest.java |   3 -
 .../GridCacheAbstractJobExecutionTest.java         |   3 -
 .../GridCacheAbstractNodeRestartSelfTest.java      |   3 -
 .../GridCacheAbstractPrimarySyncSelfTest.java      |   3 -
 .../distributed/GridCacheBasicOpAbstractTest.java  |   3 -
 .../GridCacheClientModesAbstractSelfTest.java      |  20 +-
 .../GridCacheEntrySetAbstractSelfTest.java         |   3 -
 ...idCacheEntrySetIterationPreloadingSelfTest.java |   3 -
 .../distributed/GridCacheEventAbstractTest.java    |  20 +-
 .../distributed/GridCacheLockAbstractTest.java     |  15 +-
 .../distributed/GridCacheMixedModeSelfTest.java    |   3 -
 .../GridCacheMultiNodeAbstractTest.java            |   3 -
 .../GridCacheMultiNodeLockAbstractTest.java        |   3 -
 ...GridCacheMultithreadedFailoverAbstractTest.java |   3 -
 .../GridCacheNodeFailureAbstractTest.java          |   3 -
 ...PartitionEvictionDuringReadThroughSelfTest.java |   3 -
 .../GridCachePartitionNotLoadedEventSelfTest.java  |   3 -
 ...dCachePartitionedReloadAllAbstractSelfTest.java |   7 +-
 .../GridCachePreloadEventsAbstractSelfTest.java    |   3 -
 .../GridCachePreloadRestartAbstractSelfTest.java   |   3 -
 .../GridCacheTransformEventSelfTest.java           |   3 -
 ...naryMetadataUpdateChangingTopologySelfTest.java |   3 -
 .../IgniteBinaryMetadataUpdateNodeRestartTest.java |   3 -
 .../distributed/IgniteCache150ClientsTest.java     |   3 -
 .../IgniteCacheAtomicNodeRestartTest.java          |   3 -
 ...CacheClientMultiNodeUpdateTopologyLockTest.java |   3 -
 .../IgniteCacheClientNodeChangingTopologyTest.java |   3 -
 .../IgniteCacheClientNodeConcurrentStart.java      |   3 -
 ...gniteCacheClientNodePartitionsExchangeTest.java |   3 -
 .../IgniteCacheClientReconnectTest.java            |   3 -
 .../IgniteCacheConnectionRecoveryTest.java         |   3 -
 .../IgniteCacheCreatePutMultiNodeSelfTest.java     |   3 -
 .../distributed/IgniteCacheCreatePutTest.java      |   3 -
 .../IgniteCacheFailedUpdateResponseTest.java       |   3 -
 .../distributed/IgniteCacheGetRestartTest.java     |   3 -
 ...niteCacheGroupsPartitionLossPolicySelfTest.java |   3 -
 .../distributed/IgniteCacheManyClientsTest.java    |   3 -
 .../IgniteCacheMessageRecoveryAbstractTest.java    |   3 -
 ...niteCacheMessageRecoveryIdleConnectionTest.java |   3 -
 .../IgniteCacheMessageWriteTimeoutTest.java        |   3 -
 .../IgniteCacheNearRestartRollbackSelfTest.java    |   3 -
 .../IgniteCacheNodeJoinAbstractTest.java           |   3 -
 .../IgniteCachePartitionLossPolicySelfTest.java    |  13 +-
 .../distributed/IgniteCachePrimarySyncTest.java    |   7 -
 .../IgniteCachePutGetRestartAbstractTest.java      |   3 -
 .../distributed/IgniteCacheReadFromBackupTest.java |   3 -
 .../IgniteCacheServerNodeConcurrentStart.java      |   3 -
 .../IgniteCacheSingleGetMessageTest.java           |   3 -
 .../distributed/IgniteCacheSizeFailoverTest.java   |   3 -
 .../IgniteCacheSystemTransactionsSelfTest.java     |   3 -
 .../distributed/IgniteCacheThreadLocalTxTest.java  |   3 -
 .../distributed/IgniteCacheTxIteratorSelfTest.java |   3 -
 .../IgniteCrossCacheTxStoreSelfTest.java           |   7 +-
 .../IgniteMvccTxTimeoutAbstractTest.java           |   3 -
 .../IgniteOptimisticTxSuspendResumeTest.java       |   3 -
 .../IgnitePessimisticTxSuspendResumeTest.java      |   3 -
 .../IgniteRejectConnectOnNodeStopTest.java         |   3 -
 .../distributed/IgniteTxCachePrimarySyncTest.java  |   3 -
 ...WriteSynchronizationModesMultithreadedTest.java |   3 -
 .../IgniteTxConcurrentRemoveObjectsTest.java       |   3 -
 ...IgniteTxConsistencyRestartAbstractSelfTest.java |   3 -
 .../distributed/IgniteTxGetAfterStopTest.java      |   3 -
 ...teTxOriginatingNodeFailureAbstractSelfTest.java |   3 -
 ...sticOriginatingNodeFailureAbstractSelfTest.java |   3 -
 .../distributed/IgniteTxPreloadAbstractTest.java   |   3 -
 .../IgniteTxRemoveTimeoutObjectsTest.java          |   3 -
 .../distributed/IgniteTxTimeoutAbstractTest.java   |   3 -
 .../dht/CacheGetReadFromBackupFailoverTest.java    |   3 -
 .../CachePartitionPartialCountersMapSelfTest.java  |   3 -
 ...ractPartitionedOnlyByteArrayValuesSelfTest.java |   3 -
 ...CacheAbstractTransformWriteThroughSelfTest.java |  16 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java        |   3 -
 .../dht/GridCacheAtomicNearCacheSelfTest.java      |   3 -
 .../dht/GridCacheColocatedDebugTest.java           |   3 -
 ...acheColocatedOptimisticTransactionSelfTest.java |   3 -
 .../dht/GridCacheColocatedTxExceptionSelfTest.java |  60 ++-
 .../distributed/dht/GridCacheDhtEntrySelfTest.java |   3 -
 .../GridCacheDhtEvictionNearReadersSelfTest.java   |   3 -
 .../dht/GridCacheDhtEvictionsDisabledSelfTest.java |   3 -
 .../dht/GridCacheDhtMappingSelfTest.java           |   3 -
 .../dht/GridCacheDhtMultiBackupTest.java           |   3 -
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java    |   3 -
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java    |   3 -
 .../dht/GridCacheDhtPreloadDisabledSelfTest.java   |   3 -
 .../dht/GridCacheDhtPreloadMessageCountTest.java   |   3 -
 .../GridCacheDhtPreloadMultiThreadedSelfTest.java  |   3 -
 .../dht/GridCacheDhtPreloadPerformanceTest.java    |   3 -
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |   3 -
 .../dht/GridCacheDhtPreloadSelfTest.java           |   3 -
 .../dht/GridCacheDhtPreloadStartStopSelfTest.java  |   3 -
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java     |   3 -
 .../distributed/dht/GridCacheGlobalLoadTest.java   |   5 +-
 ...idCachePartitionedNearDisabledLockSelfTest.java |   3 -
 ...achePartitionedNearDisabledMetricsSelfTest.java |   3 -
 ...GridCachePartitionedTopologyChangeSelfTest.java |   3 -
 ...artitionedTxOriginatingNodeFailureSelfTest.java |   3 -
 .../GridCachePartitionedUnloadEventsSelfTest.java  |   3 -
 .../GridCachePartitionsStateValidationTest.java    |   3 -
 .../GridCachePartitionsStateValidatorSelfTest.java |   3 -
 .../dht/GridCacheTxNodeFailureSelfTest.java        |   3 -
 .../IgniteAtomicLongChangingTopologySelfTest.java  |   3 -
 .../dht/IgniteCacheClearDuringRebalanceTest.java   |   3 -
 .../dht/IgniteCacheCommitDelayTxRecoveryTest.java  |   3 -
 .../dht/IgniteCacheConcurrentPutGetRemove.java     |   3 -
 .../dht/IgniteCacheCrossCacheTxFailoverTest.java   |   3 -
 .../dht/IgniteCacheLockFailoverSelfTest.java       |  13 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java        |  13 +-
 ...hePartitionedBackupNodeFailureRecoveryTest.java |   3 -
 ...achePrimaryNodeFailureRecoveryAbstractTest.java |   3 -
 .../dht/IgniteCachePutRetryAbstractSelfTest.java   |   3 -
 .../dht/IgniteCachePutRetryAtomicSelfTest.java     |   3 -
 .../IgniteCachePutRetryTransactionalSelfTest.java  |   3 -
 .../dht/IgniteCacheStartWithLoadTest.java          |   3 -
 .../dht/IgniteCacheTxRecoveryRollbackTest.java     |   3 -
 .../dht/IgniteCrossCacheMvccTxSelfTest.java        |   3 -
 .../dht/IgniteCrossCacheTxSelfTest.java            |   3 -
 .../dht/NotMappedPartitionInTxTest.java            |  17 +-
 .../dht/TxRecoveryStoreEnabledTest.java            |   3 -
 .../atomic/AtomicPutAllChangingTopologyTest.java   |   3 -
 ...acheAtomicInvalidPartitionHandlingSelfTest.java |   3 -
 .../dht/atomic/GridCacheAtomicPreloadSelfTest.java |   3 -
 .../dht/atomic/IgniteCacheAtomicProtocolTest.java  |   3 -
 ...heAtomicClientOnlyMultiNodeFullApiSelfTest.java |   3 -
 ...acheAtomicNearOnlyMultiNodeFullApiSelfTest.java |   3 -
 ...cheAtomicPartitionedTckMetricsSelfTestImpl.java |   3 -
 .../near/GridCacheGetStoreErrorSelfTest.java       |   7 +-
 .../near/GridCacheNearAtomicMetricsSelfTest.java   |   3 -
 .../near/GridCacheNearClientHitTest.java           |   3 -
 .../near/GridCacheNearEvictionSelfTest.java        |   3 -
 .../near/GridCacheNearMetricsSelfTest.java         |   3 -
 .../near/GridCacheNearMultiGetSelfTest.java        |   3 -
 .../near/GridCacheNearMultiNodeSelfTest.java       |  25 +-
 .../near/GridCacheNearOneNodeSelfTest.java         |  15 +-
 .../GridCacheNearOnlyMultiNodeFullApiSelfTest.java |   3 -
 .../near/GridCacheNearOnlySelfTest.java            |   3 -
 .../near/GridCacheNearOnlyTopologySelfTest.java    |   3 -
 .../GridCacheNearPartitionedClearSelfTest.java     |   3 -
 .../near/GridCacheNearReaderPreloadSelfTest.java   |   3 -
 .../near/GridCacheNearReadersSelfTest.java         |   3 -
 .../near/GridCacheNearTxExceptionSelfTest.java     |   4 +-
 .../near/GridCacheNearTxForceKeyTest.java          |   3 -
 .../near/GridCacheNearTxMultiNodeSelfTest.java     |   3 -
 .../near/GridCacheNearTxPreloadSelfTest.java       |  10 +-
 ...nedAffinityExcludeNeighborsPerformanceTest.java |   3 -
 .../near/GridCachePartitionedAffinitySelfTest.java |   3 -
 .../near/GridCachePartitionedBasicOpSelfTest.java  |   3 -
 ...achePartitionedBasicStoreMultiNodeSelfTest.java |  21 +-
 ...titionedClientOnlyNoPrimaryFullApiSelfTest.java |   3 -
 .../near/GridCachePartitionedEvictionSelfTest.java |   3 -
 ...PartitionedExplicitLockNodeFailureSelfTest.java |   3 -
 .../GridCachePartitionedFilteredPutSelfTest.java   |   3 -
 .../GridCachePartitionedHitsAndMissesSelfTest.java |   3 -
 .../GridCachePartitionedLoadCacheSelfTest.java     |   3 -
 .../near/GridCachePartitionedMetricsSelfTest.java  |   6 +-
 ...idCachePartitionedMultiNodeCounterSelfTest.java |   3 -
 .../GridCachePartitionedMultiNodeLockSelfTest.java |   3 -
 ...achePartitionedMultiThreadedPutGetSelfTest.java |   3 -
 ...achePartitionedMvccTxMultiThreadedSelfTest.java |   5 +-
 .../near/GridCachePartitionedNodeRestartTest.java  |   3 -
 ...achePartitionedOptimisticTxNodeRestartTest.java |   3 -
 ...idCachePartitionedPreloadLifecycleSelfTest.java |   3 -
 .../near/GridCachePartitionedStorePutSelfTest.java |   7 +-
 .../GridCachePartitionedTxMultiNodeSelfTest.java   |   3 -
 .../GridCachePartitionedTxSalvageSelfTest.java     |   3 -
 .../near/GridCachePutArrayValueSelfTest.java       |   3 -
 .../GridCacheRendezvousAffinityClientSelfTest.java |   3 -
 .../near/GridNearCacheStoreUpdateTest.java         |   3 -
 .../near/GridPartitionedBackupLoadSelfTest.java    |   3 -
 .../near/IgniteCacheNearOnlyTxTest.java            |  13 +-
 .../near/IgniteCacheNearReadCommittedTest.java     |  13 +-
 .../near/IgniteCacheNearTxRollbackTest.java        |   3 -
 .../near/NearCacheMultithreadedUpdateTest.java     |   3 -
 .../near/NearCachePutAllMultinodeTest.java         |   3 -
 .../distributed/near/NearCacheSyncUpdateTest.java  |   3 -
 .../near/NoneRebalanceModeSelfTest.java            |   3 -
 .../rebalancing/CacheManualRebalancingTest.java    |   3 -
 ...lancingDelayedPartitionMapExchangeSelfTest.java |   3 -
 .../GridCacheRebalancingAsyncSelfTest.java         |   3 -
 .../GridCacheRebalancingCancelTest.java            |   3 -
 .../GridCacheRebalancingOrderingTest.java          |   3 -
 .../GridCacheRebalancingPartitionCountersTest.java |   3 -
 ...dCacheRebalancingPartitionDistributionTest.java |   3 -
 .../GridCacheRebalancingSyncCheckDataTest.java     |   3 -
 .../GridCacheRebalancingSyncSelfTest.java          |   3 -
 ...acheRebalancingUnmarshallingFailedSelfTest.java |   3 -
 .../GridCacheRebalancingWithAsyncClearingTest.java |   3 -
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |   3 -
 .../GridCacheReplicatedLockSelfTest.java           |   3 -
 .../GridCacheReplicatedMetricsSelfTest.java        |   6 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java    |   3 -
 .../GridCacheReplicatedTxExceptionSelfTest.java    |  60 ++-
 .../GridCacheReplicatedTxMultiNodeBasicTest.java   |   3 -
 .../GridCacheSyncReplicatedPreloadSelfTest.java    |   3 -
 .../replicated/GridReplicatedTxPreloadTest.java    |   3 -
 .../IgniteCacheSyncRebalanceModeSelfTest.java      |   3 -
 ...ridCacheReplicatedPreloadLifecycleSelfTest.java |   3 -
 .../GridCacheReplicatedPreloadSelfTest.java        |   3 -
 ...heReplicatedPreloadStartStopEventsSelfTest.java |   3 -
 .../cache/eviction/DhtAndNearEvictionTest.java     |   7 +-
 .../cache/eviction/EvictionAbstractTest.java       |   3 -
 .../EvictionPolicyFactoryAbstractTest.java         |   3 -
 ...CacheConcurrentEvictionConsistencySelfTest.java |   7 +-
 .../GridCacheConcurrentEvictionsSelfTest.java      |   7 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java     |   3 -
 .../GridCacheEmptyEntriesLocalSelfTest.java        |   3 -
 .../GridCacheEmptyEntriesPartitionedSelfTest.java  |   3 -
 .../GridCacheEvictableEntryEqualsSelfTest.java     |   3 -
 .../eviction/GridCacheEvictionFilterSelfTest.java  |   3 -
 .../GridCacheEvictionLockUnlockSelfTest.java       |  11 +-
 .../eviction/GridCacheEvictionTouchSelfTest.java   |   7 +-
 .../lru/LruEvictionPolicyFactorySelfTest.java      |   3 -
 .../eviction/lru/LruEvictionPolicySelfTest.java    |   3 -
 .../lru/LruNearEvictionPolicySelfTest.java         |   3 -
 .../lru/LruNearOnlyNearEvictionPolicySelfTest.java |   3 -
 .../eviction/paged/PageEvictionMetricTest.java     |   3 -
 .../paged/PageEvictionMultinodeAbstractTest.java   |   3 -
 .../PageEvictionPagesRecyclingAndReusingTest.java  |   3 -
 .../paged/PageEvictionReadThroughTest.java         |   3 -
 .../eviction/paged/PageEvictionTouchOrderTest.java |   3 -
 .../PageEvictionWithRebalanceAbstractTest.java     |   3 -
 .../SortedEvictionPolicyPerformanceTest.java       |   3 -
 .../IgniteCacheClientNearCacheExpiryTest.java      |   3 -
 .../IgniteCacheExpiryPolicyAbstractTest.java       |   3 -
 ...niteCacheExpiryPolicyWithStoreAbstractTest.java |   3 -
 .../expiry/IgniteCacheLargeValueExpireTest.java    |   3 -
 ...niteCacheOnlyOneTtlCleanupThreadExistsTest.java |   3 -
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java    |   3 -
 .../IgniteCacheLoadAllAbstractTest.java            |  21 +-
 .../IgniteCacheLoaderWriterAbstractTest.java       |   3 -
 ...IgniteCacheNoLoadPreviousValueAbstractTest.java |   3 -
 .../IgniteCacheNoReadThroughAbstractTest.java      |   3 -
 .../IgniteCacheNoWriteThroughAbstractTest.java     |   3 -
 .../IgniteCacheStoreNodeRestartAbstractTest.java   |   3 -
 .../IgniteCacheStoreSessionAbstractTest.java       |   3 -
 ...teCacheStoreSessionWriteBehindAbstractTest.java |   3 -
 .../integration/IgniteCacheTxLoaderWriterTest.java |  14 +-
 .../integration/IgniteCacheTxLocalLoadAllTest.java |  11 +-
 .../IgniteCacheTxLocalNoLoadPreviousValueTest.java |  14 +-
 .../IgniteCacheTxLocalNoReadThroughTest.java       |  14 +-
 .../IgniteCacheTxLocalNoWriteThroughTest.java      |  14 +-
 ...eCacheTxNearEnabledNoLoadPreviousValueTest.java |  14 +-
 ...IgniteCacheTxNearEnabledNoWriteThroughTest.java |  14 +-
 .../IgniteCacheTxNoLoadPreviousValueTest.java      |  14 +-
 .../IgniteCacheTxNoReadThroughTest.java            |  14 +-
 .../IgniteCacheTxNoWriteThroughTest.java           |  14 +-
 .../integration/IgniteCacheTxStoreSessionTest.java |  17 +-
 ...cheTxStoreSessionWriteBehindCoalescingTest.java |  16 +-
 .../IgniteCacheTxStoreSessionWriteBehindTest.java  |  14 +-
 ...GridCacheAtomicLocalTckMetricsSelfTestImpl.java |   3 -
 .../local/GridCacheLocalBasicApiSelfTest.java      |  12 +-
 .../local/GridCacheLocalBasicStoreSelfTest.java    |  14 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java     |  15 +-
 .../cache/local/GridCacheLocalEventSelfTest.java   |  17 +-
 .../local/GridCacheLocalEvictionEventSelfTest.java |  13 +-
 .../cache/local/GridCacheLocalFullApiSelfTest.java |   3 -
 ...GridCacheLocalGetAndTransformStoreSelfTest.java |  14 +-
 .../local/GridCacheLocalIsolatedNodesSelfTest.java |   3 -
 .../local/GridCacheLocalIteratorsSelfTest.java     |   4 +-
 .../cache/local/GridCacheLocalLoadAllSelfTest.java |  15 +-
 .../cache/local/GridCacheLocalLockSelfTest.java    |  21 +-
 .../cache/local/GridCacheLocalMetricsSelfTest.java |  10 +-
 .../local/GridCacheLocalMultithreadedSelfTest.java |  21 +-
 .../local/GridCacheLocalTxExceptionSelfTest.java   |   4 +-
 .../GridCacheLocalTxMultiThreadedSelfTest.java     |  10 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java    |  10 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java     |  21 +-
 ...heAtomicNearEnabledMultiJvmFullApiSelfTest.java |   3 -
 ...eReplicatedNearOnlyMultiJvmFullApiSelfTest.java |   3 -
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |   3 -
 .../CacheMvccAbstractCoordinatorFailoverTest.java  |   5 -
 .../cache/mvcc/CacheMvccAbstractFeatureTest.java   |   4 +-
 .../cache/mvcc/CacheMvccClusterRestartTest.java    |   3 -
 .../mvcc/CacheMvccConfigurationValidationTest.java |   3 -
 ...eMvccIteratorWithConcurrentTransactionTest.java |   3 -
 ...cLocalEntriesWithConcurrentTransactionTest.java |   3 -
 .../cache/mvcc/CacheMvccOperationChecksTest.java   |  13 -
 ...acheMvccPartitionedCoordinatorFailoverTest.java |   5 -
 .../mvcc/CacheMvccProcessorLazyStartTest.java      |   3 -
 .../cache/mvcc/CacheMvccProcessorTest.java         |   3 -
 .../mvcc/CacheMvccRemoteTxOnNearNodeStartTest.java |   3 -
 ...MvccScanQueryWithConcurrentTransactionTest.java |   3 -
 ...CacheMvccSizeWithConcurrentTransactionTest.java |   3 -
 .../cache/mvcc/CacheMvccTransactionsTest.java      |   5 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |   3 -
 .../processors/cache/mvcc/CacheMvccVacuumTest.java |   3 -
 .../processors/cache/mvcc/MvccCachePeekTest.java   |   3 -
 .../cache/mvcc/MvccUnsupportedTxModesTest.java     |   3 -
 .../persistence/CheckpointReadLockFailureTest.java |   3 -
 ...niteBaselineAffinityTopologyActivationTest.java |   3 -
 .../IgniteDataStorageMetricsSelfTest.java          |   3 -
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java |   3 -
 .../IgnitePdsBinarySortObjectFieldsTest.java       |   3 -
 .../IgnitePdsCacheAssignmentNodeRestartsTest.java  |   3 -
 ...CacheConfigurationFileConsistencyCheckTest.java |   3 -
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |   3 -
 .../IgnitePdsCacheRebalancingAbstractTest.java     |   3 -
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |   3 -
 .../IgnitePdsContinuousRestartTest.java            |   3 -
 .../persistence/IgnitePdsCorruptedIndexTest.java   |   3 -
 .../persistence/IgnitePdsCorruptedStoreTest.java   |   3 -
 .../persistence/IgnitePdsDestroyCacheTest.java     |   3 -
 ...gnitePdsDestroyCacheWithoutCheckpointsTest.java |   3 -
 .../persistence/IgnitePdsDynamicCacheTest.java     |   3 -
 .../IgnitePdsExchangeDuringCheckpointTest.java     |   3 -
 ...PdsMarshallerMappingRestoreOnNodeStartTest.java |   3 -
 .../IgnitePdsNoSpaceLeftOnDeviceTest.java          |   3 -
 .../cache/persistence/IgnitePdsPageSizesTest.java  |   3 -
 .../IgnitePdsPartitionFilesDestroyTest.java        |   3 -
 .../IgnitePdsPartitionsStateRecoveryTest.java      |   3 -
 .../IgnitePdsRecoveryAfterFileCorruptionTest.java  |   3 -
 .../IgnitePdsRemoveDuringRebalancingTest.java      |   3 -
 .../persistence/IgnitePdsTaskCancelingTest.java    |   3 -
 .../IgnitePdsTxCacheRebalancingTest.java           |   3 -
 .../IgnitePersistentStoreCacheGroupsTest.java      |   3 -
 .../IgnitePersistentStoreDataStructuresTest.java   |   3 -
 ...gniteRebalanceScheduleResendPartitionsTest.java |   3 -
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   3 -
 ...NoChangeDuringRebalanceOnNonNodeAssignTest.java |   3 -
 .../MemoryPolicyInitializationTest.java            |   3 -
 .../PersistenceDirectoryWarningLoggingTest.java    |   3 -
 .../ClientAffinityAssignmentWithBaselineTest.java  |   3 -
 .../IgniteAbsentEvictionNodeOutOfBaselineTest.java |   3 -
 .../db/CheckpointBufferDeadlockTest.java           |   3 -
 .../persistence/db/IgniteLogicalRecoveryTest.java  |   3 -
 .../persistence/db/IgnitePdsCacheRestoreTest.java  |   3 -
 ...IgnitePdsCacheWalDisabledOnRebalancingTest.java |   3 -
 .../db/IgnitePdsDataRegionMetricsTest.java         |   3 -
 .../db/IgnitePdsMultiNodePutGetRestartTest.java    |   3 -
 ...itePdsPageEvictionDuringPartitionClearTest.java |   3 -
 .../persistence/db/IgnitePdsPageEvictionTest.java  |   3 -
 .../db/IgnitePdsPartitionPreloadTest.java          |   3 -
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |   3 -
 .../db/IgnitePdsReserveWalSegmentsTest.java        |   3 -
 .../db/IgnitePdsTransactionsHangTest.java          |   3 -
 .../db/IgnitePdsWholeClusterRestartTest.java       |   3 -
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |   3 -
 .../persistence/db/IgnitePdsWithTtlTest2.java      |   3 -
 .../IgniteShutdownOnSupplyMessageFailureTest.java  |   7 +-
 .../SlowHistoricalRebalanceSmallHistoryTest.java   |   3 -
 .../IgniteCheckpointDirtyPagesForLowLoadTest.java  |   3 -
 .../db/checkpoint/IgniteMassLoadSandboxTest.java   |   3 -
 .../DefaultPageSizeBackwardsCompatibilityTest.java |   3 -
 .../IgnitePdsCacheDestroyDuringCheckpointTest.java |   3 -
 .../db/file/IgnitePdsCacheIntegrationTest.java     |   3 -
 .../db/file/IgnitePdsCheckpointSimpleTest.java     |   3 -
 ...CheckpointSimulationWithRealCpDisabledTest.java |   3 -
 .../db/file/IgnitePdsDiskErrorsRecoveringTest.java |   3 -
 .../db/file/IgnitePdsNoActualWalHistoryTest.java   |   3 -
 .../db/file/IgnitePdsPageReplacementTest.java      |   3 -
 .../db/file/IgnitePdsThreadInterruptionTest.java   |   3 -
 .../IgniteUidAsConsistentIdMigrationTest.java      |   3 -
 .../db/wal/FsyncWalRolloverDoesNotBlockTest.java   |   3 -
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |   3 -
 ...ailIsReachedDuringIterationOverArchiveTest.java |   3 -
 .../db/wal/IgniteWalFlushFailoverTest.java         |   3 -
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |   3 -
 .../db/wal/IgniteWalFormatFileFailoverTest.java    |   3 -
 .../db/wal/IgniteWalHistoryReservationsTest.java   |   3 -
 .../IgniteWalIteratorExceptionDuringReadTest.java  |   3 -
 .../db/wal/IgniteWalIteratorSwitchSegmentTest.java |   3 -
 .../persistence/db/wal/IgniteWalRebalanceTest.java |   3 -
 .../db/wal/IgniteWalRecoveryPPCTest.java           |   3 -
 .../wal/IgniteWalRecoverySeveralRestartsTest.java  |   3 -
 .../db/wal/IgniteWalSerializerVersionTest.java     |   3 -
 .../db/wal/WalCompactionAfterRestartTest.java      |   3 -
 .../persistence/db/wal/WalCompactionTest.java      |   3 -
 .../db/wal/WalDeletionArchiveAbstractTest.java     |   3 -
 .../cache/persistence/db/wal/WalPathsTest.java     |   3 -
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java    |   3 -
 .../db/wal/WalRolloverRecordLoggingTest.java       |   3 -
 .../persistence/db/wal/WalRolloverTypesTest.java   |   3 -
 .../IgniteAbstractWalIteratorInvalidCrcTest.java   |   3 -
 .../crc/IgniteReplayWalIteratorInvalidCrcTest.java |   3 -
 .../db/wal/reader/IgniteWalReaderTest.java         |   3 -
 .../cache/persistence/file/FileDownloaderTest.java |   3 -
 .../metastorage/IgniteMetaStorageBasicTest.java    |   3 -
 .../persistence/pagemem/FillFactorMetricTest.java  |   3 -
 .../pagemem/PageIdDistributionTest.java            |   3 -
 .../pagemem/PageMemoryImplNoLoadTest.java          |   3 -
 .../persistence/pagemem/PageMemoryImplTest.java    |   3 -
 .../pagemem/PageMemoryNoStoreLeakTest.java         |   3 -
 .../pagemem/PagesWriteThrottleSandboxTest.java     |   3 -
 .../pagemem/PagesWriteThrottleSmokeTest.java       |   3 -
 .../IgniteChangeGlobalStateCacheTest.java          |   3 -
 .../IgniteChangeGlobalStateDataStreamerTest.java   |   3 -
 .../IgniteChangeGlobalStateDataStructureTest.java  |   3 -
 .../IgniteChangeGlobalStateFailOverTest.java       |   3 -
 .../IgniteChangeGlobalStateServiceTest.java        |   3 -
 .../IgniteChangeGlobalStateTest.java               |   3 -
 .../IgniteNoParrallelClusterIsAllowedTest.java     |   3 -
 .../standbycluster/IgniteStandByClusterTest.java   |   3 -
 .../join/JoinActiveNodeToActiveCluster.java        |   3 -
 .../join/JoinActiveNodeToInActiveCluster.java      |   3 -
 .../join/JoinInActiveNodeToActiveCluster.java      |   3 -
 .../join/JoinInActiveNodeToInActiveCluster.java    |   3 -
 ...inActiveNodeToActiveClusterWithPersistence.java |   3 -
 .../IgniteStandByClientReconnectTest.java          |   3 -
 ...niteStandByClientReconnectToNewClusterTest.java |   3 -
 .../wal/CpTriggeredWalDeltaConsistencyTest.java    |   3 -
 .../wal/ExplicitWalDeltaConsistencyTest.java       |   3 -
 .../wal/SegmentedRingByteBufferTest.java           |   3 -
 .../wal/SysPropWalDeltaConsistencyTest.java        |   3 -
 .../reader/StandaloneWalRecordsIteratorTest.java   |   3 -
 .../cache/query/CacheDataPageScanQueryTest.java    |   3 -
 .../cache/query/CacheScanQueryFailoverTest.java    |   3 -
 .../query/GridCacheQueryTransformerSelfTest.java   |   3 -
 .../cache/query/GridCircularQueueTest.java         |   3 -
 .../IgniteCacheQueryCacheDestroySelfTest.java      |   3 -
 .../cache/query/IndexingSpiQuerySelfTest.java      |   3 -
 .../cache/query/IndexingSpiQueryTxSelfTest.java    |   3 -
 .../ScanQueryOffheapExpiryPolicySelfTest.java      |   3 -
 .../continuous/CacheContinuousBatchAckTest.java    |   3 -
 ...ContinuousQueryAsyncFailoverMvccTxSelfTest.java |  10 +-
 ...acheContinuousQueryAsyncFilterListenerTest.java |   3 -
 ...ntinuousQueryConcurrentPartitionUpdateTest.java |   3 -
 .../CacheContinuousQueryCounterAbstractTest.java   |   3 -
 .../CacheContinuousQueryEventBufferTest.java       |   3 -
 .../CacheContinuousQueryExecuteInPrimaryTest.java  |   3 -
 ...nuousQueryFactoryFilterRandomOperationTest.java |   3 -
 ...cheContinuousQueryFailoverAbstractSelfTest.java |   3 -
 ...CacheContinuousQueryFailoverMvccTxSelfTest.java |  10 +-
 .../CacheContinuousQueryLostPartitionTest.java     |   3 -
 ...heContinuousQueryOperationFromCallbackTest.java |   3 -
 .../CacheContinuousQueryOperationP2PTest.java      |   3 -
 .../CacheContinuousQueryOrderingEventTest.java     |   3 -
 .../CacheContinuousQueryRandomOperationsTest.java  |   3 -
 .../CacheContinuousQueryVariationsTest.java        |  10 +-
 ...CacheContinuousWithTransformerFailoverTest.java |   3 -
 ...ontinuousWithTransformerReplicatedSelfTest.java |   3 -
 ...acheEntryProcessorExternalizableFailedTest.java |   3 -
 .../CacheEntryProcessorNonSerializableTest.java    |   3 -
 .../CacheKeepBinaryIterationNearEnabledTest.java   |   3 -
 .../CacheKeepBinaryIterationStoreEnabledTest.java  |   3 -
 .../continuous/CacheKeepBinaryIterationTest.java   |   3 -
 .../ClientReconnectContinuousQueryTest.java        |   3 -
 .../continuous/ContinuousQueryMarshallerTest.java  |   3 -
 .../ContinuousQueryPeerClassLoadingTest.java       |   3 -
 .../ContinuousQueryReassignmentTest.java           |   3 -
 ...ueryRemoteFilterMissingInClassPathSelfTest.java |   3 -
 .../GridCacheContinuousQueryAbstractSelfTest.java  |   3 -
 .../GridCacheContinuousQueryAtomicSelfTest.java    |   3 -
 .../GridCacheContinuousQueryConcurrentTest.java    |   3 -
 ...acheContinuousQueryMultiNodesFilteringTest.java |   3 -
 ...GridCacheContinuousQueryNodesFilteringTest.java |   3 -
 ...acheContinuousQueryPartitionedOnlySelfTest.java |   3 -
 ...cheContinuousQueryReplicatedAtomicSelfTest.java |   3 -
 ...GridCacheContinuousQueryReplicatedSelfTest.java |   3 -
 ...acheContinuousQueryReplicatedTxOneNodeTest.java |   3 -
 .../GridCacheContinuousQueryTxSelfTest.java        |   3 -
 .../IgniteCacheContinuousQueryBackupQueueTest.java |   3 -
 ...iteCacheContinuousQueryClientReconnectTest.java |   3 -
 .../IgniteCacheContinuousQueryClientTest.java      |   3 -
 ...niteCacheContinuousQueryImmutableEntryTest.java |   3 -
 ...gniteCacheContinuousQueryNoUnsubscribeTest.java |   3 -
 .../IgniteCacheContinuousQueryReconnectTest.java   |   3 -
 .../GridCacheWriteBehindStoreAbstractTest.java     |  21 +-
 .../store/GridCacheWriteBehindStoreLocalTest.java  |  14 +-
 ...CacheWriteBehindStoreMultithreadedSelfTest.java |   3 -
 ...iteBehindStorePartitionedMultiNodeSelfTest.java |   3 -
 .../store/GridCacheWriteBehindStoreSelfTest.java   |   3 -
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java    |   3 -
 ...nteCacheClientWriteBehindStoreAbstractTest.java |  20 +-
 ...cheClientWriteBehindStoreNonCoalescingTest.java |   3 -
 .../transactions/AtomicOperationsInTxTest.java     |   3 -
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |   3 -
 ...nsactionIntegrityWithSystemWorkerDeathTest.java |   3 -
 .../TxDataConsistencyOnCommitFailureTest.java      |   3 -
 .../cache/transactions/TxDeadlockCauseTest.java    |   3 -
 .../TxDeadlockDetectionMessageMarshallingTest.java |   3 -
 .../TxDeadlockDetectionNoHangsTest.java            |   3 -
 .../transactions/TxDeadlockDetectionTest.java      |   3 -
 .../TxDeadlockDetectionUnmasrhalErrorsTest.java    |   3 -
 .../processors/cache/transactions/TxLabelTest.java |   3 -
 .../transactions/TxMultiCacheAsyncOpsTest.java     |   3 -
 .../cache/transactions/TxOnCachesStartTest.java    |   3 -
 ...xOptimisticDeadlockDetectionCrossCacheTest.java |   3 -
 .../TxOptimisticDeadlockDetectionTest.java         |   3 -
 .../TxOptimisticOnPartitionExchangeTest.java       |   3 -
 .../TxOptimisticPrepareOnUnstableTopologyTest.java |   3 -
 ...PessimisticDeadlockDetectionCrossCacheTest.java |   3 -
 .../TxPessimisticDeadlockDetectionTest.java        |   3 -
 .../cache/transactions/TxRollbackAsyncTest.java    |   3 -
 .../TxRollbackAsyncWithPersistenceTest.java        |   4 -
 .../TxRollbackOnIncorrectParamsTest.java           |   3 -
 .../TxRollbackOnTimeoutOnePhaseCommitTest.java     |   3 -
 .../transactions/TxRollbackOnTimeoutTest.java      |   3 -
 .../TxRollbackOnTopologyChangeTest.java            |   3 -
 .../cache/transactions/TxStateChangeEventTest.java |   3 -
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |   3 -
 .../version/CacheVersionedEntryAbstractTest.java   |   3 -
 ...heVersionedEntryLocalTransactionalSelfTest.java |  15 +-
 .../closure/GridClosureProcessorRemoteTest.java    |   3 -
 .../closure/GridClosureProcessorSelfTest.java      |   3 -
 .../closure/GridClosureSerializationTest.java      |   3 -
 .../cluster/GridAddressResolverSelfTest.java       |   3 -
 .../cluster/GridUpdateNotifierSelfTest.java        |   3 -
 ...ridComputeJobExecutionErrorToLogManualTest.java |   3 -
 .../IgniteComputeConfigVariationsFullApiTest.java  |   3 -
 ...ComputeCustomExecutorConfigurationSelfTest.java |   3 -
 .../IgniteComputeCustomExecutorSelfTest.java       |   3 -
 .../compute/PublicThreadpoolStarvationTest.java    |   3 -
 .../distributed/DistributedConfigurationTest.java  |   3 -
 .../continuous/GridEventConsumeSelfTest.java       |   3 -
 .../continuous/GridMessageListenSelfTest.java      |   3 -
 .../IgniteContinuousQueryMetadataUpdateTest.java   |   3 -
 .../IgniteNoCustomEventsOnNodeStart.java           |   3 -
 .../processors/database/BPlusTreeSelfTest.java     |   3 -
 .../database/CacheFreeListImplSelfTest.java        |   3 -
 .../database/DataRegionMetricsSelfTest.java        |   3 -
 .../database/IgniteDbDynamicCacheSelfTest.java     |   3 -
 .../database/IgniteDbMemoryLeakAbstractTest.java   |   3 -
 .../database/IgniteDbPutGetAbstractTest.java       |   3 -
 .../database/IgniteDbPutGetWithCacheStoreTest.java |   3 -
 .../database/IgniteDbSingleNodeTinyPutGetTest.java |   3 -
 .../processors/database/IndexStorageSelfTest.java  |   3 -
 .../database/SwapPathConstructionSelfTest.java     |   3 -
 .../DataStreamProcessorMvccSelfTest.java           |   3 -
 .../datastreamer/DataStreamProcessorSelfTest.java  |   3 -
 ...amerClientReconnectAfterClusterRestartTest.java |   3 -
 .../datastreamer/DataStreamerImplSelfTest.java     |   3 -
 .../DataStreamerMultiThreadedSelfTest.java         |   3 -
 .../DataStreamerMultinodeCreateCacheTest.java      |   3 -
 .../datastreamer/DataStreamerTimeoutTest.java      |   3 -
 .../DataStreamerUpdateAfterLoadTest.java           |   3 -
 .../IgniteDataStreamerPerformanceTest.java         |   3 -
 .../processors/igfs/IgfsAbstractSelfTest.java      |   3 -
 .../processors/igfs/IgfsAttributesSelfTest.java    |   3 -
 .../igfs/IgfsBackupFailoverSelfTest.java           |   3 -
 ...fsBlockMessageSystemPoolStarvationSelfTest.java |   3 -
 ...IgfsCachePerBlockLruEvictionPolicySelfTest.java |   3 -
 .../processors/igfs/IgfsCacheSelfTest.java         |   3 -
 .../processors/igfs/IgfsDataManagerSelfTest.java   |   3 -
 .../processors/igfs/IgfsDualAbstractSelfTest.java  |   3 -
 .../processors/igfs/IgfsFileInfoSelfTest.java      |   3 -
 .../processors/igfs/IgfsFileMapSelfTest.java       |   3 -
 .../IgfsGroupDataBlockKeyMapperHashSelfTest.java   |   3 -
 ...calSecondaryFileSystemDualAbstractSelfTest.java |   3 -
 .../IgfsLocalSecondaryFileSystemProxySelfTest.java |   3 -
 .../processors/igfs/IgfsMetaManagerSelfTest.java   |   3 -
 .../processors/igfs/IgfsMetricsSelfTest.java       |   3 -
 .../processors/igfs/IgfsModesSelfTest.java         |   3 -
 .../processors/igfs/IgfsOneClientNodeTest.java     |   3 -
 .../igfs/IgfsPrimaryMultiNodeSelfTest.java         |   3 -
 ...PrimaryRelaxedConsistencyMultiNodeSelfTest.java |   3 -
 .../processors/igfs/IgfsProcessorSelfTest.java     |   3 -
 .../igfs/IgfsProcessorValidationSelfTest.java      |   3 -
 .../IgfsSecondaryFileSystemInjectionSelfTest.java  |   3 -
 ...gerIpcEndpointRegistrationAbstractSelfTest.java |   3 -
 ...cEndpointRegistrationOnLinuxAndMacSelfTest.java |   3 -
 ...erIpcEndpointRegistrationOnWindowsSelfTest.java |   9 +-
 .../internal/processors/igfs/IgfsSizeSelfTest.java |   3 -
 .../processors/igfs/IgfsStartCacheTest.java        |   3 -
 .../processors/igfs/IgfsStreamsSelfTest.java       |   3 -
 .../internal/processors/igfs/IgfsTaskSelfTest.java |   3 -
 .../IgfsByteDelimiterRecordResolverSelfTest.java   |   3 -
 .../IgfsFixedLengthRecordResolverSelfTest.java     |   3 -
 ...IgfsNewLineDelimiterRecordResolverSelfTest.java |   3 -
 .../IgfsStringDelimiterRecordResolverSelfTest.java |   3 -
 .../GridJobMetricsProcessorLoadTest.java           |   3 -
 .../IgniteMessagingConfigVariationFullApiTest.java |   3 -
 .../DistributedMetaStoragePersistentTest.java      |   3 -
 .../metastorage/DistributedMetaStorageTest.java    |   3 -
 .../odbc/OdbcConfigurationValidationSelfTest.java  |   3 -
 .../odbc/OdbcEscapeSequenceSelfTest.java           |   3 -
 .../processors/port/GridPortProcessorSelfTest.java |   3 -
 .../cache/GridCacheCommandHandlerSelfTest.java     |   3 -
 .../handlers/log/GridLogCommandHandlerTest.java    |   3 -
 .../query/GridQueryCommandHandlerTest.java         |   3 -
 .../top/CacheTopologyCommandHandlerTest.java       |   3 -
 .../service/ClosureServiceClientsNodesTest.java    |   3 -
 .../service/GridServiceClientNodeTest.java         |   3 -
 .../GridServiceContinuousQueryRedeployTest.java    |   3 -
 ...ridServiceDeploymentCompoundFutureSelfTest.java |   3 -
 ...dServiceDeploymentExceptionPropagationTest.java |   9 +-
 .../service/GridServicePackagePrivateSelfTest.java |   3 -
 .../GridServiceProcessorAbstractSelfTest.java      |   3 -
 .../GridServiceProcessorBatchDeploySelfTest.java   |   3 -
 ...ridServiceProcessorMultiNodeConfigSelfTest.java |   3 -
 .../GridServiceProcessorMultiNodeSelfTest.java     |   3 -
 .../service/GridServiceProcessorProxySelfTest.java |   3 -
 .../GridServiceProcessorSingleNodeSelfTest.java    |   3 -
 .../service/GridServiceProcessorStopSelfTest.java  |   3 -
 .../GridServiceProxyClientReconnectSelfTest.java   |   3 -
 .../service/GridServiceProxyNodeStopSelfTest.java  |   3 -
 .../service/GridServiceReassignmentSelfTest.java   |   3 -
 .../service/GridServiceSerializationSelfTest.java  |   3 -
 .../IgniteServiceConfigVariationsFullApiTest.java  |   3 -
 ...ployment2ClassLoadersDefaultMarshallerTest.java |   3 -
 ...eploymentClassLoadingDefaultMarshallerTest.java |   3 -
 .../IgniteServiceDynamicCachesSelfTest.java        |   3 -
 .../IgniteServiceProxyTimeoutInitializedTest.java  |   3 -
 .../service/IgniteServiceReassignmentTest.java     |   3 -
 ...mentDiscoveryListenerNotificationOrderTest.java |  11 +-
 ...mentNonSerializableStaticConfigurationTest.java |  13 +-
 .../service/ServiceDeploymentOnActivationTest.java |  13 +-
 .../ServiceDeploymentOnClientDisconnectTest.java   |   9 +-
 .../ServiceDeploymentOutsideBaselineTest.java      |   3 -
 .../ServiceDeploymentProcessAbstractTest.java      |   6 +-
 ...eDeploymentProcessingOnCoordinatorFailTest.java |   3 -
 ...eDeploymentProcessingOnCoordinatorLeftTest.java |   3 -
 ...ServiceDeploymentProcessingOnNodesFailTest.java |   3 -
 ...ServiceDeploymentProcessingOnNodesLeftTest.java |   3 -
 .../service/ServicePredicateAccessCacheTest.java   |   3 -
 .../service/SystemCacheNotConfiguredTest.java      |   3 -
 .../timeout/GridTimeoutProcessorSelfTest.java      |   3 -
 .../product/GridProductVersionSelfTest.java        |   3 -
 .../internal/sql/SqlParserBulkLoadSelfTest.java    |   3 -
 .../internal/sql/SqlParserCreateIndexSelfTest.java |   3 -
 .../internal/sql/SqlParserDropIndexSelfTest.java   |   3 -
 .../sql/SqlParserSetStreamingSelfTest.java         |   3 -
 .../SqlParserTransactionalKeywordsSelfTest.java    |   3 -
 .../ignite/internal/sql/SqlParserUserSelfTest.java |   3 -
 .../stat/IoStatisticsCachePersistenceSelfTest.java |   4 -
 .../internal/stat/IoStatisticsCacheSelfTest.java   |   3 -
 .../internal/stat/IoStatisticsManagerSelfTest.java |   3 -
 ...IoStatisticsMetricsLocalMXBeanImplSelfTest.java |   3 -
 .../ignite/internal/util/BitSetIntSetTest.java     |   3 -
 .../ignite/internal/util/GridArraysSelfTest.java   |   3 -
 .../internal/util/GridHandleTableSelfTest.java     |   3 -
 .../ignite/internal/util/IgniteDevOnlyLogTest.java |   3 -
 .../util/IgniteExceptionRegistrySelfTest.java      |   3 -
 .../ignite/internal/util/IgniteUtilsSelfTest.java  |   3 -
 .../ignite/internal/util/StripedExecutorTest.java  |   3 -
 .../util/future/GridCompoundFutureSelfTest.java    |   3 -
 .../util/future/GridEmbeddedFutureSelfTest.java    |   3 -
 .../util/future/GridFutureAdapterSelfTest.java     |   3 -
 .../internal/util/future/IgniteFutureImplTest.java |   3 -
 .../future/nio/GridNioEmbeddedFutureSelfTest.java  |   3 -
 .../util/future/nio/GridNioFutureSelfTest.java     |   3 -
 .../GridUnsafeDataOutputArraySizingSelfTest.java   |   3 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java     |   3 -
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java    |   3 -
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java    |   3 -
 .../ignite/internal/util/nio/GridNioSelfTest.java  |   3 -
 .../util/nio/GridNioSessionMetaKeySelfTest.java    |   3 -
 .../internal/util/nio/GridNioSslSelfTest.java      |   3 -
 .../nio/IgniteExceptionInNioWorkerSelfTest.java    |   3 -
 .../util/nio/impl/GridNioFilterChainSelfTest.java  |   3 -
 .../offheap/GridOffHeapMapAbstractSelfTest.java    |   3 -
 .../GridOffHeapMapPerformanceAbstractTest.java     |   3 -
 .../GridOffHeapPartitionedMapAbstractSelfTest.java |   3 -
 ...fHeapPartitionedMapPerformanceAbstractTest.java |   3 -
 .../offheap/unsafe/GridUnsafeMemorySelfTest.java   |   3 -
 .../unsafe/GridUnsafeStripedLruSefTest.java        |   3 -
 .../tostring/CircularStringBuilderSelfTest.java    |   3 -
 .../util/tostring/GridToStringBuilderSelfTest.java |   3 -
 .../tostring/IncludeSensitiveAbstractTest.java     |   3 -
 .../ignite/lang/GridByteArrayListSelfTest.java     |   3 -
 .../ignite/lang/GridFuncPerformanceTest.java       |   3 -
 .../lang/GridMetadataAwareAdapterLoadTest.java     |   3 -
 .../lang/GridMetadataAwareAdapterSelfTest.java     |   3 -
 .../apache/ignite/lang/GridSetWrapperSelfTest.java |   3 -
 .../org/apache/ignite/lang/GridTupleSelfTest.java  |   3 -
 .../java/org/apache/ignite/lang/GridXSelfTest.java |   3 -
 .../org/apache/ignite/lang/IgniteUuidSelfTest.java |   3 -
 ...GridBoundedConcurrentLinkedHashMapSelfTest.java |   3 -
 .../GridBoundedConcurrentOrderedMapSelfTest.java   |   3 -
 .../utils/GridBoundedPriorityQueueSelfTest.java    |   3 -
 .../utils/GridCircularBufferPerformanceTest.java   |   3 -
 .../lang/utils/GridCircularBufferSelfTest.java     |   3 -
 .../utils/GridConcurrentLinkedHashMapSelfTest.java |   3 -
 .../utils/GridConcurrentWeakHashSetSelfTest.java   |   3 -
 .../lang/utils/GridConsistentHashSelfTest.java     |   3 -
 .../lang/utils/GridLeanIdentitySetSelfTest.java    |   3 -
 .../lang/utils/GridLeanMapPerformanceTest.java     |   3 -
 .../ignite/lang/utils/GridLeanMapSelfTest.java     |   3 -
 .../ignite/lang/utils/GridListSetSelfTest.java     |   3 -
 .../ignite/lang/utils/GridStripedLockSelfTest.java |   3 -
 .../utils/IgniteOffheapReadWriteLockSelfTest.java  |   3 -
 .../loadtests/GridCacheMultiNodeLoadTest.java      |   3 -
 .../cache/GridCacheWriteBehindStoreLoadTest.java   |   3 -
 .../communication/GridIoManagerBenchmark0.java     |   3 -
 .../GridCachePartitionedAtomicLongLoadTest.java    |   3 -
 .../direct/multisplit/GridMultiSplitsLoadTest.java |   3 -
 .../GridMultiSplitsRedeployLoadTest.java           |   3 -
 .../GridSingleSplitsNewNodesAbstractLoadTest.java  |   3 -
 .../redeploy/GridSingleSplitsRedeployLoadTest.java |   3 -
 .../direct/session/GridSessionLoadTest.java        |   3 -
 .../direct/stealing/GridStealingLoadTest.java      |   3 -
 .../loadtests/hashmap/GridHashMapLoadTest.java     |   3 -
 .../DynamicProxySerializationMultiJvmSelfTest.java |   3 -
 .../marshaller/GridMarshallerAbstractTest.java     |   3 -
 .../GridMarshallerMappingConsistencyTest.java      |   3 -
 .../marshaller/GridMarshallerPerformanceTest.java  |   3 -
 .../marshaller/MarshallerContextSelfTest.java      |   3 -
 .../MarshallerEnumDeadlockMultiJvmTest.java        |   3 -
 .../GridMessagingNoPeerClassLoadingSelfTest.java   |   3 -
 .../ignite/messaging/GridMessagingSelfTest.java    |   3 -
 .../messaging/IgniteMessagingSendAsyncTest.java    |   3 -
 .../messaging/IgniteMessagingWithClientTest.java   |   3 -
 .../p2p/DeploymentClassLoaderCallableTest.java     |   3 -
 ...ridMultinodeRedeployContinuousModeSelfTest.java |   3 -
 .../GridMultinodeRedeployIsolatedModeSelfTest.java |   3 -
 .../GridMultinodeRedeployPrivateModeSelfTest.java  |   3 -
 .../GridMultinodeRedeploySharedModeSelfTest.java   |   3 -
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java    |   3 -
 .../p2p/GridP2PContinuousDeploymentSelfTest.java   |   3 -
 .../p2p/GridP2PDifferentClassLoaderSelfTest.java   |   3 -
 .../p2p/GridP2PDoubleDeploymentSelfTest.java       |   3 -
 .../ignite/p2p/GridP2PHotRedeploymentSelfTest.java |   3 -
 .../ignite/p2p/GridP2PJobClassLoaderSelfTest.java  |   3 -
 .../ignite/p2p/GridP2PLocalDeploymentSelfTest.java |   3 -
 .../GridP2PMissedResourceCacheSizeSelfTest.java    |   3 -
 .../apache/ignite/p2p/GridP2PNodeLeftSelfTest.java |   3 -
 .../ignite/p2p/GridP2PRecursionTaskSelfTest.java   |   3 -
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java     |   3 -
 .../ignite/p2p/GridP2PSameClassLoaderSelfTest.java |   3 -
 .../ignite/p2p/GridP2PTestTaskExecutionTest.java   |   3 -
 .../apache/ignite/p2p/GridP2PTimeoutSelfTest.java  |   3 -
 .../apache/ignite/p2p/GridP2PUndeploySelfTest.java |   3 -
 .../ignite/p2p/P2PScanQueryUndeployTest.java       |   3 -
 .../ignite/p2p/P2PStreamingClassLoaderTest.java    |   3 -
 .../apache/ignite/p2p/SharedDeploymentTest.java    |   3 -
 .../PlatformDefaultJavaObjectFactorySelfTest.java  |   3 -
 .../PlatformJavaObjectFactoryProxySelfTest.java    |   3 -
 .../ignite/plugin/PluginNodeValidationTest.java    |   3 -
 .../security/SecurityPermissionSetBuilderTest.java |   3 -
 .../ignite/services/ServiceThreadPoolSelfTest.java |   3 -
 ...ridSessionCancelSiblingsFromFutureSelfTest.java |   3 -
 .../GridSessionCancelSiblingsFromJobSelfTest.java  |   3 -
 .../GridSessionCancelSiblingsFromTaskSelfTest.java |   3 -
 .../session/GridSessionCheckpointSelfTest.java     |   3 -
 .../session/GridSessionCollisionSpiSelfTest.java   |   3 -
 .../GridSessionFutureWaitJobAttributeSelfTest.java |   3 -
 ...GridSessionFutureWaitTaskAttributeSelfTest.java |   3 -
 .../session/GridSessionJobFailoverSelfTest.java    |   3 -
 .../GridSessionJobWaitTaskAttributeSelfTest.java   |   3 -
 .../ignite/session/GridSessionLoadSelfTest.java    |   3 -
 .../GridSessionSetFutureAttributeSelfTest.java     |   3 -
 ...sionSetFutureAttributeWaitListenerSelfTest.java |   3 -
 .../GridSessionSetJobAttribute2SelfTest.java       |   3 -
 .../GridSessionSetJobAttributeOrderSelfTest.java   |   3 -
 .../GridSessionSetJobAttributeSelfTest.java        |   3 -
 ...SessionSetJobAttributeWaitListenerSelfTest.java |   3 -
 .../GridSessionSetTaskAttributeSelfTest.java       |   3 -
 .../GridSessionTaskWaitJobAttributeSelfTest.java   |   3 -
 .../session/GridSessionWaitAttributeSelfTest.java  |   3 -
 .../ignite/spi/GridSpiLocalHostInjectionTest.java  |   3 -
 .../ignite/spi/GridSpiStartStopAbstractTest.java   |   3 -
 .../ignite/spi/GridTcpSpiForwardingSelfTest.java   |   3 -
 .../checkpoint/GridCheckpointSpiAbstractTest.java  |   3 -
 .../cache/CacheCheckpointSpiConfigSelfTest.java    |   3 -
 .../CacheCheckpointSpiSecondCacheSelfTest.java     |   3 -
 .../jdbc/JdbcCheckpointSpiConfigSelfTest.java      |   3 -
 .../GridSharedFsCheckpointSpiConfigSelfTest.java   |   3 -
 ...SharedFsCheckpointSpiMultiThreadedSelfTest.java |   3 -
 ...FsCheckpointSpiMultipleDirectoriesSelfTest.java |   3 -
 .../GridFifoQueueCollisionSpiConfigSelfTest.java   |   3 -
 .../GridFifoQueueCollisionSpiSelfTest.java         |   3 -
 ...dJobStealingCollisionSpiAttributesSelfTest.java |   3 -
 .../GridJobStealingCollisionSpiConfigSelfTest.java |   3 -
 ...StealingCollisionSpiCustomTopologySelfTest.java |   7 +-
 .../GridJobStealingCollisionSpiSelfTest.java       |   3 -
 ...ridPriorityQueueCollisionSpiConfigSelfTest.java |   3 -
 .../GridPriorityQueueCollisionSpiSelfTest.java     |   3 -
 .../GridAbstractCommunicationSelfTest.java         |   3 -
 .../communication/GridCacheMessageSelfTest.java    |   3 -
 .../tcp/GridCacheDhtLockBackupSelfTest.java        |   3 -
 .../tcp/GridTcpCommunicationSpiAbstractTest.java   |   3 -
 ...pCommunicationSpiConcurrentConnectSelfTest.java |   3 -
 .../tcp/GridTcpCommunicationSpiConfigSelfTest.java |   3 -
 .../tcp/GridTcpCommunicationSpiLanLoadTest.java    |   3 -
 ...idTcpCommunicationSpiMultithreadedSelfTest.java |   3 -
 ...GridTcpCommunicationSpiRecoveryAckSelfTest.java |   3 -
 ...icationSpiRecoveryFailureDetectionSelfTest.java |   3 -
 .../GridTcpCommunicationSpiRecoverySelfTest.java   |   3 -
 ...ommunicationSpiTcpFailureDetectionSelfTest.java |   5 +-
 .../IgniteTcpCommunicationConnectOnInitTest.java   |   3 -
 ...TcpCommunicationRecoveryAckClosureSelfTest.java |   3 -
 .../tcp/TcpCommunicationSpiDropNodesTest.java      |   3 -
 .../tcp/TcpCommunicationSpiFaultyClientTest.java   |   3 -
 ...cpCommunicationSpiHalfOpenedConnectionTest.java |   3 -
 .../TcpCommunicationSpiSkipMessageSendTest.java    |   3 -
 .../tcp/TcpCommunicationStatisticsTest.java        |   3 -
 .../local/GridLocalDeploymentSpiSelfTest.java      |   3 -
 .../AbstractDiscoveryRandomStartStopTest.java      |   3 -
 .../spi/discovery/AbstractDiscoverySelfTest.java   |   3 -
 .../spi/discovery/AbstractDiscoveryTest.java       |   3 -
 .../spi/discovery/AuthenticationRestartTest.java   |   3 -
 .../ClusterMetricsSnapshotSerializeSelfTest.java   |   3 -
 .../FilterDataForClientNodeDiscoveryTest.java      |   3 -
 .../IgniteDiscoveryCacheReuseSelfTest.java         |   3 -
 .../discovery/LongClientConnectToClusterTest.java  |   3 -
 .../tcp/DiscoveryUnmarshalVulnerabilityTest.java   |   3 -
 .../discovery/tcp/IgniteClientConnectSslTest.java  |   3 -
 .../spi/discovery/tcp/IgniteClientConnectTest.java |   3 -
 ...gniteClientReconnectMassiveShutdownSslTest.java |   3 -
 .../IgniteClientReconnectMassiveShutdownTest.java  |   3 -
 .../TcpClientDiscoveryMarshallerCheckSelfTest.java |   3 -
 ...TcpClientDiscoverySpiCoordinatorChangeTest.java |   3 -
 ...cpClientDiscoverySpiFailureTimeoutSelfTest.java |   3 -
 .../tcp/TcpClientDiscoverySpiMulticastTest.java    |   3 -
 .../tcp/TcpClientDiscoverySpiSelfTest.java         |   3 -
 .../tcp/TcpClientDiscoveryUnresolvedHostTest.java  |   3 -
 .../tcp/TcpDiscoveryClientSuspensionSelfTest.java  |   3 -
 .../tcp/TcpDiscoveryConcurrentStartTest.java       |   3 -
 .../tcp/TcpDiscoveryIpFinderCleanerTest.java       |   3 -
 .../tcp/TcpDiscoveryMarshallerCheckSelfTest.java   |   3 -
 .../tcp/TcpDiscoveryMultiThreadedTest.java         |   3 -
 ...scoveryNodeAttributesUpdateOnReconnectTest.java |   3 -
 ...TcpDiscoveryNodeConfigConsistentIdSelfTest.java |   3 -
 .../tcp/TcpDiscoveryNodeConsistentIdSelfTest.java  |   3 -
 .../TcpDiscoveryPendingMessageDeliveryTest.java    |   3 -
 .../TcpDiscoveryReconnectUnstableTopologyTest.java |   3 -
 .../spi/discovery/tcp/TcpDiscoveryRestartTest.java |   3 -
 .../tcp/TcpDiscoverySegmentationPolicyTest.java    |   3 -
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java    |   3 -
 .../tcp/TcpDiscoverySnapshotHistoryTest.java       |   3 -
 .../tcp/TcpDiscoverySpiConfigSelfTest.java         |   3 -
 .../tcp/TcpDiscoverySpiFailureTimeoutSelfTest.java |   3 -
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |   3 -
 .../tcp/TcpDiscoverySpiReconnectDelayTest.java     |   3 -
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java       |   3 -
 .../tcp/TcpDiscoverySslParametersTest.java         |   3 -
 .../tcp/TcpDiscoverySslSecuredUnsecuredTest.java   |   3 -
 .../tcp/TcpDiscoverySslTrustedUntrustedTest.java   |   3 -
 .../tcp/TcpDiscoveryWithWrongServerTest.java       |   3 -
 .../TcpDiscoveryIpFinderAbstractSelfTest.java      |   3 -
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java     |   3 -
 .../TcpDiscoveryMulticastIpFinderSelfTest.java     |   3 -
 .../TcpDiscoverySharedFsIpFinderSelfTest.java      |   3 -
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java         |   3 -
 ...ridMemoryEventStorageMultiThreadedSelfTest.java |   3 -
 .../GridMemoryEventStorageSpiConfigSelfTest.java   |   3 -
 .../memory/GridMemoryEventStorageSpiSelfTest.java  |   3 -
 .../GridAlwaysFailoverSpiConfigSelfTest.java       |   3 -
 .../always/GridAlwaysFailoverSpiSelfTest.java      |   3 -
 .../GridJobStealingFailoverSpiConfigSelfTest.java  |   3 -
 .../GridJobStealingFailoverSpiOneNodeSelfTest.java |   3 -
 .../GridJobStealingFailoverSpiSelfTest.java        |   3 -
 .../never/GridNeverFailoverSpiSelfTest.java        |   3 -
 ...GridAdaptiveLoadBalancingSpiConfigSelfTest.java |   3 -
 ...aptiveLoadBalancingSpiMultipleNodeSelfTest.java |   3 -
 .../GridAdaptiveLoadBalancingSpiSelfTest.java      |   3 -
 .../GridInternalTasksLoadBalancingSelfTest.java    |   3 -
 ...adBalancingNotPerTaskMultithreadedSelfTest.java |   3 -
 ...oundRobinLoadBalancingSpiLocalNodeSelfTest.java |   3 -
 ...RobinLoadBalancingSpiMultipleNodesSelfTest.java |   3 -
 ...undRobinLoadBalancingSpiNotPerTaskSelfTest.java |   3 -
 ...obinLoadBalancingSpiTopologyChangeSelfTest.java |   3 -
 ...ightedRandomLoadBalancingSpiConfigSelfTest.java |   3 -
 ...GridWeightedRandomLoadBalancingSpiSelfTest.java |   3 -
 ...htedRandomLoadBalancingSpiWeightedSelfTest.java |   3 -
 .../startup/cmdline/GridCommandLineLoaderTest.java |   3 -
 .../GridCommandLineTransformerSelfTest.java        |   3 -
 .../properties/NotStringSystemPropertyTest.java    |   3 -
 .../startup/servlet/GridServletLoaderTest.java     |   3 -
 .../stream/socket/SocketStreamerSelfTest.java      |   3 -
 .../SocketStreamerUnmarshalVulnerabilityTest.java  |   3 -
 .../ignite/testframework/MvccFeatureChecker.java   |  51 ++-
 .../testframework/junits/GridAbstractTest.java     | 455 +++++++--------------
 .../junits/GridAbstractTestWithAssumption.java     |  50 +++
 .../IgniteCacheConfigVariationsAbstractTest.java   |   2 +-
 .../junits/IgniteConfigVariationsAbstractTest.java |  75 ++--
 .../junits/JUnit3TestLegacySupport.java            |   2 +-
 .../cache/GridAbstractCacheStoreSelfTest.java      |   3 -
 .../common/GridAbstractLifecycleAwareSelfTest.java |   3 -
 .../junits/common/GridCommonAbstractTest.java      |   9 -
 .../common/GridRollingRestartAbstractTest.java     |   2 +-
 .../junits/spi/GridSpiAbstractTest.java            |  53 ++-
 .../test/ConfigVariationsTestSuiteBuilderTest.java | 117 +++++-
 .../test/ListeningTestLoggerTest.java              |   3 -
 .../ignite/testsuites/IgniteBasicTestSuite.java    |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite9.java      |   2 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |   4 +-
 ...IgniteContinuousQueryConfigVariationsSuite.java |  24 +-
 .../GridThreadPoolExecutorServiceSelfTest.java     |   3 -
 .../org/apache/ignite/thread/GridThreadTest.java   |   3 -
 .../ignite/thread/IgniteThreadPoolSizeTest.java    |   3 -
 .../ignite/util/AttributeNodeFilterSelfTest.java   |   3 -
 .../ignite/util/GridCommandHandlerSslTest.java     |   3 -
 .../apache/ignite/util/GridCommandHandlerTest.java |   3 -
 ...GridConcurrentLinkedDequeMultiThreadedTest.java |   3 -
 .../util/GridConcurrentLinkedDequeSelfTest.java    |   3 -
 ...ncurrentLinkedHashMapMultiThreadedSelfTest.java |   3 -
 .../GridInternalTaskUnusedWalSegmentsTest.java     |   3 -
 .../apache/ignite/util/GridLogThrottleTest.java    |   3 -
 .../ignite/util/GridPartitionMapSelfTest.java      |   3 -
 .../org/apache/ignite/util/GridQueueSelfTest.java  |   3 -
 .../org/apache/ignite/util/GridRandomSelfTest.java |   3 -
 .../ignite/util/GridSnapshotLockSelfTest.java      |   3 -
 .../ignite/util/GridSpinReadWriteLockSelfTest.java |   3 -
 .../util/GridStringBuilderFactorySelfTest.java     |   3 -
 .../ignite/util/GridTopologyHeapSizeSelfTest.java  |   3 -
 .../org/apache/ignite/util/GridTransientTest.java  |   3 -
 .../ignite/util/mbeans/GridMBeanBaselineTest.java  |   3 -
 .../util/mbeans/GridMBeanDisableSelfTest.java      |   3 -
 .../util/mbeans/GridMBeanExoticNamesSelfTest.java  |   3 -
 .../ignite/util/mbeans/GridMBeanSelfTest.java      |   3 -
 .../util/mbeans/WorkersControlMXBeanTest.java      |   3 -
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   3 -
 .../file/IgniteNativeIoWithNoPersistenceTest.java  |   3 -
 .../IgnitePdsReplacementNativeIoTest.java          |   3 -
 .../ignite/sink/flink/FlinkIgniteSinkSelfTest.java |   3 -
 .../source/flink/FlinkIgniteSourceSelfTest.java    |   3 -
 .../apache/ignite/stream/flume/IgniteSinkTest.java |   3 -
 .../query/h2/H2IndexingAbstractGeoSelfTest.java    |   3 -
 .../hadoop/impl/HadoopAbstractSelfTest.java        |   4 +-
 .../hadoop/impl/HadoopCommandLineTest.java         |  23 +-
 .../hadoop/impl/HadoopFileSystemsTest.java         |   3 -
 .../processors/hadoop/impl/HadoopGroupingTest.java |   3 -
 .../hadoop/impl/HadoopJobTrackerSelfTest.java      |   3 -
 .../impl/HadoopMapReduceEmbeddedSelfTest.java      |   3 -
 .../impl/HadoopMapReduceErrorResilienceTest.java   |   3 -
 .../hadoop/impl/HadoopMapReduceTest.java           |   3 -
 .../hadoop/impl/HadoopNoHadoopMapReduceTest.java   |   3 -
 .../impl/HadoopSerializationWrapperSelfTest.java   |   3 -
 .../hadoop/impl/HadoopSnappyFullMapReduceTest.java |  10 +
 .../processors/hadoop/impl/HadoopSnappyTest.java   |   6 +-
 .../processors/hadoop/impl/HadoopSortingTest.java  |   3 -
 .../hadoop/impl/HadoopSplitWrapperSelfTest.java    |   3 -
 .../hadoop/impl/HadoopTaskExecutionSelfTest.java   |   3 -
 .../impl/HadoopTasksVersionsAbstractTest.java      |   3 -
 .../processors/hadoop/impl/HadoopTeraSortTest.java |   8 +-
 .../hadoop/impl/HadoopTxConfigCacheTest.java       |   3 -
 .../hadoop/impl/HadoopUserLibsSelfTest.java        |   3 -
 .../hadoop/impl/HadoopV2JobSelfTest.java           |   3 -
 .../hadoop/impl/HadoopValidationSelfTest.java      |   3 -
 .../impl/HadoopWeightedMapReducePlannerTest.java   |   3 -
 ...adoopClientProtocolMultipleServersSelfTest.java |   3 -
 .../impl/client/HadoopClientProtocolSelfTest.java  |   3 -
 .../KerberosHadoopFileSystemFactorySelfTest.java   |   3 -
 .../hadoop/impl/igfs/Hadoop1OverIgfsProxyTest.java |   3 -
 .../impl/igfs/HadoopFIleSystemFactorySelfTest.java |   3 -
 .../HadoopIgfs20FileSystemAbstractSelfTest.java    |   3 -
 ...oopIgfs20FileSystemLoopbackPrimarySelfTest.java |  11 +-
 .../impl/igfs/HadoopIgfsDualAbstractSelfTest.java  |   9 +-
 ...HadoopSecondaryFileSystemConfigurationTest.java |   3 -
 .../impl/igfs/IgfsNearOnlyMultiNodeSelfTest.java   |   9 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java    |   3 -
 ...adoopFileSystemClientBasedAbstractSelfTest.java |   3 -
 ...doopFileSystemClientBasedDualAsyncSelfTest.java |  11 +-
 ...adoopFileSystemClientBasedDualSyncSelfTest.java |  11 +-
 .../IgniteHadoopFileSystemClientBasedOpenTest.java |   3 -
 ...HadoopFileSystemClientBasedPrimarySelfTest.java |  11 +-
 ...teHadoopFileSystemClientBasedProxySelfTest.java |  11 +-
 .../igfs/IgniteHadoopFileSystemClientSelfTest.java |   3 -
 .../IgniteHadoopFileSystemHandshakeSelfTest.java   |   3 -
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java    |   3 -
 .../igfs/IgniteHadoopFileSystemLoggerSelfTest.java |   3 -
 .../IgniteHadoopFileSystemLoggerStateSelfTest.java |   3 -
 ...ileSystemLoopbackEmbeddedDualAsyncSelfTest.java |  12 +-
 ...FileSystemLoopbackEmbeddedDualSyncSelfTest.java |  12 +-
 ...pFileSystemLoopbackEmbeddedPrimarySelfTest.java |  12 +-
 ...ileSystemLoopbackEmbeddedSecondarySelfTest.java |  13 +-
 ...gniteHadoopFileSystemShmemAbstractSelfTest.java |   3 -
 ...ystemShmemExternalToClientAbstractSelfTest.java |   3 -
 .../HadoopConcurrentHashMultimapSelftest.java      |   3 -
 .../shuffle/collections/HadoopHashMapSelfTest.java |   3 -
 .../collections/HadoopSkipListSelfTest.java        |   3 -
 .../shuffle/streams/HadoopDataStreamSelfTest.java  |   3 -
 .../taskexecutor/HadoopExecutorServiceTest.java    |   3 -
 .../HadoopExternalTaskExecutionSelfTest.java       |   3 -
 .../HadoopExternalCommunicationSelfTest.java       |   3 -
 .../impl/util/BasicUserNameMapperSelfTest.java     |   3 -
 .../impl/util/ChainedUserNameMapperSelfTest.java   |   3 -
 .../impl/util/KerberosUserNameMapperSelfTest.java  |   3 -
 .../state/HadoopJobTrackerSelfTestState.java       |   2 +-
 .../HibernateL2CacheConfigurationSelfTest.java     |   3 -
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |   3 -
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |   3 -
 .../HibernateL2CacheStrategySelfTest.java          |   3 -
 .../CacheHibernateStoreFactorySelfTest.java        |   3 -
 .../HibernateL2CacheConfigurationSelfTest.java     |   3 -
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |   3 -
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |   3 -
 .../HibernateL2CacheStrategySelfTest.java          |   3 -
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |   3 -
 .../CacheHibernateStoreFactorySelfTest.java        |   3 -
 .../HibernateL2CacheConfigurationSelfTest.java     |   3 -
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |   3 -
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |   3 -
 .../HibernateL2CacheStrategySelfTest.java          |   3 -
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |   3 -
 .../CacheHibernateStoreFactorySelfTest.java        |   3 -
 .../query/h2/DmlStatementsProcessor.java           |   5 +
 .../processors/query/h2/IgniteH2Indexing.java      |   2 +-
 .../query/h2/opt/GridH2KeyValueRowOnheap.java      |  80 ++--
 .../query/h2/opt/GridH2RowDescriptor.java          |   9 +-
 .../query/h2/twostep/ReducePartitionMapper.java    |  30 +-
 ...finityKeyNameAndValueFieldNameConflictTest.java |   3 -
 .../processors/cache/BigEntryQueryTest.java        |   3 -
 ...aryMetadataConcurrentUpdateWithIndexesTest.java |   3 -
 .../cache/BinarySerializationQuerySelfTest.java    |   3 -
 .../cache/BinaryTypeMismatchLoggingTest.java       |   3 -
 .../CacheAbstractQueryDetailMetricsSelfTest.java   |   3 -
 .../cache/CacheAbstractQueryMetricsSelfTest.java   |   3 -
 .../cache/CacheBinaryKeyConcurrentQueryTest.java   |   3 -
 .../cache/CacheConfigurationP2PTest.java           |   3 -
 .../processors/cache/CacheIndexStreamerTest.java   |   3 -
 .../cache/CacheIteratorScanQueryTest.java          |   3 -
 .../CacheOffheapBatchIndexingMultiTypeTest.java    |   3 -
 .../CacheOffheapBatchIndexingSingleTypeTest.java   |   3 -
 .../cache/CacheOperationsWithExpirationTest.java   |   3 -
 .../processors/cache/CacheQueryBuildValueTest.java |   3 -
 .../cache/CacheQueryEvictDataLostTest.java         |   3 -
 .../cache/CacheQueryFilterExpiredTest.java         |   3 -
 .../cache/CacheQueryNewClientSelfTest.java         |   3 -
 .../CacheRandomOperationsMultithreadedTest.java    |   3 -
 .../CacheScanPartitionQueryFallbackSelfTest.java   |   3 -
 .../cache/CacheSqlQueryValueCopySelfTest.java      |   3 -
 .../ClientReconnectAfterClusterRestartTest.java    |   3 -
 .../cache/ClusterReadOnlyModeSqlTest.java          |   3 -
 .../processors/cache/DdlTransactionSelfTest.java   |   3 -
 .../cache/GridCacheCrossCacheQuerySelfTest.java    |   3 -
 .../cache/GridCacheDynamicLoadOnClientTest.java    |   3 -
 .../cache/GridCacheFullTextQuerySelfTest.java      |   3 -
 .../GridCacheLazyQueryPartitionsReleaseTest.java   |   3 -
 .../processors/cache/GridCacheOffHeapSelfTest.java |   3 -
 .../cache/GridCacheOffheapIndexEntryEvictTest.java |   3 -
 .../cache/GridCacheOffheapIndexGetSelfTest.java    |   3 -
 .../cache/GridCacheQueryIndexDisabledSelfTest.java |   3 -
 .../cache/GridCacheQuerySerializationSelfTest.java |   3 -
 .../cache/GridCacheQuerySimpleBenchmark.java       |   3 -
 .../cache/GridIndexingWithNoopSwapSelfTest.java    |   3 -
 .../IgniteBinaryObjectFieldsQuerySelfTest.java     |   3 -
 .../IgniteBinaryObjectQueryArgumentsTest.java      |   3 -
 .../IgniteCacheAbstractFieldsQuerySelfTest.java    |   3 -
 .../cache/IgniteCacheCollocatedQuerySelfTest.java  |   3 -
 .../IgniteCacheConfigVariationsQueryTest.java      |   3 -
 ...teCacheConfigurationPrimitiveTypesSelfTest.java |   3 -
 .../cache/IgniteCacheCrossCacheJoinRandomTest.java |   3 -
 .../cache/IgniteCacheDeleteSqlQuerySelfTest.java   |   3 -
 ...teCacheDistributedJoinCollocatedAndNotTest.java |   3 -
 ...teCacheDistributedJoinCustomAffinityMapper.java |   3 -
 .../IgniteCacheDistributedJoinNoIndexTest.java     |   3 -
 ...istributedJoinPartitionedAndReplicatedTest.java |   3 -
 ...iteCacheDistributedJoinQueryConditionsTest.java |   3 -
 .../cache/IgniteCacheDistributedJoinTest.java      |   3 -
 ...eCacheDuplicateEntityConfigurationSelfTest.java |   3 -
 .../IgniteCacheFieldsQueryNoDataSelfTest.java      |   3 -
 ...gniteCacheFullTextQueryNodeJoiningSelfTest.java |   3 -
 .../processors/cache/IgniteCacheGroupsSqlTest.java |   3 -
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |   3 -
 ...oinPartitionedAndReplicatedCollocationTest.java |   3 -
 ...gniteCacheJoinPartitionedAndReplicatedTest.java |   3 -
 .../IgniteCacheJoinQueryWithAffinityKeyTest.java   |   3 -
 .../cache/IgniteCacheLargeResultSelfTest.java      |   3 -
 ...ockPartitionOnAffinityRunAtomicCacheOpTest.java |   3 -
 .../IgniteCacheLockPartitionOnAffinityRunTest.java |   3 -
 ...PartitionOnAffinityRunWithCollisionSpiTest.java |   3 -
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java    |   3 -
 .../cache/IgniteCacheMultipleIndexedTypesTest.java |   3 -
 .../cache/IgniteCacheNoClassQuerySelfTest.java     |   3 -
 .../IgniteCacheObjectKeyIndexingSelfTest.java      |   3 -
 .../cache/IgniteCacheOffheapEvictQueryTest.java    |   3 -
 .../cache/IgniteCacheOffheapIndexScanTest.java     |   3 -
 .../IgniteCacheP2pUnmarshallingQueryErrorTest.java |   3 -
 ...CachePartitionedQueryMultiThreadedSelfTest.java |   3 -
 .../IgniteCachePrimitiveFieldsQuerySelfTest.java   |   3 -
 .../cache/IgniteCacheQueriesLoadTest1.java         |   7 +-
 .../cache/IgniteCacheQueryH2IndexingLeakTest.java  |   7 +-
 .../cache/IgniteCacheQueryIndexSelfTest.java       |   3 -
 .../cache/IgniteCacheQueryLoadSelfTest.java        |   3 -
 .../IgniteCacheQueryMultiThreadedSelfTest.java     |   3 -
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |   3 -
 .../IgniteCacheSqlInsertValidationSelfTest.java    |   5 +-
 .../cache/IgniteCacheSqlQueryErrorSelfTest.java    |   3 -
 .../IgniteCacheSqlQueryMultiThreadedSelfTest.java  |   3 -
 .../IgniteCacheStarvationOnRebalanceTest.java      |   3 -
 .../cache/IgniteCacheUnionDuplicatesTest.java      |   3 -
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |   3 -
 ...iteCheckClusterStateBeforeExecuteQueryTest.java |   3 -
 ...iteClientReconnectCacheQueriesFailoverTest.java |   3 -
 .../cache/IgniteClientReconnectQueriesTest.java    |   3 -
 .../cache/IgniteCrossCachesJoinsQueryTest.java     |   3 -
 .../cache/IgniteDynamicSqlRestoreTest.java         |   3 -
 .../cache/IgniteErrorOnRebalanceTest.java          |   3 -
 .../processors/cache/IncorrectQueryEntityTest.java |   3 -
 .../cache/QueryEntityCaseMismatchTest.java         |   3 -
 .../QueryJoinWithDifferentNodeFiltersTest.java     |   3 -
 .../processors/cache/SqlFieldsQuerySelfTest.java   |   3 -
 .../cache/StartCachesInParallelTest.java           |   3 -
 .../authentication/SqlUserCommandSelfTest.java     |   3 -
 .../CacheBlockOnCreateDestoryIndexTest.java        |   3 -
 .../distributed/CacheBlockOnSqlQueryTest.java      |   3 -
 ...heClientQueryReplicatedNodeRestartSelfTest.java |   3 -
 ...ributedPartitionQueryConfigurationSelfTest.java |   3 -
 ...tributedPartitionQueryNodeRestartsSelfTest.java |   3 -
 ...niteCacheDistributedPartitionQuerySelfTest.java |   3 -
 .../IgniteCacheDistributedQueryCancelSelfTest.java |   3 -
 ...tributedQueryStopOnCancelOrTimeoutSelfTest.java |   3 -
 .../IgniteCachePartitionedFieldsQuerySelfTest.java |   3 -
 .../near/IgniteCacheQueryNoRebalanceSelfTest.java  |   3 -
 .../near/IgniteCacheQueryNodeFailTest.java         |   3 -
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |   3 -
 .../near/IgniteCacheQueryNodeRestartSelfTest.java  |   3 -
 .../near/IgniteCacheQueryNodeRestartSelfTest2.java |   3 -
 ...opOnCancelOrTimeoutDistributedJoinSelfTest.java |   3 -
 .../near/IgniteSqlQueryWithBaselineTest.java       |   3 -
 ...FieldsQueryJoinNoPrimaryPartitionsSelfTest.java |   3 -
 .../IgniteCacheReplicatedFieldsQuerySelfTest.java  |   3 -
 .../IgniteCacheReplicatedQuerySelfTest.java        |   3 -
 .../cache/index/AbstractIndexingCommonTest.java    |   3 -
 .../processors/cache/index/BasicIndexTest.java     |   3 -
 .../index/ComplexPrimaryKeyUnwrapSelfTest.java     |   3 -
 .../index/ComplexSecondaryKeyUnwrapSelfTest.java   |   3 -
 .../index/DuplicateKeyValueClassesSelfTest.java    |   3 -
 .../DynamicColumnsAbstractConcurrentSelfTest.java  |   3 -
 .../index/DynamicIndexAbstractBasicSelfTest.java   |   3 -
 .../DynamicIndexAbstractConcurrentSelfTest.java    |   3 -
 .../cache/index/H2ConnectionLeaksSelfTest.java     |   3 -
 .../H2DynamicColumnsAbstractBasicSelfTest.java     |   3 -
 .../index/H2DynamicIndexAbstractSelfTest.java      |   3 -
 .../H2DynamicIndexingComplexAbstractTest.java      |   3 -
 .../cache/index/H2DynamicTableSelfTest.java        |   3 -
 .../cache/index/H2RowCachePageEvictionTest.java    |   3 -
 .../processors/cache/index/H2RowCacheSelfTest.java |   3 -
 .../cache/index/IgniteDecimalSelfTest.java         |   3 -
 .../processors/cache/index/LongIndexNameTest.java  |   3 -
 .../cache/index/MvccEmptyTransactionSelfTest.java  |   3 -
 .../index/OptimizedMarshallerIndexNameTest.java    |   3 -
 .../cache/index/QueryEntityValidationSelfTest.java |   3 -
 .../cache/index/SchemaExchangeSelfTest.java        |   3 -
 ...ransactionCommandsWithMvccDisabledSelfTest.java |   3 -
 ...ransactionsCommandsWithMvccEnabledSelfTest.java |   3 -
 .../cache/index/SqlTransactionsSelfTest.java       |   3 -
 .../local/IgniteCacheLocalFieldsQuerySelfTest.java |   3 -
 ...niteCacheLocalQueryCancelOrTimeoutSelfTest.java |   3 -
 .../cache/local/IgniteCacheLocalQuerySelfTest.java |   3 -
 .../CacheMvccAbstractContinuousQuerySelfTest.java  |   3 -
 ...acheMvccAbstractSqlCoordinatorFailoverTest.java |  15 +-
 .../cache/mvcc/CacheMvccBackupsAbstractTest.java   |   3 -
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |   3 -
 .../cache/mvcc/CacheMvccBulkLoadTest.java          |   3 -
 ...vccContinuousWithTransformerClientSelfTest.java |   3 -
 ...ntinuousWithTransformerPartitionedSelfTest.java |   3 -
 ...ontinuousWithTransformerReplicatedSelfTest.java |   3 -
 .../cache/mvcc/CacheMvccDmlSimpleTest.java         |   3 -
 ...cheMvccPartitionedSelectForUpdateQueryTest.java |   3 -
 ...eMvccPartitionedSqlCoordinatorFailoverTest.java |  17 +-
 ...MvccPartitionedSqlTxQueriesWithReducerTest.java |   3 -
 ...heMvccReplicatedSqlCoordinatorFailoverTest.java |   9 +
 .../mvcc/CacheMvccReplicatedSqlTxQueriesTest.java  |   3 -
 .../CacheMvccSelectForUpdateQueryAbstractTest.java |   3 -
 .../processors/cache/mvcc/CacheMvccSizeTest.java   |   3 -
 .../CacheMvccSqlConfigurationValidationTest.java   |   3 -
 .../cache/mvcc/CacheMvccSqlLockTimeoutTest.java    |   3 -
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |   3 -
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |   3 -
 ...cheMvccSqlTxQueriesWithReducerAbstractTest.java |   3 -
 .../cache/mvcc/CacheMvccSqlUpdateCountersTest.java |   3 -
 .../cache/mvcc/CacheMvccStreamingInsertTest.java   |   3 -
 .../cache/mvcc/CacheMvccTxNodeMappingTest.java     |   3 -
 .../cache/mvcc/CacheMvccTxRecoveryTest.java        |   3 -
 .../cache/mvcc/MvccDeadlockDetectionTest.java      |   3 -
 .../cache/mvcc/MvccRepeatableReadBulkOpsTest.java  |   3 -
 .../mvcc/MvccRepeatableReadOperationsTest.java     |   3 -
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |   3 -
 .../transaction/DmlInsideTransactionTest.java      |   3 -
 .../cache/ttl/CacheTtlAbstractSelfTest.java        |   3 -
 ...ntConnectorConfigurationValidationSelfTest.java |   3 -
 .../processors/client/IgniteDataStreamerTest.java  |   3 -
 .../IgniteDbSingleNodeWithIndexingPutGetTest.java  |   3 -
 ...niteDbSingleNodeWithIndexingWalRestoreTest.java |   3 -
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |   3 -
 .../IgnitePersistentStoreSchemaLoadTest.java       |   3 -
 .../database/IgniteTwoRegionsRebuildIndexTest.java |   3 -
 ...IgniteCacheGroupsSqlSegmentedIndexSelfTest.java |   3 -
 .../query/IgniteCachelessQueriesSelfTest.java      |   3 -
 .../query/IgniteQueryDedicatedPoolTest.java        |   3 -
 .../query/IgniteSqlDefaultValueTest.java           |   3 -
 .../query/IgniteSqlDistributedJoinSelfTest.java    |   3 -
 .../query/IgniteSqlEntryCacheModeAgnosticTest.java |   3 -
 .../query/IgniteSqlGroupConcatCollocatedTest.java  |   3 -
 .../IgniteSqlGroupConcatNotCollocatedTest.java     |   3 -
 .../query/IgniteSqlKeyValueFieldsTest.java         |   3 -
 .../query/IgniteSqlNotNullConstraintTest.java      |   3 -
 .../query/IgniteSqlParameterizedQueryTest.java     |   3 -
 .../query/IgniteSqlQueryParallelismTest.java       |   3 -
 .../processors/query/IgniteSqlRoutingTest.java     |   3 -
 .../query/IgniteSqlSchemaIndexingTest.java         |   3 -
 .../query/IgniteSqlSegmentedIndexSelfTest.java     |   3 -
 ...gniteSqlSkipReducerOnUpdateDmlFlagSelfTest.java |   3 -
 .../IgniteSqlSkipReducerOnUpdateDmlSelfTest.java   |   3 -
 .../query/IgniteSqlSplitterSelfTest.java           |   3 -
 .../processors/query/LazyQuerySelfTest.java        |   3 -
 .../query/MultipleStatementsSqlQuerySelfTest.java  |   3 -
 .../processors/query/RunningQueriesTest.java       |  29 +-
 .../processors/query/SqlIllegalSchemaSelfTest.java |   3 -
 .../SqlLocalQueryConnectionAndStatementTest.java   |   5 +-
 .../processors/query/SqlNestedQuerySelfTest.java   |   3 -
 .../processors/query/SqlPushDownFunctionTest.java  |   3 -
 .../processors/query/SqlQueryHistorySelfTest.java  |   3 -
 .../processors/query/SqlSchemaSelfTest.java        |   3 -
 .../processors/query/SqlSystemViewsSelfTest.java   |   3 -
 .../CacheQueryEntityWithDateTimeApiFieldsTest.java |   3 -
 .../query/h2/GridIndexRebuildSelfTest.java         |   3 -
 .../GridIndexRebuildWithMvccEnabledSelfTest.java   |   3 -
 .../query/h2/GridIndexingSpiAbstractSelfTest.java  |   3 -
 .../H2ResultSetIteratorNullifyOnEndSelfTest.java   |   3 -
 .../query/h2/H2StatementCacheSelfTest.java         |   3 -
 .../query/h2/IgniteSqlBigIntegerKeyTest.java       |   3 -
 .../query/h2/IgniteSqlQueryMinMaxTest.java         |   3 -
 .../query/h2/PreparedStatementExSelfTest.java      |   3 -
 .../processors/query/h2/QueryDataPageScanTest.java |   5 +-
 .../query/h2/ThreadLocalObjectPoolSelfTest.java    |   3 -
 .../query/h2/database/InlineIndexHelperTest.java   |   3 -
 .../query/h2/sql/BaseH2CompareQueryTest.java       |   3 -
 .../processors/query/h2/sql/ExplainSelfTest.java   |   3 -
 .../query/h2/sql/GridQueryParsingTest.java         |   3 -
 .../query/h2/sql/H2CompareBigQueryTest.java        |   3 -
 .../BetweenOperationExtractPartitionSelfTest.java  |   3 -
 .../query/h2/twostep/CacheQueryMemoryLeakTest.java |   3 -
 .../h2/twostep/CreateTableWithDateKeySelfTest.java |   3 -
 .../DisappearedCacheCauseRetryMessageSelfTest.java |   3 -
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |   3 -
 .../InOperationExtractPartitionSelfTest.java       |   3 -
 .../h2/twostep/JoinPartitionPruningSelfTest.java   |   3 -
 .../twostep/NonCollocatedRetryMessageSelfTest.java |   3 -
 ...neOrSinglePartitionsQueryOptimizationsTest.java |   3 -
 .../h2/twostep/RetryCauseMessageSelfTest.java      |   3 -
 .../h2/twostep/TableViewSubquerySelfTest.java      |   3 -
 ...achePartitionedAtomicColumnConstraintsTest.java |   3 -
 ...dTransactionalSnapshotColumnConstraintTest.java |   3 -
 ...dTransactionalSnapshotColumnConstraintTest.java |   3 -
 .../sql/IgniteSQLColumnConstraintsTest.java        |   3 -
 .../IgniteTransactionSQLColumnConstraintTest.java  |   3 -
 ...qlConnectorConfigurationValidationSelfTest.java |   3 -
 .../tcp/GridOrderedMessageCancelSelfTest.java      |   3 -
 .../org/apache/ignite/sqltests/BaseSqlTest.java    |   3 -
 .../apache/ignite/sqltests/PartitionedSqlTest.java |   3 -
 .../apache/ignite/sqltests/ReplicatedSqlTest.java  |   3 -
 .../util/GridCommandHandlerIndexingTest.java       |   3 -
 .../ignite/stream/jms11/IgniteJmsStreamerTest.java |   3 -
 .../cache/CacheJndiTmFactorySelfTest.java          |   3 -
 ...ridCacheJtaConfigurationValidationSelfTest.java |   3 -
 ...ridCacheJtaFactoryConfigValidationSelfTest.java |   3 -
 .../cache/GridJtaLifecycleAwareSelfTest.java       |   3 -
 .../cache/GridJtaTransactionManagerSelfTest.java   |   3 -
 .../cache/jta/AbstractCacheJtaSelfTest.java        |   3 -
 .../stream/kafka/KafkaIgniteStreamerSelfTest.java  |   3 -
 .../kafka/connect/IgniteSinkConnectorTest.java     |   3 -
 .../kafka/connect/IgniteSourceConnectorTest.java   |   3 -
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java    |   3 -
 .../logger/log4j2/Log4j2LoggerMarkerTest.java      |   3 -
 .../ignite/logger/log4j2/Log4j2LoggerSelfTest.java |   3 -
 .../ml/sparkmodelparser/SparkModelParser.java      |  44 ++
 .../ml/sparkmodelparser/SupportedSparkModels.java  |   3 +
 .../java/org/apache/ignite/ml/IgniteModel.java     |  24 +-
 .../ignite/ml/clustering/kmeans/KMeansTrainer.java |  31 +-
 .../ignite/ml/composition/CompositionUtils.java    |  53 ++-
 .../ml/composition/bagging/BaggedTrainer.java      |  42 +-
 .../composition/boosting/GDBLearningStrategy.java  |  16 +-
 .../ignite/ml/composition/boosting/GDBTrainer.java |  37 +-
 .../parallel/TrainersParallelComposition.java      |  19 +-
 .../sequential/ModelsSequentialComposition.java    |  10 +-
 .../sequential/TrainersSequentialComposition.java  | 138 ++++++-
 .../stacking/StackedDatasetTrainer.java            |  26 +-
 .../bootstrapping/BootstrappedDatasetBuilder.java  |  26 +-
 .../impl/bootstrapping/BootstrappedVector.java     |   2 +-
 .../ml/knn/ann/ANNClassificationTrainer.java       |  17 +-
 .../classification/KNNClassificationTrainer.java   |  27 +-
 .../ml/knn/regression/KNNRegressionModel.java      |   4 +-
 .../ml/knn/regression/KNNRegressionTrainer.java    |  23 +-
 .../ignite/ml/math/functions/IgniteFunction.java   |  13 +
 .../ml/math/primitives/vector/VectorUtils.java     |  26 +-
 .../ignite/ml/multiclass/OneVsRestTrainer.java     |  22 +-
 .../discrete/DiscreteNaiveBayesTrainer.java        | 112 ++---
 .../gaussian/GaussianNaiveBayesTrainer.java        |  26 +-
 .../java/org/apache/ignite/ml/nn/MLPTrainer.java   |  13 +-
 .../linear/LinearRegressionLSQRTrainer.java        |  13 +-
 .../linear/LinearRegressionSGDTrainer.java         |  12 +-
 .../logistic/LogisticRegressionSGDTrainer.java     |  13 +-
 .../apache/ignite/ml/structures/LabeledVector.java |   7 +-
 .../ignite/ml/structures/LabeledVectorSet.java     |   2 +-
 .../ml/svm/SVMLinearClassificationTrainer.java     |  18 +-
 .../ignite/ml/trainers/AdaptableDatasetModel.java  |   2 +-
 .../ml/trainers/AdaptableDatasetTrainer.java       |  61 ++-
 .../apache/ignite/ml/trainers/DatasetTrainer.java  | 100 ++++-
 .../ignite/ml/trainers/FeatureLabelExtractor.java  |  71 ++++
 .../ignite/ml/trainers/TrainerTransformers.java    |  29 +-
 .../org/apache/ignite/ml/tree/DecisionTree.java    |  15 +-
 .../tree/boosting/GDBOnTreesLearningStrategy.java  |   4 +-
 .../ml/tree/data/DecisionTreeDataBuilder.java      |  25 +-
 .../ml/tree/randomforest/RandomForestTrainer.java  |  10 +-
 .../ml/util/generators/DataStreamGenerator.java    |   6 +-
 .../primitives/vector/VectorGenerator.java         |   2 +-
 .../primitives/vector/VectorGeneratorsFamily.java  |   2 +-
 .../standard/GaussianMixtureDataStream.java        |   2 +-
 .../generators/standard/RegressionDataStream.java  |   2 +-
 .../util/generators/standard/RingsDataStream.java  |   3 +-
 .../standard/TwoSeparableClassesDataStream.java    |   2 +-
 .../test/java/org/apache/ignite/ml/TestUtils.java  |   7 +-
 .../apache/ignite/ml/common/KeepBinaryTest.java    |   3 -
 .../apache/ignite/ml/composition/BaggingTest.java  |   9 +-
 .../ml/composition/boosting/GDBTrainerTest.java    |  10 +-
 .../impl/cache/CacheBasedDatasetBuilderTest.java   |   3 -
 .../dataset/impl/cache/CacheBasedDatasetTest.java  |   3 -
 .../ml/environment/LearningEnvironmentTest.java    |   6 +-
 .../apache/ignite/ml/knn/LabeledVectorSetTest.java |   3 +-
 .../discrete/DiscreteNaiveBayesTrainerTest.java    |  11 +-
 .../ignite/ml/nn/MLPTrainerIntegrationTest.java    |   3 -
 .../MLPTrainerMnistIntegrationTest.java            |   3 -
 .../cursor/CacheBasedLabelPairCursorTest.java      |   3 -
 .../selection/scoring/evaluator/EvaluatorTest.java |   3 -
 ...onTreeClassificationTrainerIntegrationTest.java |   3 -
 ...cisionTreeRegressionTrainerIntegrationTest.java |   3 -
 .../DecisionTreeMNISTIntegrationTest.java          |   3 -
 .../util/generators/DataStreamGeneratorTest.java   |  12 +-
 .../ignite/stream/mqtt/IgniteMqttStreamerTest.java |   3 -
 .../protocols/http/jetty/RestSetupSimpleTest.java  |   3 -
 .../stream/rocketmq/RocketMQStreamerTest.java      |   3 -
 .../processors/schedule/GridScheduleSelfTest.java  |   3 -
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java       |   3 -
 .../spark/JavaStandaloneIgniteRDDSelfTest.java     |   3 -
 .../springdata/IgniteSpringDataCrudSelfTest.java   |   3 -
 .../IgniteSpringDataQueriesSelfTest.java           |   3 -
 .../springdata/IgniteSpringDataCrudSelfTest.java   |   3 -
 .../IgniteSpringDataQueriesSelfTest.java           |   3 -
 .../spring/GridSpringCacheManagerAbstractTest.java |   3 -
 .../GridSpringCacheManagerMultiJvmSelfTest.java    |   3 -
 .../SpringCacheManagerContextInjectionTest.java    |   3 -
 .../ignite/cache/spring/SpringCacheTest.java       |   3 -
 .../jdbc/CacheJdbcBlobStoreFactorySelfTest.java    |   3 -
 .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java    |   3 -
 .../SpringEncryptedCacheRestartTest.java           |   3 -
 .../ignite/internal/GridFactorySelfTest.java       |   3 -
 .../GridSpringBeanSerializationSelfTest.java       |  10 +-
 .../internal/IgniteDynamicCacheConfigTest.java     |   3 -
 .../ignite/internal/IgniteSpringBeanTest.java      |   3 -
 .../resource/GridLoggerInjectionSelfTest.java      |   3 -
 .../resource/GridResourceProcessorSelfTest.java    |   3 -
 .../resource/GridServiceInjectionSelfTest.java     |   3 -
 .../GridSpringResourceInjectionSelfTest.java       |   3 -
 .../GridTransformSpringInjectionSelfTest.java      |   3 -
 .../p2p/GridP2PUserVersionChangeSelfTest.java      |   3 -
 .../spring/IgniteExcludeInConfigurationTest.java   |   3 -
 .../IgniteStartFromStreamConfigurationTest.java    |   3 -
 .../GridServiceInjectionSpringResourceTest.java    |   3 -
 ...gniteSpringBeanSpringResourceInjectionTest.java |   3 -
 .../GridSpringTransactionManagerAbstractTest.java  |   3 -
 ...ringTransactionManagerContextInjectionTest.java |   3 -
 .../internal/IgniteNodeStartUtilsSelfTest.java     |   3 -
 .../IgniteProjectionStartStopRestartSelfTest.java  |   3 -
 .../stream/storm/StormIgniteStreamerSelfTest.java  |   3 -
 .../GridTaskUriDeploymentDeadlockSelfTest.java     |   3 -
 .../apache/ignite/p2p/GridP2PDisabledSelfTest.java |   3 -
 ...DeploymentClassLoaderMultiThreadedSelfTest.java |   3 -
 .../uri/GridUriDeploymentClassLoaderSelfTest.java  |   3 -
 ...idUriDeploymentClassloaderRegisterSelfTest.java |   3 -
 .../uri/GridUriDeploymentConfigSelfTest.java       |   3 -
 .../GridUriDeploymentFileProcessorSelfTest.java    |   3 -
 .../uri/GridUriDeploymentMd5CheckSelfTest.java     |   3 -
 ...DeploymentMultiScannersErrorThrottlingTest.java |   3 -
 .../GridUriDeploymentMultiScannersSelfTest.java    |   3 -
 .../uri/GridUriDeploymentSimpleSelfTest.java       |   3 -
 .../scanners/file/GridFileDeploymentSelfTest.java  |   3 -
 .../file/GridFileDeploymentUndeploySelfTest.java   |   3 -
 .../scanners/http/GridHttpDeploymentSelfTest.java  |   3 -
 .../org/apache/ignite/tools/GridToolsSelfTest.java |   3 -
 .../form-field/showValidationError.directive.ts    |  17 +-
 .../web-console-sidebar-navigation/style.scss      |   4 -
 .../internal/websession/WebSessionSelfTest.java    |   3 -
 .../yarn/IgniteApplicationMasterSelfTest.java      |   3 -
 .../stream/zeromq/IgniteZeroMqStreamerTest.java    |   3 -
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java     |   3 -
 ...iteCacheEntryListenerWithZkDiscoAtomicTest.java |   3 -
 .../ZookeeperDiscoverySuitePreprocessorTest.java   |   3 -
 .../discovery/zk/internal/ZookeeperClientTest.java |   3 -
 .../ZookeeperDiscoverySpiSaslFailedAuthTest.java   |   3 -
 ...ookeeperDiscoverySpiSaslSuccessfulAuthTest.java |   3 -
 2169 files changed, 3150 insertions(+), 7596 deletions(-)
 create mode 100644 examples/README.md
 copy examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/{LinearRegressionFromSparkExample.java => KMeansFromSparkExample.java} (76%)
 copy examples/src/main/resources/models/spark/serialized/{svm/metadata => kmeans/data}/._SUCCESS.crc (100%)
 create mode 100644 examples/src/main/resources/models/spark/serialized/kmeans/data/.part-00000-e1f2c475-c65a-4b9e-879e-de4afd4f65bc-c000.snappy.parquet.crc
 copy examples/src/main/resources/models/spark/serialized/{svm/metadata => kmeans/data}/_SUCCESS (100%)
 create mode 100644 examples/src/main/resources/models/spark/serialized/kmeans/data/part-00000-e1f2c475-c65a-4b9e-879e-de4afd4f65bc-c000.snappy.parquet
 copy examples/src/main/resources/models/spark/serialized/{svm => kmeans}/metadata/._SUCCESS.crc (100%)
 create mode 100644 examples/src/main/resources/models/spark/serialized/kmeans/metadata/.part-00000.crc
 copy examples/src/main/resources/models/spark/serialized/{svm => kmeans}/metadata/_SUCCESS (100%)
 create mode 100644 examples/src/main/resources/models/spark/serialized/kmeans/metadata/part-00000
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/ConsistentIdImplicitlyExplicitlyTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTestWithAssumption.java
 create mode 100644 modules/ml/src/main/java/org/apache/ignite/ml/trainers/FeatureLabelExtractor.java


[ignite] 01/01: Merge branch 'master' into ignite-11155

Posted by dp...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

dpavlov pushed a commit to branch ignite-11155
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 71f567fbc016e114521565e40e1ba5636903143e
Merge: 0f573de 2a5c3d3
Author: Dmitriy Pavlov <dp...@apache.org>
AuthorDate: Thu Jan 31 16:03:47 2019 +0300

    Merge branch 'master' into ignite-11155

 examples/README.md                                 |  30 ++
 examples/pom-standalone.xml                        |  45 ++
 .../spark/modelparser/KMeansFromSparkExample.java  |  90 ++++
 .../spark/serialized/kmeans/data/._SUCCESS.crc     | Bin 0 -> 8 bytes
 ...-4b9e-879e-de4afd4f65bc-c000.snappy.parquet.crc | Bin 0 -> 24 bytes
 .../models/spark/serialized/kmeans/data/_SUCCESS   |   0
 ...c65a-4b9e-879e-de4afd4f65bc-c000.snappy.parquet | Bin 0 -> 1622 bytes
 .../spark/serialized/kmeans/metadata/._SUCCESS.crc | Bin 0 -> 8 bytes
 .../serialized/kmeans/metadata/.part-00000.crc     | Bin 0 -> 12 bytes
 .../spark/serialized/kmeans/metadata/_SUCCESS      |   0
 .../spark/serialized/kmeans/metadata/part-00000    |   1 +
 .../org/apache/ignite/gridify/AbstractAopTest.java |   3 -
 .../apache/ignite/gridify/BasicAopSelfTest.java    |   3 -
 .../GridifySetToXXXNonSpringAopSelfTest.java       |   3 -
 .../gridify/GridifySetToXXXSpringAopSelfTest.java  |   3 -
 .../gridify/hierarchy/GridifyHierarchyTest.java    |   3 -
 .../optimized/OptimizedMarshallerAopTest.java      |   3 -
 .../org/apache/ignite/p2p/P2PGridifySelfTest.java  |   3 -
 .../direct/singlesplit/SingleSplitsLoadTest.java   |   3 -
 .../gridify/GridifySingleSplitLoadTest.java        |   3 -
 .../test/gridify/ExternalNonSpringAopSelfTest.java |   3 -
 .../checkpoint/s3/S3CheckpointManagerSelfTest.java |   3 -
 .../s3/S3CheckpointSpiConfigSelfTest.java          |   3 -
 .../spi/checkpoint/s3/S3CheckpointSpiSelfTest.java |   4 +-
 ...eckpointSpiStartStopBucketEndpointSelfTest.java |   3 -
 ...CheckpointSpiStartStopSSEAlgorithmSelfTest.java |   3 -
 .../s3/S3CheckpointSpiStartStopSelfTest.java       |   3 -
 .../checkpoint/s3/S3SessionCheckpointSelfTest.java |   3 -
 .../elb/TcpDiscoveryElbIpFinderSelfTest.java       |   3 -
 .../s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java |   3 -
 ...ryS3IpFinderAwsCredentialsProviderSelfTest.java |   3 -
 ...pDiscoveryS3IpFinderAwsCredentialsSelfTest.java |   3 -
 ...pDiscoveryS3IpFinderBucketEndpointSelfTest.java |   3 -
 .../TcpDiscoveryS3IpFinderKeyPrefixSelfTest.java   |   3 -
 ...TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java |   3 -
 .../ipfinder/s3/client/DummyObjectListingTest.java |   3 -
 .../tcp/ipfinder/s3/client/DummyS3ClientTest.java  |   3 -
 .../AsymmetricKeyEncryptionServiceTest.java        |   3 -
 .../s3/encrypt/AwsKmsEncryptionServiceTest.java    |   3 -
 .../s3/encrypt/MockEncryptionServiceTest.java      |   3 -
 .../encrypt/SymmetricKeyEncryptionServiceTest.java |   3 -
 .../stream/camel/IgniteCamelStreamerTest.java      |   3 -
 .../internal/TaskEventSubjectIdSelfTest.java       |   3 -
 .../ClientAbstractMultiThreadedSelfTest.java       |   3 -
 .../client/ClientDefaultCacheSelfTest.java         |   3 -
 .../client/ClientReconnectionSelfTest.java         |   3 -
 .../internal/client/ClientSslParametersTest.java   |   3 -
 .../client/ClientTcpSslAuthenticationSelfTest.java |   3 -
 ...pTaskExecutionAfterTopologyRestartSelfTest.java |   3 -
 .../client/impl/ClientComputeImplSelfTest.java     |   3 -
 .../client/impl/ClientDataImplSelfTest.java        |   3 -
 .../client/impl/ClientFutureAdapterSelfTest.java   |   3 -
 .../ClientPropertiesConfigurationSelfTest.java     |   3 -
 .../ClientAbstractConnectivitySelfTest.java        |   3 -
 .../ClientAbstractMultiNodeSelfTest.java           |   3 -
 .../client/integration/ClientAbstractSelfTest.java |   3 -
 .../integration/ClientPreferDirectSelfTest.java    |   3 -
 .../client/router/ClientFailedInitSelfTest.java    |   3 -
 .../client/router/RouterFactorySelfTest.java       |   3 -
 .../client/router/TcpRouterAbstractSelfTest.java   |   3 -
 .../internal/client/util/ClientByteUtilsTest.java  |   3 -
 .../client/util/ClientConsistentHashSelfTest.java  |   3 -
 .../client/util/ClientJavaHasherSelfTest.java      |   3 -
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java       |   3 -
 .../internal/jdbc2/JdbcComplexQuerySelfTest.java   |   3 -
 .../internal/jdbc2/JdbcConnectionReopenTest.java   |   3 -
 .../internal/jdbc2/JdbcConnectionSelfTest.java     |   3 -
 .../jdbc2/JdbcDeleteStatementSelfTest.java         |   3 -
 .../jdbc2/JdbcDistributedJoinsQueryTest.java       |   3 -
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java    |   3 -
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java     |   3 -
 .../ignite/internal/jdbc2/JdbcErrorsSelfTest.java  |   3 -
 .../jdbc2/JdbcInsertStatementSelfTest.java         |   3 -
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java    |   3 -
 .../internal/jdbc2/JdbcMergeStatementSelfTest.java |   3 -
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |   3 -
 .../jdbc2/JdbcNoCacheStreamingSelfTest.java        |   3 -
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java     |   3 -
 .../jdbc2/JdbcPreparedStatementSelfTest.java       |   3 -
 .../internal/jdbc2/JdbcResultSetSelfTest.java      |   3 -
 .../ignite/internal/jdbc2/JdbcSpringSelfTest.java  |   3 -
 .../jdbc2/JdbcStatementBatchingSelfTest.java       |   3 -
 .../internal/jdbc2/JdbcStatementSelfTest.java      |   3 -
 .../internal/jdbc2/JdbcStreamingSelfTest.java      |   3 -
 .../jdbc2/JdbcStreamingToPublicCacheTest.java      |   3 -
 .../jdbc2/JdbcUpdateStatementSelfTest.java         |   3 -
 .../rest/ChangeStateCommandHandlerTest.java        |   3 -
 .../rest/ClientMemcachedProtocolSelfTest.java      |   3 -
 .../rest/JettyRestProcessorAbstractSelfTest.java   |   3 -
 ...ttyRestProcessorAuthenticationAbstractTest.java |   3 -
 ...stProcessorAuthenticationWithTokenSelfTest.java |   3 -
 .../rest/JettyRestProcessorBaselineSelfTest.java   |  13 +-
 .../rest/JettyRestProcessorGetAllAsArrayTest.java  |   3 -
 .../rest/JettyRestProcessorSignedSelfTest.java     |   3 -
 .../rest/RestBinaryProtocolSelfTest.java           |   3 -
 .../rest/RestMemcacheProtocolSelfTest.java         |   3 -
 .../rest/RestProcessorMultiStartSelfTest.java      |   3 -
 .../rest/RestProcessorStartSelfTest.java           |   3 -
 .../rest/TaskCommandHandlerSelfTest.java           |   3 -
 .../rest/TcpRestUnmarshalVulnerabilityTest.java    |   3 -
 .../rest/protocols/tcp/TcpRestParserSelfTest.java  |   3 -
 .../tcp/redis/RedisProtocolConnectSelfTest.java    |   3 -
 .../tcp/redis/RedisProtocolServerSelfTest.java     |   3 -
 ...ProtocolStringAtomicDatastructuresSelfTest.java |   3 -
 .../tcp/redis/RedisProtocolStringSelfTest.java     |   3 -
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java      |   3 -
 .../apache/ignite/jdbc/JdbcConnectionSelfTest.java |   3 -
 .../apache/ignite/jdbc/JdbcEmptyCacheSelfTest.java |   3 -
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |   3 -
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java       |   3 -
 .../apache/ignite/jdbc/JdbcMetadataSelfTest.java   |   3 -
 .../apache/ignite/jdbc/JdbcNoDefaultCacheTest.java |   3 -
 .../ignite/jdbc/JdbcPojoLegacyQuerySelfTest.java   |   3 -
 .../apache/ignite/jdbc/JdbcPojoQuerySelfTest.java  |   3 -
 .../ignite/jdbc/JdbcPreparedStatementSelfTest.java |   3 -
 .../apache/ignite/jdbc/JdbcResultSetSelfTest.java  |   3 -
 .../apache/ignite/jdbc/JdbcStatementSelfTest.java  |   3 -
 .../ignite/jdbc/JdbcThinMetadataSqlMatchTest.java  |   5 +-
 .../ignite/jdbc/JdbcVersionMismatchSelfTest.java   |   3 -
 .../JdbcThinAuthenticateConnectionSelfTest.java    |   3 -
 .../thin/JdbcThinAutoCloseServerCursorTest.java    |   3 -
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java    |   3 -
 .../thin/JdbcThinBulkLoadAbstractSelfTest.java     |   3 -
 .../JdbcThinComplexDmlDdlCustomSchemaSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinComplexDmlDdlSelfTest.java   |   3 -
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java    |   3 -
 .../JdbcThinConnectionMultipleAddressesTest.java   |   3 -
 .../JdbcThinConnectionMvccEnabledSelfTest.java     |   3 -
 .../jdbc/thin/JdbcThinConnectionSSLTest.java       |   3 -
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |   3 -
 .../thin/JdbcThinConnectionTimeoutSelfTest.java    |   5 +-
 .../jdbc/thin/JdbcThinDataSourceSelfTest.java      |   3 -
 .../jdbc/thin/JdbcThinDeleteStatementSelfTest.java |   3 -
 .../thin/JdbcThinDynamicIndexAbstractSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java      |   3 -
 .../ignite/jdbc/thin/JdbcThinErrorsSelfTest.java   |   3 -
 .../jdbc/thin/JdbcThinInsertStatementSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinLocalQueriesSelfTest.java    |   3 -
 .../jdbc/thin/JdbcThinMergeStatementSelfTest.java  |   3 -
 .../thin/JdbcThinMetadataPrimaryKeysSelfTest.java  |   3 -
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |   3 -
 .../thin/JdbcThinMissingLongArrayResultsTest.java  |   3 -
 .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java     |   3 -
 .../thin/JdbcThinPreparedStatementSelfTest.java    |   3 -
 .../jdbc/thin/JdbcThinResultSetSelfTest.java       |   3 -
 .../ignite/jdbc/thin/JdbcThinSchemaCaseTest.java   |   3 -
 .../jdbc/thin/JdbcThinSelectAfterAlterTable.java   |   3 -
 .../jdbc/thin/JdbcThinStatementCancelSelfTest.java |   5 +-
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |   3 -
 .../thin/JdbcThinStatementTimeoutSelfTest.java     |   5 +-
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |   3 -
 .../apache/ignite/jdbc/thin/JdbcThinTcpIoTest.java |   3 -
 ...dbcThinTransactionsAbstractComplexSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinTransactionsSelfTest.java    |   3 -
 ...dbcThinTransactionsWithMvccEnabledSelfTest.java |   3 -
 .../jdbc/thin/JdbcThinUpdateStatementSelfTest.java |   3 -
 ...nsactionFinishOnDeactivatedClusterSelfTest.java |   3 -
 .../client/ClientMarshallerBenchmarkTest.java      |   3 -
 .../loadtests/client/ClientTcpSslLoadTest.java     |   3 -
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |   3 -
 .../compatibility/PdsWithTtlCompatibilityTest.java |   3 -
 .../persistence/FoldersReuseCompatibilityTest.java |   3 -
 .../IgnitePKIndexesMigrationToUnwrapPkTest.java    |   3 -
 ...gratingToWalV2SerializerWithCompactionTest.java |   3 -
 .../PersistenceBasicCompatibilityTest.java         |   3 -
 .../compress/CompressionConfigurationTest.java     |   3 -
 .../compress/CompressionProcessorTest.java         |   3 -
 .../DiskPageCompressionIntegrationTest.java        |   3 -
 .../org/apache/ignite/IgniteSystemProperties.java  |   8 +
 .../org/apache/ignite/internal/IgnitionEx.java     |   6 +
 .../processors/cache/GridCacheDeployable.java      |   2 +-
 .../processors/cache/GridCacheEntryEx.java         |   8 +-
 .../processors/cache/GridCacheMapEntry.java        |  14 +-
 .../internal/processors/cache/GridCacheUtils.java  |   2 +-
 .../cache/IgniteCacheOffheapManager.java           |   8 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |  26 +-
 .../dht/GridDhtTransactionalCacheAdapter.java      |   3 +-
 .../dht/GridDhtTxAbstractEnlistFuture.java         |  11 +-
 .../distributed/dht/GridDhtTxEnlistFuture.java     |  11 +-
 .../dht/GridDhtTxQueryAbstractEnlistFuture.java    |   3 +-
 .../dht/GridDhtTxQueryEnlistRequest.java           |  32 +-
 .../dht/GridDhtTxQueryFirstEnlistRequest.java      |   5 -
 .../cache/distributed/dht/GridInvokeValue.java     |  68 ++-
 .../cache/distributed/near/GridNearGetFuture.java  |   6 +
 .../distributed/near/GridNearTxEnlistFuture.java   |  12 +-
 .../distributed/near/GridNearTxEnlistRequest.java  | 108 +++--
 .../distributed/near/GridNearTxEnlistResponse.java |   2 +-
 .../cache/distributed/near/GridNearTxLocal.java    |  15 +-
 .../cache/persistence/GridCacheOffheapManager.java |   5 +-
 .../cache/transactions/IgniteTxHandler.java        |   1 +
 .../processors/query/GridRunningQueryInfo.java     |  28 +-
 .../internal/processors/query/QueryUtils.java      |  11 +
 .../processors/query/RunningQueryManager.java      |  13 +-
 .../internal/visor/baseline/VisorBaselineTask.java |  11 +-
 .../ignite/GridCacheAffinityBackupsSelfTest.java   |   3 -
 .../apache/ignite/IgniteCacheAffinitySelfTest.java |   3 -
 ...gniteCacheEntryProcessorSequentialCallTest.java |   3 -
 .../ignite/cache/IgniteWarmupClosureSelfTest.java  |   3 -
 .../apache/ignite/cache/LargeEntryUpdateTest.java  |   3 -
 .../ignite/cache/ResetLostPartitionTest.java       |   3 -
 .../affinity/AbstractAffinityFunctionSelfTest.java |   3 -
 .../cache/affinity/AffinityClientNodeSelfTest.java |   3 -
 .../affinity/AffinityDistributionLoggingTest.java  |   3 -
 ...finityFunctionBackupFilterAbstractSelfTest.java |   3 -
 ...tyFunctionExcludeNeighborsAbstractSelfTest.java |   3 -
 .../cache/affinity/AffinityHistoryCleanupTest.java |   3 -
 .../affinity/local/LocalAffinityFunctionTest.java  |   3 -
 .../RendezvousAffinityFunctionSimpleBenchmark.java |   3 -
 ...nerRWThroughDisabledTransactionalCacheTest.java |  17 +-
 .../cache/store/CacheStoreReadFromBackupTest.java  |   3 -
 .../CacheStoreSessionListenerAbstractSelfTest.java |   3 -
 ...CacheStoreSessionListenerLifecycleSelfTest.java |  13 +-
 ...stenerReadWriteThroughDisabledAbstractTest.java |   3 -
 ...StoreSessionListenerWriteBehindEnabledTest.java |  19 +-
 .../cache/store/CacheStoreWriteErrorTest.java      |   3 -
 .../CacheTransactionalStoreReadFromBackupTest.java |   2 +-
 .../store/GridCacheBalancingStoreSelfTest.java     |   3 -
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java     |   7 +-
 .../ignite/cache/store/GridStoreLoadCacheTest.java |   3 -
 .../store/IgniteCacheExpiryStoreLoadSelfTest.java  |   3 -
 .../store/StoreResourceInjectionSelfTest.java      |   3 -
 .../jdbc/CacheJdbcPojoStoreAbstractSelfTest.java   |   7 +-
 ...CacheJdbcPojoStoreBinaryMarshallerSelfTest.java |   3 -
 .../cache/store/jdbc/CacheJdbcPojoStoreTest.java   |   3 -
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |   3 -
 ...acheJdbcStoreAbstractMultithreadedSelfTest.java |   3 -
 .../CacheJdbcStoreSessionListenerSelfTest.java     |  12 +-
 ...ridCacheJdbcBlobStoreMultithreadedSelfTest.java |   7 +-
 .../jdbc/JdbcTypesDefaultTransformerTest.java      |   3 -
 .../apache/ignite/client/SslParametersTest.java    |   3 -
 .../failure/FailureHandlerTriggeredTest.java       |   3 -
 .../failure/FailureHandlingConfigurationTest.java  |   3 -
 .../ignite/failure/IoomFailureHandlerTest.java     |   3 -
 .../ignite/failure/OomFailureHandlerTest.java      |   3 -
 .../ignite/failure/StopNodeFailureHandlerTest.java |   3 -
 .../failure/StopNodeOrHaltFailureHandlerTest.java  |   3 -
 .../ignite/failure/SystemWorkersBlockingTest.java  |   3 -
 .../failure/SystemWorkersTerminationTest.java      |   3 -
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java    |   3 -
 .../ignite/igfs/IgfsFragmentizerSelfTest.java      |   3 -
 .../igfs/IgfsFragmentizerTopologySelfTest.java     |   3 -
 .../org/apache/ignite/igfs/IgfsPathSelfTest.java   |   3 -
 .../ClusterBaselineNodesMetricsSelfTest.java       |   3 -
 .../ignite/internal/ClusterGroupAbstractTest.java  |   3 -
 .../ignite/internal/ClusterGroupHostsSelfTest.java |   3 -
 .../ignite/internal/ClusterGroupSelfTest.java      |   3 -
 .../ignite/internal/ClusterMetricsSelfTest.java    |   3 -
 .../internal/ClusterNodeMetricsSelfTest.java       |   3 -
 .../internal/ClusterNodeMetricsUpdateTest.java     |   3 -
 .../ComputeJobCancelWithServiceSelfTest.java       |   3 -
 .../ConsistentIdImplicitlyExplicitlyTest.java      | 186 +++++++++
 .../ignite/internal/GridAffinityMappedTest.java    |   3 -
 .../internal/GridAffinityNoCacheSelfTest.java      |   3 -
 .../ignite/internal/GridAffinityP2PSelfTest.java   |   3 -
 .../ignite/internal/GridAffinitySelfTest.java      |   3 -
 .../GridAlwaysFailoverSpiFailSelfTest.java         |  31 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |   3 -
 .../internal/GridCancelOnGridStopSelfTest.java     |   3 -
 .../internal/GridCancelUnusedJobSelfTest.java      |   3 -
 .../internal/GridCancelledJobsMetricsSelfTest.java |   3 -
 .../internal/GridCollisionJobsContextSelfTest.java |   3 -
 .../ignite/internal/GridCommunicationSelfTest.java |   3 -
 ...idComputationBinarylizableClosuresSelfTest.java |   3 -
 .../GridContinuousJobAnnotationSelfTest.java       |   3 -
 .../GridContinuousJobSiblingsSelfTest.java         |   3 -
 .../internal/GridContinuousTaskSelfTest.java       |   3 -
 .../GridDeploymentMultiThreadedSelfTest.java       |   3 -
 .../ignite/internal/GridDeploymentSelfTest.java    |   3 -
 .../internal/GridDiscoveryEventSelfTest.java       |   3 -
 .../ignite/internal/GridDiscoverySelfTest.java     |   3 -
 .../GridEventStorageCheckAllEventsSelfTest.java    |   3 -
 .../GridEventStorageDefaultExceptionTest.java      |   3 -
 ...idEventStorageRuntimeConfigurationSelfTest.java |   3 -
 .../ignite/internal/GridEventStorageSelfTest.java  |   3 -
 .../GridFailFastNodeFailureDetectionSelfTest.java  |   3 -
 .../GridFailedInputParametersSelfTest.java         |   3 -
 .../GridFailoverCustomTopologySelfTest.java        |   3 -
 .../ignite/internal/GridFailoverSelfTest.java      |   3 -
 .../GridFailoverTaskWithPredicateSelfTest.java     |   3 -
 .../internal/GridFailoverTopologySelfTest.java     |   3 -
 .../ignite/internal/GridGetOrStartSelfTest.java    |   3 -
 .../ignite/internal/GridHomePathSelfTest.java      |   3 -
 .../internal/GridJobCheckpointCleanupSelfTest.java |   3 -
 .../internal/GridJobCollisionCancelSelfTest.java   |   3 -
 .../ignite/internal/GridJobContextSelfTest.java    |   3 -
 .../internal/GridJobMasterLeaveAwareSelfTest.java  |   3 -
 .../internal/GridJobServicesAddNodeTest.java       |   3 -
 .../ignite/internal/GridJobStealingSelfTest.java   |   3 -
 .../GridJobStealingZeroActiveJobsSelfTest.java     |   3 -
 .../ignite/internal/GridJobSubjectIdSelfTest.java  |   3 -
 .../GridKernalConcurrentAccessStopSelfTest.java    |   3 -
 .../ignite/internal/GridLifecycleBeanSelfTest.java |   3 -
 .../ignite/internal/GridListenActorSelfTest.java   |   3 -
 .../internal/GridLocalEventListenerSelfTest.java   |   3 -
 .../org/apache/ignite/internal/GridMBeansTest.java |   3 -
 .../ignite/internal/GridMultipleJobsSelfTest.java  |   3 -
 .../ignite/internal/GridMultipleSpisSelfTest.java  |   3 -
 .../GridMultipleVersionsDeploymentSelfTest.java    |   3 -
 .../GridMultithreadedJobStealingSelfTest.java      |   3 -
 .../ignite/internal/GridNodeFilterSelfTest.java    |  14 +-
 .../ignite/internal/GridNodeLocalSelfTest.java     |   3 -
 .../internal/GridNodeMetricsLogSelfTest.java       |   3 -
 .../internal/GridNodeVisorAttributesSelfTest.java  |   3 -
 .../internal/GridNonHistoryMetricsSelfTest.java    |   3 -
 .../internal/GridProjectionForCachesSelfTest.java  |   3 -
 ...rojectionLocalJobMultipleArgumentsSelfTest.java |   3 -
 .../apache/ignite/internal/GridReduceSelfTest.java |   3 -
 .../ignite/internal/GridReleaseTypeSelfTest.java   |   3 -
 .../internal/GridRuntimeExceptionSelfTest.java     |   3 -
 .../ignite/internal/GridSameVmStartupSelfTest.java |   3 -
 .../org/apache/ignite/internal/GridSelfTest.java   |   3 -
 .../ignite/internal/GridSpiExceptionSelfTest.java  |   3 -
 .../ignite/internal/GridStartStopSelfTest.java     |   3 -
 .../internal/GridStopWithCancelSelfTest.java       |   3 -
 .../ignite/internal/GridStopWithWaitSelfTest.java  |   3 -
 .../internal/GridTaskCancelSingleNodeSelfTest.java |   3 -
 .../internal/GridTaskContinuousMapperSelfTest.java |   3 -
 .../internal/GridTaskExecutionContextSelfTest.java |   3 -
 .../ignite/internal/GridTaskExecutionSelfTest.java |   3 -
 .../internal/GridTaskFailoverAffinityRunTest.java  |   3 -
 .../ignite/internal/GridTaskFailoverSelfTest.java  |   3 -
 .../GridTaskFutureImplStopGridSelfTest.java        |   3 -
 .../GridTaskInstanceExecutionSelfTest.java         |   3 -
 .../internal/GridTaskInstantiationSelfTest.java    |   3 -
 .../ignite/internal/GridTaskJobRejectSelfTest.java |   3 -
 .../ignite/internal/GridTaskListenerSelfTest.java  |   3 -
 .../ignite/internal/GridTaskMapAsyncSelfTest.java  |   3 -
 .../internal/GridTaskNameAnnotationSelfTest.java   |   3 -
 .../internal/GridTaskResultCacheSelfTest.java      |   3 -
 .../ignite/internal/GridTaskTimeoutSelfTest.java   |   3 -
 .../internal/GridTopicExternalizableSelfTest.java  |   3 -
 .../ignite/internal/GridVersionSelfTest.java       |   3 -
 ...ClientConnectAfterCommunicationFailureTest.java |   3 -
 .../IgniteClientReconnectApiExceptionTest.java     |   3 -
 .../internal/IgniteClientReconnectAtomicsTest.java |   3 -
 .../IgniteClientReconnectBinaryContexTest.java     |   3 -
 .../internal/IgniteClientReconnectCacheTest.java   |   3 -
 .../IgniteClientReconnectCollectionsTest.java      |   3 -
 .../internal/IgniteClientReconnectComputeTest.java |   3 -
 ...niteClientReconnectContinuousProcessorTest.java |   3 -
 .../IgniteClientReconnectDelayedSpiTest.java       |   3 -
 .../IgniteClientReconnectDiscoveryStateTest.java   |   3 -
 .../IgniteClientReconnectFailoverTest.java         |   3 -
 .../IgniteClientReconnectServicesTest.java         |   3 -
 .../internal/IgniteClientReconnectStopTest.java    |   3 -
 .../IgniteClientReconnectStreamerTest.java         |   3 -
 .../ignite/internal/IgniteClientRejoinTest.java    |   3 -
 .../IgniteComputeEmptyClusterGroupTest.java        |   3 -
 .../internal/IgniteComputeJobOneThreadTest.java    |   3 -
 .../internal/IgniteComputeResultExceptionTest.java |   3 -
 .../IgniteComputeTopologyExceptionTest.java        |   3 -
 ...niteConcurrentEntryProcessorAccessStopTest.java |   3 -
 ...teConnectionConcurrentReserveAndRemoveTest.java |   3 -
 .../IgniteDiscoveryMassiveNodeFailTest.java        |   3 -
 .../ignite/internal/IgniteExecutorServiceTest.java |   3 -
 .../IgniteExplicitImplicitDeploymentSelfTest.java  |   3 -
 .../internal/IgniteInternalCacheRemoveTest.java    |   3 -
 .../IgniteLocalNodeMapBeforeStartTest.java         |   3 -
 ...iteRoundRobinErrorAfterClientReconnectTest.java |   3 -
 .../IgniteSlowClientDetectionSelfTest.java         |   3 -
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |   3 -
 .../internal/IgniteVersionUtilsSelfTest.java       |   3 -
 .../ignite/internal/LongJVMPauseDetectorTest.java  |   3 -
 .../internal/MarshallerContextLockingSelfTest.java |   7 +-
 .../internal/MemoryLeaksOnRestartNodeTest.java     |   3 -
 .../ignite/internal/TaskNodeRestartTest.java       |   3 -
 .../internal/TransactionMetricsMxBeanImplTest.java |   7 +-
 .../internal/TransactionsMXBeanImplTest.java       |   3 -
 .../internal/VisorManagementEventSelfTest.java     |   3 -
 .../BinaryArrayIdentityResolverSelfTest.java       |   3 -
 .../binary/BinaryBasicIdMapperSelfTest.java        |   3 -
 .../binary/BinaryBasicNameMapperSelfTest.java      |   3 -
 .../BinaryConfigurationConsistencySelfTest.java    |   3 -
 ...inaryConfigurationCustomSerializerSelfTest.java |   3 -
 .../internal/binary/BinaryEnumsSelfTest.java       |   3 -
 .../binary/BinaryFieldExtractionSelfTest.java      |   3 -
 .../binary/BinaryFieldsAbstractSelfTest.java       |   3 -
 .../BinaryFooterOffsetsAbstractSelfTest.java       |   3 -
 .../internal/binary/BinaryMarshallerSelfTest.java  |   3 -
 .../BinaryObjectBuilderAdditionalSelfTest.java     |   3 -
 .../BinaryObjectBuilderDefaultMappersSelfTest.java |   3 -
 .../binary/BinaryObjectExceptionSelfTest.java      |   3 -
 .../binary/BinaryObjectToStringSelfTest.java       |   3 -
 .../binary/BinaryObjectTypeCompatibilityTest.java  |   3 -
 .../BinarySerialiedFieldComparatorSelfTest.java    |   3 -
 .../BinarySimpleNameTestPropertySelfTest.java      |   3 -
 .../ignite/internal/binary/BinaryTreeSelfTest.java |   3 -
 .../binary/GridBinaryAffinityKeySelfTest.java      |   3 -
 .../GridBinaryMarshallerCtxDisabledSelfTest.java   |   3 -
 .../binary/GridBinaryWildcardsSelfTest.java        |   3 -
 ...DefaultBinaryMappersBinaryMetaDataSelfTest.java |   3 -
 .../AbstractBinaryStreamByteOrderSelfTest.java     |   3 -
 .../streams/BinaryAbstractOutputStreamTest.java    |   3 -
 .../encryption/EncryptedCacheBigEntryTest.java     |   3 -
 .../encryption/EncryptedCacheCreateTest.java       |   3 -
 .../encryption/EncryptedCacheDestroyTest.java      |   3 -
 .../encryption/EncryptedCacheGroupCreateTest.java  |   3 -
 .../encryption/EncryptedCacheNodeJoinTest.java     |   3 -
 .../EncryptedCachePreconfiguredRestartTest.java    |   3 -
 .../encryption/EncryptedCacheRestartTest.java      |   3 -
 .../GridManagerLocalMessageListenerSelfTest.java   |   3 -
 .../internal/managers/GridManagerStopSelfTest.java |   3 -
 .../internal/managers/GridNoopManagerSelfTest.java |   3 -
 .../managers/IgniteDiagnosticMessagesTest.java     |   3 -
 .../checkpoint/GridCheckpointManagerSelfTest.java  |   3 -
 .../checkpoint/GridCheckpointTaskSelfTest.java     |   3 -
 .../GridCommunicationManagerListenersSelfTest.java |   3 -
 .../GridCommunicationSendMessageSelfTest.java      |   3 -
 .../communication/GridIoManagerSelfTest.java       |   3 -
 .../IgniteCommunicationBalanceTest.java            |   3 -
 .../communication/IgniteIoTestMessagesTest.java    |   3 -
 .../IgniteVariousConnectionNumberTest.java         |   3 -
 ...loymentRequestOfUnknownClassProcessingTest.java |   3 -
 .../GridDeploymentManagerStopSelfTest.java         |   3 -
 .../GridDeploymentMessageCountSelfTest.java        |   3 -
 .../GridDiscoveryManagerAliveCacheSelfTest.java    |   3 -
 .../GridDiscoveryManagerAttributesSelfTest.java    |   3 -
 .../IgniteTopologyPrintFormatSelfTest.java         |   3 -
 .../events/GridEventStorageManagerSelfTest.java    |   3 -
 .../OptimizedMarshallerNodeFailoverTest.java       |   3 -
 .../optimized/OptimizedMarshallerSelfTest.java     |   3 -
 ...edMarshallerSerialPersistentFieldsSelfTest.java |   3 -
 .../optimized/OptimizedMarshallerTest.java         |   3 -
 .../optimized/OptimizedObjectStreamSelfTest.java   |   3 -
 .../internal/pagemem/impl/PageIdUtilsSelfTest.java |   3 -
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java     |   3 -
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java    |  13 +-
 .../affinity/GridAffinityAssignmentV2Test.java     |   3 -
 ...ridAffinityAssignmentV2TestNoOptimizations.java |   3 -
 .../GridAffinityProcessorAbstractSelfTest.java     |   3 -
 .../GridAffinityProcessorMemoryLeakTest.java       |   3 -
 .../Authentication1kUsersNodeRestartTest.java      |   3 -
 .../AuthenticationConfigurationClusterTest.java    |   3 -
 .../AuthenticationOnNotActiveClusterTest.java      |   3 -
 .../AuthenticationProcessorNPEOnStartTest.java     |   3 -
 .../AuthenticationProcessorNodeRestartTest.java    |   3 -
 .../AuthenticationProcessorSelfTest.java           |   3 -
 .../AtomicCacheAffinityConfigurationTest.java      |   3 -
 ...tadataRegistrationInsideEntryProcessorTest.java |   3 -
 .../cache/CacheAffinityCallSelfTest.java           |   3 -
 .../CacheAtomicSingleMessageCountSelfTest.java     |   3 -
 .../processors/cache/CacheClientStoreSelfTest.java |  13 +-
 .../cache/CacheConcurrentReadThroughTest.java      |  15 +-
 .../cache/CacheConfigurationLeakTest.java          |   3 -
 .../cache/CacheConnectionLeakStoreTxTest.java      |   3 -
 .../cache/CacheDataRegionConfigurationTest.java    |   3 -
 .../cache/CacheDeferredDeleteQueueTest.java        |   3 -
 .../cache/CacheDeferredDeleteSanitySelfTest.java   |   3 -
 .../CacheDhtLocalPartitionAfterRemoveSelfTest.java |   3 -
 .../cache/CacheEntryProcessorCopySelfTest.java     |   3 -
 .../cache/CacheEnumOperationsAbstractTest.java     |   3 -
 .../cache/CacheEventWithTxLabelTest.java           |   3 -
 .../CacheExchangeMessageDuplicatedStateTest.java   |   3 -
 .../cache/CacheFutureExceptionSelfTest.java        |   3 -
 .../cache/CacheGetEntryAbstractTest.java           |   3 -
 ...eGetEntryPessimisticRepeatableReadSelfTest.java |   3 -
 .../processors/cache/CacheGetFromJobTest.java      |   3 -
 .../cache/CacheGetsDistributionAbstractTest.java   |   3 -
 .../CacheGroupLocalConfigurationSelfTest.java      |   3 -
 .../cache/CacheGroupMetricsMBeanTest.java          |   3 -
 .../cache/CacheGroupsMetricsRebalanceTest.java     |   3 -
 ...InterceptorPartitionCounterLocalSanityTest.java |   3 -
 ...ceptorPartitionCounterRandomOperationsTest.java |   3 -
 .../cache/CacheKeepBinaryTransactionTest.java      |   3 -
 .../cache/CacheLocalGetSerializationTest.java      |   3 -
 .../cache/CacheMetricsCacheSizeTest.java           |   3 -
 .../cache/CacheMetricsEntitiesCountTest.java       |   3 -
 .../cache/CacheMetricsForClusterGroupSelfTest.java |   5 +-
 .../processors/cache/CacheMetricsManageTest.java   |   3 -
 .../processors/cache/CacheNamesSelfTest.java       |   3 -
 .../cache/CacheNamesWithSpecialCharactersTest.java |   3 -
 .../cache/CacheNearReaderUpdateTest.java           |  13 +-
 .../CacheNearUpdateTopologyChangeAbstractTest.java |   3 -
 .../cache/CacheNoAffinityExchangeTest.java         |   3 -
 .../cache/CacheOffheapMapEntrySelfTest.java        |   3 -
 .../CacheOptimisticTransactionsWithFilterTest.java |   3 -
 .../cache/CachePutEventListenerErrorSelfTest.java  |   7 +-
 .../processors/cache/CachePutIfAbsentTest.java     |   3 -
 .../CacheReadThroughLocalRestartSelfTest.java      |  16 +-
 .../cache/CacheReadThroughRestartSelfTest.java     |  13 +-
 .../cache/CacheRebalanceConfigValidationTest.java  |   3 -
 .../processors/cache/CacheRebalancingSelfTest.java |   3 -
 .../processors/cache/CacheRemoveAllSelfTest.java   |   3 -
 .../cache/CacheSerializableTransactionsTest.java   |   3 -
 .../cache/CacheStartupInDeploymentModesTest.java   |   3 -
 .../cache/CacheStopAndDestroySelfTest.java         |  15 +-
 ...toreUsageMultinodeDynamicStartAbstractTest.java |   3 -
 ...CacheStoreUsageMultinodeDynamicStartTxTest.java |  12 +-
 ...StoreUsageMultinodeStaticStartAbstractTest.java |   3 -
 .../CacheStoreUsageMultinodeStaticStartTxTest.java |  12 +-
 .../processors/cache/CacheTxFastFinishTest.java    |   3 -
 .../cache/CacheTxNotAllowReadFromBackupTest.java   |   3 -
 .../cache/CacheValidatorMetricsTest.java           |   3 -
 .../processors/cache/ClusterReadOnlyModeTest.java  |   3 -
 .../processors/cache/ClusterStateAbstractTest.java |   3 -
 .../processors/cache/ConcurrentCacheStartTest.java |   3 -
 .../processors/cache/CrossCacheLockTest.java       |  13 +-
 .../cache/CrossCacheTxRandomOperationsTest.java    |  14 +-
 .../EntryVersionConsistencyReadThroughTest.java    |   3 -
 .../GridAbstractCacheInterceptorRebalanceTest.java |   3 -
 .../cache/GridCacheAbstractFailoverSelfTest.java   |   3 -
 .../cache/GridCacheAbstractFailoverTxSelfTest.java |   3 -
 ...dCacheAbstractFullApiMultithreadedSelfTest.java |   3 -
 .../cache/GridCacheAbstractFullApiSelfTest.java    |  20 +-
 .../cache/GridCacheAbstractIteratorsSelfTest.java  |   3 -
 .../cache/GridCacheAbstractLocalStoreSelfTest.java |   3 -
 .../cache/GridCacheAbstractMetricsSelfTest.java    |   3 -
 .../cache/GridCacheAbstractRemoveFailureTest.java  |   3 -
 .../cache/GridCacheAbstractTxReadTest.java         |   3 -
 ...idCacheAbstractUsersAffinityMapperSelfTest.java |   3 -
 .../cache/GridCacheAffinityApiSelfTest.java        |   3 -
 .../cache/GridCacheAffinityMapperSelfTest.java     |   3 -
 .../cache/GridCacheAffinityRoutingSelfTest.java    |   3 -
 .../GridCacheAsyncOperationsLimitSelfTest.java     |   3 -
 ...acheAtomicEntryProcessorDeploymentSelfTest.java |  13 -
 .../cache/GridCacheAtomicMessageCountSelfTest.java |   3 -
 .../cache/GridCacheBasicApiAbstractTest.java       |   3 -
 .../cache/GridCacheBasicStoreAbstractTest.java     |  17 +-
 ...idCacheBasicStoreMultithreadedAbstractTest.java |   3 -
 .../cache/GridCacheClearAllSelfTest.java           |   3 -
 .../cache/GridCacheClearLocallySelfTest.java       |   3 -
 .../processors/cache/GridCacheClearSelfTest.java   |   3 -
 .../GridCacheConcurrentGetCacheOnClientTest.java   |   3 -
 .../cache/GridCacheConcurrentMapSelfTest.java      |   3 -
 .../GridCacheConcurrentTxMultiNodeLoadTest.java    |   3 -
 .../GridCacheConditionalDeploymentSelfTest.java    |   3 -
 .../GridCacheConfigurationConsistencySelfTest.java |   3 -
 .../GridCacheConfigurationValidationSelfTest.java  |   3 -
 .../cache/GridCacheDaemonNodeAbstractSelfTest.java |   3 -
 .../cache/GridCacheDeploymentSelfTest.java         |   3 -
 .../cache/GridCacheEntryMemorySizeSelfTest.java    |   3 -
 .../cache/GridCacheEntryVersionSelfTest.java       |   3 -
 .../cache/GridCacheEvictionEventAbstractTest.java  |  18 +-
 .../cache/GridCacheFinishPartitionsSelfTest.java   |  13 +-
 ...ridCacheFullTextQueryMultithreadedSelfTest.java |   3 -
 .../GridCacheGetAndTransformStoreAbstractTest.java |  21 +-
 .../cache/GridCacheIncrementTransformTest.java     |   3 -
 .../GridCacheInterceptorAbstractSelfTest.java      |  36 +-
 .../cache/GridCacheInterceptorLocalSelfTest.java   |  14 +-
 ...GridCacheInterceptorLocalWithStoreSelfTest.java |  14 +-
 .../cache/GridCacheIteratorPerformanceTest.java    |   3 -
 .../cache/GridCacheKeyCheckSelfTest.java           |   3 -
 .../processors/cache/GridCacheLeakTest.java        |   3 -
 .../cache/GridCacheLifecycleAwareSelfTest.java     |   3 -
 .../GridCacheLocalTxStoreExceptionSelfTest.java    |   4 +-
 .../cache/GridCacheMarshallerTxAbstractTest.java   |   3 -
 .../GridCacheMarshallingNodeJoinSelfTest.java      |  17 +-
 .../GridCacheMissingCommitVersionSelfTest.java     |   3 -
 .../GridCacheMixedPartitionExchangeSelfTest.java   |   3 -
 .../cache/GridCacheMultiUpdateLockSelfTest.java    |   3 -
 .../GridCacheMultinodeUpdateAbstractSelfTest.java  |   3 -
 ...ultinodeUpdateNearEnabledNoBackupsSelfTest.java |   3 -
 ...ridCacheMultinodeUpdateNearEnabledSelfTest.java |  13 +-
 .../processors/cache/GridCacheMvccFlagsTest.java   |   3 -
 .../cache/GridCacheMvccManagerSelfTest.java        |   3 -
 .../cache/GridCacheMvccPartitionedSelfTest.java    |   3 -
 .../processors/cache/GridCacheMvccSelfTest.java    |   3 -
 .../cache/GridCacheNestedTxAbstractTest.java       |   3 -
 .../cache/GridCacheObjectToStringSelfTest.java     |   7 +-
 ...OffHeapMultiThreadedUpdateAbstractSelfTest.java |   3 -
 ...ridCacheOffHeapMultiThreadedUpdateSelfTest.java |   3 -
 .../cache/GridCacheOffheapUpdateSelfTest.java      |   3 -
 .../cache/GridCacheOnCopyFlagAbstractSelfTest.java |   3 -
 .../cache/GridCacheOrderedPreloadingSelfTest.java  |   3 -
 .../cache/GridCacheP2PUndeploySelfTest.java        |   3 -
 .../cache/GridCachePartitionedGetSelfTest.java     |   3 -
 ...CachePartitionedProjectionAffinitySelfTest.java |   3 -
 .../cache/GridCachePartitionedWritesTest.java      |   3 -
 .../GridCachePreloadingEvictionsSelfTest.java      |   3 -
 .../cache/GridCachePutAllFailoverSelfTest.java     |   3 -
 .../GridCacheQueryIndexingDisabledSelfTest.java    |   3 -
 .../cache/GridCacheQueryInternalKeysSelfTest.java  |   3 -
 .../GridCacheQuerySqlFieldInlineSizeSelfTest.java  |   3 -
 .../cache/GridCacheReferenceCleanupSelfTest.java   |   3 -
 .../processors/cache/GridCacheReloadSelfTest.java  |  34 +-
 .../GridCacheReplicatedSynchronousCommitTest.java  |   3 -
 .../GridCacheReturnValueTransferSelfTest.java      |   3 -
 .../processors/cache/GridCacheSlowTxWarnTest.java  |   3 -
 .../processors/cache/GridCacheStopSelfTest.java    |   3 -
 .../GridCacheStoreManagerDeserializationTest.java  |  15 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java    |   3 -
 ...idCacheTcpClientDiscoveryMultiThreadedTest.java |   3 -
 .../processors/cache/GridCacheTestEntryEx.java     |   5 +-
 ...dCacheTransactionalAbstractMetricsSelfTest.java |   3 -
 .../cache/GridCacheTtlManagerEvictionSelfTest.java |   3 -
 .../cache/GridCacheTtlManagerLoadTest.java         |   3 -
 .../cache/GridCacheTtlManagerNotificationTest.java |   3 -
 .../cache/GridCacheTtlManagerSelfTest.java         |   7 +-
 .../GridCacheTxPartitionedLocalStoreSelfTest.java  |   6 +-
 .../processors/cache/GridCacheUtilsSelfTest.java   |   3 -
 .../GridCacheValueBytesPreloadingSelfTest.java     |   3 -
 .../GridCacheValueConsistencyAbstractSelfTest.java |   3 -
 .../cache/GridCacheVariableTopologySelfTest.java   |   3 -
 .../cache/GridCacheVersionMultinodeTest.java       |   3 -
 .../processors/cache/GridCacheVersionSelfTest.java |   3 -
 .../cache/GridCacheVersionTopologyChangeTest.java  |   3 -
 ...ataStorageConfigurationConsistencySelfTest.java |   3 -
 .../cache/GridEvictionPolicyMBeansTest.java        |   5 +-
 ...dLocalCacheStoreManagerDeserializationTest.java |   3 -
 .../cache/GridLocalIgniteSerializationTest.java    |   3 -
 ...ridProjectionForCachesOnDaemonNodeSelfTest.java |   3 -
 .../IgniteAbstractDynamicCacheStartFailTest.java   |   3 -
 .../cache/IgniteCacheAbstractStopBusySelfTest.java |   3 -
 .../cache/IgniteCacheAtomicStopBusySelfTest.java   |   3 -
 .../IgniteCacheBinaryEntryProcessorSelfTest.java   |   3 -
 .../IgniteCacheBinaryObjectsScanSelfTest.java      |   3 -
 .../IgniteCacheConfigVariationsFullApiTest.java    |   3 -
 ...gniteCacheConfigurationDefaultTemplateTest.java |   3 -
 .../IgniteCacheConfigurationTemplateTest.java      |   3 -
 .../IgniteCacheContainsKeyAbstractSelfTest.java    |   3 -
 .../cache/IgniteCacheContainsKeyAtomicTest.java    |   3 -
 .../IgniteCacheCopyOnReadDisabledAbstractTest.java |   3 -
 .../cache/IgniteCacheCreateRestartSelfTest.java    |   3 -
 .../cache/IgniteCacheDynamicStopSelfTest.java      |   3 -
 .../IgniteCacheEntryListenerAbstractTest.java      |   7 +-
 ...niteCacheEntryListenerEagerTtlDisabledTest.java |   4 +-
 .../IgniteCacheEntryListenerExpiredEventsTest.java |   3 -
 .../cache/IgniteCacheEntryListenerTxLocalTest.java |   4 +-
 .../cache/IgniteCacheEntryProcessorCallTest.java   |   3 -
 .../IgniteCacheEntryProcessorNodeJoinTest.java     |   3 -
 .../IgniteCacheExpireAndUpdateConsistencyTest.java |   3 -
 .../IgniteCacheGetCustomCollectionsSelfTest.java   |   3 -
 .../processors/cache/IgniteCacheGroupsTest.java    |   4 -
 .../cache/IgniteCacheIncrementTxTest.java          |   3 -
 .../cache/IgniteCacheInvokeAbstractTest.java       |   3 -
 ...IgniteCacheInvokeReadThroughSingleNodeTest.java |   3 -
 .../cache/IgniteCacheInvokeReadThroughTest.java    |   3 -
 .../IgniteCacheLoadRebalanceEvictionSelfTest.java  |   3 -
 .../cache/IgniteCacheManyAsyncOperationsTest.java  |   3 -
 .../cache/IgniteCacheNearLockValueSelfTest.java    |   7 +-
 .../cache/IgniteCacheNoSyncForGetTest.java         |   3 -
 .../cache/IgniteCacheObjectPutSelfTest.java        |   3 -
 .../IgniteCacheP2pUnmarshallingErrorTest.java      |   3 -
 .../IgniteCacheP2pUnmarshallingNearErrorTest.java  |   3 -
 ...iteCacheP2pUnmarshallingRebalanceErrorTest.java |   3 -
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java    |   3 -
 .../cache/IgniteCachePartitionMapUpdateTest.java   |   3 -
 .../cache/IgniteCachePeekModesAbstractTest.java    |   3 -
 .../cache/IgniteCachePutAllRestartTest.java        |   3 -
 .../cache/IgniteCachePutStackOverflowSelfTest.java |   3 -
 .../IgniteCacheReadThroughEvictionSelfTest.java    |   3 -
 .../cache/IgniteCacheReadThroughStoreCallTest.java |  13 +-
 ...IgniteCacheScanPredicateDeploymentSelfTest.java |   3 -
 .../cache/IgniteCacheSerializationSelfTest.java    |   3 -
 .../cache/IgniteCacheStartStopLoadTest.java        |   3 -
 .../processors/cache/IgniteCacheStartTest.java     |   3 -
 .../cache/IgniteCacheStoreCollectionTest.java      |   3 -
 .../cache/IgniteCacheStoreValueAbstractTest.java   |   3 -
 .../IgniteCacheTransactionalStopBusySelfTest.java  |   3 -
 .../cache/IgniteCacheTxCopyOnReadDisabledTest.java |  10 +-
 .../cache/IgniteCacheTxLocalInvokeTest.java        |   4 +-
 .../cache/IgniteCacheTxLocalPeekModesTest.java     |  14 +-
 .../cache/IgniteCacheTxLocalStoreValueTest.java    |  10 +-
 .../IgniteCacheTxNearEnabledStoreValueTest.java    |  10 +-
 .../cache/IgniteCacheTxNearPeekModesTest.java      |  13 +-
 .../cache/IgniteCacheTxPreloadNoWriteTest.java     |   3 -
 .../cache/IgniteCacheTxStoreValueTest.java         |  10 +-
 .../cache/IgniteCachingProviderSelfTest.java       |   3 -
 .../IgniteClientAffinityAssignmentSelfTest.java    |   3 -
 .../IgniteClientCacheInitializationFailTest.java   |   3 -
 .../cache/IgniteClientCacheStartFailoverTest.java  |   3 -
 .../cache/IgniteClusterActivateDeactivateTest.java |   3 -
 ...usterActivateDeactivateTestWithPersistence.java |  13 -
 ...eactivateTestWithPersistenceAndMemoryReuse.java |  27 --
 .../cache/IgniteDaemonNodeMarshallerCacheTest.java |   3 -
 ...gniteDiscoveryDataHandlingInNewClusterTest.java |   3 -
 .../cache/IgniteDynamicCacheAndNodeStop.java       |   3 -
 .../cache/IgniteDynamicCacheFilterTest.java        |   3 -
 .../cache/IgniteDynamicCacheMultinodeTest.java     |   3 -
 ...teDynamicCacheStartCoordinatorFailoverTest.java |   3 -
 ...niteDynamicCacheStartNoExchangeTimeoutTest.java |   3 -
 .../cache/IgniteDynamicCacheStartSelfTest.java     |   3 -
 .../IgniteDynamicCacheStartStopConcurrentTest.java |   3 -
 .../IgniteDynamicCacheWithConfigStartSelfTest.java |   3 -
 .../IgniteDynamicClientCacheStartSelfTest.java     |   3 -
 .../cache/IgniteExchangeFutureHistoryTest.java     |   3 -
 .../IgniteGetNonPlainKeyReadThroughSelfTest.java   |   3 -
 .../cache/IgniteIncompleteCacheObjectSelfTest.java |   3 -
 .../cache/IgniteInternalCacheTypesTest.java        |   3 -
 ...IgniteMarshallerCacheClassNameConflictTest.java |   3 -
 ...hallerCacheClientRequestsMappingOnMissTest.java |   3 -
 ...niteMarshallerCacheConcurrentReadWriteTest.java |   3 -
 .../cache/IgniteMarshallerCacheFSRestoreTest.java  |   3 -
 .../IgniteMvccTxMultiThreadedAbstractTest.java     |   3 -
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |   3 -
 .../cache/IgniteNearClientCacheCloseTest.java      |   3 -
 .../cache/IgniteOnePhaseCommitInvokeTest.java      |   3 -
 .../cache/IgniteOnePhaseCommitNearReadersTest.java |   3 -
 .../cache/IgniteOnePhaseCommitNearSelfTest.java    |   3 -
 .../cache/IgniteOutOfMemoryPropagationTest.java    |   3 -
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |   3 -
 .../cache/IgnitePutAllLargeBatchSelfTest.java      |   7 +-
 ...ePutAllUpdateNonPreloadedPartitionSelfTest.java |   7 +-
 .../IgniteStartCacheInTransactionSelfTest.java     |   5 +-
 .../cache/IgniteStaticCacheStartSelfTest.java      |   3 -
 .../cache/IgniteSystemCacheOnClientTest.java       |   3 -
 .../IgniteTopologyValidatorAbstractCacheTest.java  |   3 -
 ...TopologyValidatorAbstractTxCacheGroupsTest.java |   3 -
 ...IgniteTopologyValidatorAbstractTxCacheTest.java |   3 -
 ...teTopologyValidatorCacheGroupsAbstractTest.java |   3 -
 .../IgniteTopologyValidatorGridSplitCacheTest.java |   3 -
 ...yValidatorNearPartitionedTxCacheGroupsTest.java |   4 +-
 ...opologyValidatorNearPartitionedTxCacheTest.java |   4 +-
 .../cache/IgniteTxConcurrentGetAbstractTest.java   |   3 -
 .../cache/IgniteTxConfigCacheSelfTest.java         |   3 -
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |   9 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java       |   3 -
 .../cache/IgniteTxMultiThreadedAbstractTest.java   |   3 -
 .../cache/IgniteTxReentryAbstractSelfTest.java     |   3 -
 .../cache/IgniteTxSingleThreadedAbstractTest.java  |   3 -
 .../IgniteTxStoreExceptionAbstractSelfTest.java    |   7 +-
 ...nterceptorCacheConfigVariationsFullApiTest.java |   3 -
 .../MarshallerCacheJobRunNodeRestartTest.java      |   3 -
 .../cache/MemoryPolicyConfigValidationTest.java    |   3 -
 ...NonAffinityCoordinatorDynamicStartStopTest.java |   3 -
 ...OffheapCacheMetricsForClusterGroupSelfTest.java |   3 -
 .../PartitionsExchangeCoordinatorFailoverTest.java |   3 -
 ...ionsExchangeOnDiscoveryHistoryOverflowTest.java |   3 -
 .../SetTxTimeoutOnPartitionMapExchangeTest.java    |   3 -
 .../cache/WalModeChangeAbstractSelfTest.java       |   3 -
 .../cache/WalModeChangeAdvancedSelfTest.java       |   3 -
 .../cache/WithKeepBinaryCacheFullApiTest.java      |   3 -
 .../binary/BinaryMetadataUpdatesFlowTest.java      |   3 -
 .../binary/BinaryTxCacheLocalEntriesSelfTest.java  |   3 -
 .../binary/CacheKeepBinaryWithInterceptorTest.java |   3 -
 ...naryAtomicEntryProcessorDeploymentSelfTest.java |   9 +-
 ...eBinaryObjectMetadataExchangeMultinodeTest.java |   3 -
 ...idCacheBinaryObjectUserClassloaderSelfTest.java |   3 -
 ...eBinaryObjectsAbstractDataStreamerSelfTest.java |   3 -
 ...BinaryObjectsAbstractMultiThreadedSelfTest.java |   3 -
 .../GridCacheBinaryObjectsAbstractSelfTest.java    |   3 -
 .../GridCacheBinaryStoreAbstractSelfTest.java      |   3 -
 ...lientNodeBinaryObjectMetadataMultinodeTest.java |   3 -
 ...ridCacheClientNodeBinaryObjectMetadataTest.java |   3 -
 .../GridDataStreamerImplSelfTest.java              |   3 -
 .../IgniteCacheAbstractExecutionContextTest.java   |   3 -
 ...acheAbstractDataStructuresFailoverSelfTest.java |   3 -
 ...stractQueueFailoverDataConsistencySelfTest.java |   3 -
 ...ridCacheAtomicReferenceApiSelfAbstractTest.java |   3 -
 ...dCacheAtomicReferenceMultiNodeAbstractTest.java |   3 -
 .../GridCacheAtomicStampedApiSelfAbstractTest.java |   3 -
 .../GridCacheQueueApiSelfAbstractTest.java         |   3 -
 .../GridCacheQueueCleanupSelfTest.java             |   3 -
 .../GridCacheQueueClientDisconnectTest.java        |   3 -
 .../GridCacheQueueJoinedNodeSelfAbstractTest.java  |   3 -
 .../GridCacheQueueMultiNodeAbstractSelfTest.java   |   3 -
 ...GridCacheQueueMultiNodeConsistencySelfTest.java |   3 -
 ...ridCacheQueueRotativeMultiNodeAbstractTest.java |   3 -
 .../GridCacheSequenceApiSelfAbstractTest.java      |   3 -
 ...GridCacheSequenceMultiNodeAbstractSelfTest.java |   3 -
 .../GridCacheSetAbstractSelfTest.java              |   3 -
 .../GridCacheSetFailoverAbstractSelfTest.java      |   3 -
 .../IgniteAtomicLongApiAbstractSelfTest.java       |   3 -
 .../IgniteClientDataStructuresAbstractTest.java    |   3 -
 .../IgniteCountDownLatchAbstractSelfTest.java      |   3 -
 .../IgniteDataStructureUniqueNameTest.java         |   3 -
 .../IgniteDataStructureWithJobTest.java            |   3 -
 ...iteExchangeLatchManagerCoordinatorFailTest.java |   3 -
 .../datastructures/IgniteLockAbstractSelfTest.java |   3 -
 .../IgniteSemaphoreAbstractSelfTest.java           |   3 -
 .../IgniteSequenceInternalCleanupTest.java         |   3 -
 .../SemaphoreFailoverNoWaitingAcquirerTest.java    |   3 -
 .../SemaphoreFailoverSafeReleasePermitsTest.java   |   3 -
 .../local/IgniteLocalCountDownLatchSelfTest.java   |   3 -
 .../local/IgniteLocalLockSelfTest.java             |   3 -
 .../local/IgniteLocalSemaphoreSelfTest.java        |   3 -
 ...PartitionedAtomicSequenceMultiThreadedTest.java |   3 -
 ...idCachePartitionedAtomicSequenceTxSelfTest.java |   3 -
 ...dCachePartitionedAtomicSetFailoverSelfTest.java |   3 -
 .../GridCachePartitionedNodeRestartTxSelfTest.java |   3 -
 ...chePartitionedQueueCreateMultiNodeSelfTest.java |   3 -
 ...GridCachePartitionedQueueEntryMoveSelfTest.java |   3 -
 .../GridCachePartitionedSetFailoverSelfTest.java   |   3 -
 .../IgnitePartitionedQueueNoBackupsTest.java       |   3 -
 .../IgnitePartitionedSetNoBackupsSelfTest.java     |   3 -
 .../cache/distributed/Cache64kPartitionsTest.java  |   3 -
 .../distributed/CacheAbstractRestartSelfTest.java  |   3 -
 .../cache/distributed/CacheAffinityEarlyTest.java  |   3 -
 .../CacheAsyncOperationsFailoverAbstractTest.java  |   3 -
 .../distributed/CacheAsyncOperationsTest.java      |   3 -
 .../CacheAtomicPrimarySyncBackPressureTest.java    |   3 -
 .../distributed/CacheBaselineTopologyTest.java     |   3 -
 .../cache/distributed/CacheBlockOnGetAllTest.java  |   3 -
 .../distributed/CacheBlockOnReadAbstractTest.java  |   3 -
 .../cache/distributed/CacheBlockOnScanTest.java    |   3 -
 .../distributed/CacheBlockOnSingleGetTest.java     |   3 -
 .../CacheClientsConcurrentStartTest.java           |   3 -
 .../CacheDataLossOnPartitionMoveTest.java          |   3 -
 .../CacheDiscoveryDataConcurrentJoinTest.java      |   3 -
 .../cache/distributed/CacheExchangeMergeTest.java  |   3 -
 .../distributed/CacheGetFutureHangsSelfTest.java   |   3 -
 .../CacheGetInsideLockChangingTopologyTest.java    |   3 -
 .../cache/distributed/CacheGroupsPreloadTest.java  |   3 -
 ...teAffinityAssignmentNodeJoinValidationTest.java |   3 -
 .../CacheLateAffinityAssignmentTest.java           |   3 -
 .../CacheLoadingConcurrentGridStartSelfTest.java   |   3 -
 .../distributed/CacheLockReleaseNodeLeaveTest.java |   3 -
 .../distributed/CacheOperationsInterruptTest.java  |   3 -
 .../distributed/CachePageWriteLockUnlockTest.java  |   3 -
 .../cache/distributed/CacheParallelStartTest.java  |   3 -
 .../cache/distributed/CachePartitionStateTest.java |   3 -
 .../CachePutAllFailoverAbstractTest.java           |   3 -
 .../distributed/CacheRentingStateRepairTest.java   |   3 -
 .../CacheResultIsNotNullOnPartitionLossTest.java   |   3 -
 .../cache/distributed/CacheStartOnJoinTest.java    |   3 -
 .../distributed/CacheTryLockMultithreadedTest.java |   3 -
 .../CacheTxNearUpdateTopologyChangeTest.java       |   4 +-
 ...AbstractDistributedByteArrayValuesSelfTest.java |   3 -
 .../GridCacheAbstractJobExecutionTest.java         |   3 -
 .../GridCacheAbstractNodeRestartSelfTest.java      |   3 -
 .../GridCacheAbstractPrimarySyncSelfTest.java      |   3 -
 .../distributed/GridCacheBasicOpAbstractTest.java  |   3 -
 .../GridCacheClientModesAbstractSelfTest.java      |  20 +-
 .../GridCacheEntrySetAbstractSelfTest.java         |   3 -
 ...idCacheEntrySetIterationPreloadingSelfTest.java |   3 -
 .../distributed/GridCacheEventAbstractTest.java    |  20 +-
 .../distributed/GridCacheLockAbstractTest.java     |  15 +-
 .../distributed/GridCacheMixedModeSelfTest.java    |   3 -
 .../GridCacheMultiNodeAbstractTest.java            |   3 -
 .../GridCacheMultiNodeLockAbstractTest.java        |   3 -
 ...GridCacheMultithreadedFailoverAbstractTest.java |   3 -
 .../GridCacheNodeFailureAbstractTest.java          |   3 -
 ...PartitionEvictionDuringReadThroughSelfTest.java |   3 -
 .../GridCachePartitionNotLoadedEventSelfTest.java  |   3 -
 ...dCachePartitionedReloadAllAbstractSelfTest.java |   7 +-
 .../GridCachePreloadEventsAbstractSelfTest.java    |   3 -
 .../GridCachePreloadRestartAbstractSelfTest.java   |   3 -
 .../GridCacheTransformEventSelfTest.java           |   3 -
 ...naryMetadataUpdateChangingTopologySelfTest.java |   3 -
 .../IgniteBinaryMetadataUpdateNodeRestartTest.java |   3 -
 .../distributed/IgniteCache150ClientsTest.java     |   3 -
 .../IgniteCacheAtomicNodeRestartTest.java          |   3 -
 ...CacheClientMultiNodeUpdateTopologyLockTest.java |   3 -
 .../IgniteCacheClientNodeChangingTopologyTest.java |   3 -
 .../IgniteCacheClientNodeConcurrentStart.java      |   3 -
 ...gniteCacheClientNodePartitionsExchangeTest.java |   3 -
 .../IgniteCacheClientReconnectTest.java            |   3 -
 .../IgniteCacheConnectionRecoveryTest.java         |   3 -
 .../IgniteCacheCreatePutMultiNodeSelfTest.java     |   3 -
 .../distributed/IgniteCacheCreatePutTest.java      |   3 -
 .../IgniteCacheFailedUpdateResponseTest.java       |   3 -
 .../distributed/IgniteCacheGetRestartTest.java     |   3 -
 ...niteCacheGroupsPartitionLossPolicySelfTest.java |   3 -
 .../distributed/IgniteCacheManyClientsTest.java    |   3 -
 .../IgniteCacheMessageRecoveryAbstractTest.java    |   3 -
 ...niteCacheMessageRecoveryIdleConnectionTest.java |   3 -
 .../IgniteCacheMessageWriteTimeoutTest.java        |   3 -
 .../IgniteCacheNearRestartRollbackSelfTest.java    |   3 -
 .../IgniteCacheNodeJoinAbstractTest.java           |   3 -
 .../IgniteCachePartitionLossPolicySelfTest.java    |  13 +-
 .../distributed/IgniteCachePrimarySyncTest.java    |   7 -
 .../IgniteCachePutGetRestartAbstractTest.java      |   3 -
 .../distributed/IgniteCacheReadFromBackupTest.java |   3 -
 .../IgniteCacheServerNodeConcurrentStart.java      |   3 -
 .../IgniteCacheSingleGetMessageTest.java           |   3 -
 .../distributed/IgniteCacheSizeFailoverTest.java   |   3 -
 .../IgniteCacheSystemTransactionsSelfTest.java     |   3 -
 .../distributed/IgniteCacheThreadLocalTxTest.java  |   3 -
 .../distributed/IgniteCacheTxIteratorSelfTest.java |   3 -
 .../IgniteCrossCacheTxStoreSelfTest.java           |   7 +-
 .../IgniteMvccTxTimeoutAbstractTest.java           |   3 -
 .../IgniteOptimisticTxSuspendResumeTest.java       |   3 -
 .../IgnitePessimisticTxSuspendResumeTest.java      |   3 -
 .../IgniteRejectConnectOnNodeStopTest.java         |   3 -
 .../distributed/IgniteTxCachePrimarySyncTest.java  |   3 -
 ...WriteSynchronizationModesMultithreadedTest.java |   3 -
 .../IgniteTxConcurrentRemoveObjectsTest.java       |   3 -
 ...IgniteTxConsistencyRestartAbstractSelfTest.java |   3 -
 .../distributed/IgniteTxGetAfterStopTest.java      |   3 -
 ...teTxOriginatingNodeFailureAbstractSelfTest.java |   3 -
 ...sticOriginatingNodeFailureAbstractSelfTest.java |   3 -
 .../distributed/IgniteTxPreloadAbstractTest.java   |   3 -
 .../IgniteTxRemoveTimeoutObjectsTest.java          |   3 -
 .../distributed/IgniteTxTimeoutAbstractTest.java   |   3 -
 .../dht/CacheGetReadFromBackupFailoverTest.java    |   3 -
 .../CachePartitionPartialCountersMapSelfTest.java  |   3 -
 ...ractPartitionedOnlyByteArrayValuesSelfTest.java |   3 -
 ...CacheAbstractTransformWriteThroughSelfTest.java |  16 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java        |   3 -
 .../dht/GridCacheAtomicNearCacheSelfTest.java      |   3 -
 .../dht/GridCacheColocatedDebugTest.java           |   3 -
 ...acheColocatedOptimisticTransactionSelfTest.java |   3 -
 .../dht/GridCacheColocatedTxExceptionSelfTest.java |  60 ++-
 .../distributed/dht/GridCacheDhtEntrySelfTest.java |   3 -
 .../GridCacheDhtEvictionNearReadersSelfTest.java   |   3 -
 .../dht/GridCacheDhtEvictionsDisabledSelfTest.java |   3 -
 .../dht/GridCacheDhtMappingSelfTest.java           |   3 -
 .../dht/GridCacheDhtMultiBackupTest.java           |   3 -
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java    |   3 -
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java    |   3 -
 .../dht/GridCacheDhtPreloadDisabledSelfTest.java   |   3 -
 .../dht/GridCacheDhtPreloadMessageCountTest.java   |   3 -
 .../GridCacheDhtPreloadMultiThreadedSelfTest.java  |   3 -
 .../dht/GridCacheDhtPreloadPerformanceTest.java    |   3 -
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |   3 -
 .../dht/GridCacheDhtPreloadSelfTest.java           |   3 -
 .../dht/GridCacheDhtPreloadStartStopSelfTest.java  |   3 -
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java     |   3 -
 .../distributed/dht/GridCacheGlobalLoadTest.java   |   5 +-
 ...idCachePartitionedNearDisabledLockSelfTest.java |   3 -
 ...achePartitionedNearDisabledMetricsSelfTest.java |   3 -
 ...GridCachePartitionedTopologyChangeSelfTest.java |   3 -
 ...artitionedTxOriginatingNodeFailureSelfTest.java |   3 -
 .../GridCachePartitionedUnloadEventsSelfTest.java  |   3 -
 .../GridCachePartitionsStateValidationTest.java    |   3 -
 .../GridCachePartitionsStateValidatorSelfTest.java |   3 -
 .../dht/GridCacheTxNodeFailureSelfTest.java        |   3 -
 .../IgniteAtomicLongChangingTopologySelfTest.java  |   3 -
 .../dht/IgniteCacheClearDuringRebalanceTest.java   |   3 -
 .../dht/IgniteCacheCommitDelayTxRecoveryTest.java  |   3 -
 .../dht/IgniteCacheConcurrentPutGetRemove.java     |   3 -
 .../dht/IgniteCacheCrossCacheTxFailoverTest.java   |   3 -
 .../dht/IgniteCacheLockFailoverSelfTest.java       |  13 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java        |  13 +-
 ...hePartitionedBackupNodeFailureRecoveryTest.java |   3 -
 ...achePrimaryNodeFailureRecoveryAbstractTest.java |   3 -
 .../dht/IgniteCachePutRetryAbstractSelfTest.java   |   3 -
 .../dht/IgniteCachePutRetryAtomicSelfTest.java     |   3 -
 .../IgniteCachePutRetryTransactionalSelfTest.java  |   3 -
 .../dht/IgniteCacheStartWithLoadTest.java          |   3 -
 .../dht/IgniteCacheTxRecoveryRollbackTest.java     |   3 -
 .../dht/IgniteCrossCacheMvccTxSelfTest.java        |   3 -
 .../dht/IgniteCrossCacheTxSelfTest.java            |   3 -
 .../dht/NotMappedPartitionInTxTest.java            |  17 +-
 .../dht/TxRecoveryStoreEnabledTest.java            |   3 -
 .../atomic/AtomicPutAllChangingTopologyTest.java   |   3 -
 ...acheAtomicInvalidPartitionHandlingSelfTest.java |   3 -
 .../dht/atomic/GridCacheAtomicPreloadSelfTest.java |   3 -
 .../dht/atomic/IgniteCacheAtomicProtocolTest.java  |   3 -
 ...heAtomicClientOnlyMultiNodeFullApiSelfTest.java |   3 -
 ...acheAtomicNearOnlyMultiNodeFullApiSelfTest.java |   3 -
 ...cheAtomicPartitionedTckMetricsSelfTestImpl.java |   3 -
 .../near/GridCacheGetStoreErrorSelfTest.java       |   7 +-
 .../near/GridCacheNearAtomicMetricsSelfTest.java   |   3 -
 .../near/GridCacheNearClientHitTest.java           |   3 -
 .../near/GridCacheNearEvictionSelfTest.java        |   3 -
 .../near/GridCacheNearMetricsSelfTest.java         |   3 -
 .../near/GridCacheNearMultiGetSelfTest.java        |   3 -
 .../near/GridCacheNearMultiNodeSelfTest.java       |  25 +-
 .../near/GridCacheNearOneNodeSelfTest.java         |  15 +-
 .../GridCacheNearOnlyMultiNodeFullApiSelfTest.java |   3 -
 .../near/GridCacheNearOnlySelfTest.java            |   3 -
 .../near/GridCacheNearOnlyTopologySelfTest.java    |   3 -
 .../GridCacheNearPartitionedClearSelfTest.java     |   3 -
 .../near/GridCacheNearReaderPreloadSelfTest.java   |   3 -
 .../near/GridCacheNearReadersSelfTest.java         |   3 -
 .../near/GridCacheNearTxExceptionSelfTest.java     |   4 +-
 .../near/GridCacheNearTxForceKeyTest.java          |   3 -
 .../near/GridCacheNearTxMultiNodeSelfTest.java     |   3 -
 .../near/GridCacheNearTxPreloadSelfTest.java       |  10 +-
 ...nedAffinityExcludeNeighborsPerformanceTest.java |   3 -
 .../near/GridCachePartitionedAffinitySelfTest.java |   3 -
 .../near/GridCachePartitionedBasicOpSelfTest.java  |   3 -
 ...achePartitionedBasicStoreMultiNodeSelfTest.java |  21 +-
 ...titionedClientOnlyNoPrimaryFullApiSelfTest.java |   3 -
 .../near/GridCachePartitionedEvictionSelfTest.java |   3 -
 ...PartitionedExplicitLockNodeFailureSelfTest.java |   3 -
 .../GridCachePartitionedFilteredPutSelfTest.java   |   3 -
 .../GridCachePartitionedHitsAndMissesSelfTest.java |   3 -
 .../GridCachePartitionedLoadCacheSelfTest.java     |   3 -
 .../near/GridCachePartitionedMetricsSelfTest.java  |   6 +-
 ...idCachePartitionedMultiNodeCounterSelfTest.java |   3 -
 .../GridCachePartitionedMultiNodeLockSelfTest.java |   3 -
 ...achePartitionedMultiThreadedPutGetSelfTest.java |   3 -
 ...achePartitionedMvccTxMultiThreadedSelfTest.java |   5 +-
 .../near/GridCachePartitionedNodeRestartTest.java  |   3 -
 ...achePartitionedOptimisticTxNodeRestartTest.java |   3 -
 ...idCachePartitionedPreloadLifecycleSelfTest.java |   3 -
 .../near/GridCachePartitionedStorePutSelfTest.java |   7 +-
 .../GridCachePartitionedTxMultiNodeSelfTest.java   |   3 -
 .../GridCachePartitionedTxSalvageSelfTest.java     |   3 -
 .../near/GridCachePutArrayValueSelfTest.java       |   3 -
 .../GridCacheRendezvousAffinityClientSelfTest.java |   3 -
 .../near/GridNearCacheStoreUpdateTest.java         |   3 -
 .../near/GridPartitionedBackupLoadSelfTest.java    |   3 -
 .../near/IgniteCacheNearOnlyTxTest.java            |  13 +-
 .../near/IgniteCacheNearReadCommittedTest.java     |  13 +-
 .../near/IgniteCacheNearTxRollbackTest.java        |   3 -
 .../near/NearCacheMultithreadedUpdateTest.java     |   3 -
 .../near/NearCachePutAllMultinodeTest.java         |   3 -
 .../distributed/near/NearCacheSyncUpdateTest.java  |   3 -
 .../near/NoneRebalanceModeSelfTest.java            |   3 -
 .../rebalancing/CacheManualRebalancingTest.java    |   3 -
 ...lancingDelayedPartitionMapExchangeSelfTest.java |   3 -
 .../GridCacheRebalancingAsyncSelfTest.java         |   3 -
 .../GridCacheRebalancingCancelTest.java            |   3 -
 .../GridCacheRebalancingOrderingTest.java          |   3 -
 .../GridCacheRebalancingPartitionCountersTest.java |   3 -
 ...dCacheRebalancingPartitionDistributionTest.java |   3 -
 .../GridCacheRebalancingSyncCheckDataTest.java     |   3 -
 .../GridCacheRebalancingSyncSelfTest.java          |   3 -
 ...acheRebalancingUnmarshallingFailedSelfTest.java |   3 -
 .../GridCacheRebalancingWithAsyncClearingTest.java |   3 -
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |   3 -
 .../GridCacheReplicatedLockSelfTest.java           |   3 -
 .../GridCacheReplicatedMetricsSelfTest.java        |   6 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java    |   3 -
 .../GridCacheReplicatedTxExceptionSelfTest.java    |  60 ++-
 .../GridCacheReplicatedTxMultiNodeBasicTest.java   |   3 -
 .../GridCacheSyncReplicatedPreloadSelfTest.java    |   3 -
 .../replicated/GridReplicatedTxPreloadTest.java    |   3 -
 .../IgniteCacheSyncRebalanceModeSelfTest.java      |   3 -
 ...ridCacheReplicatedPreloadLifecycleSelfTest.java |   3 -
 .../GridCacheReplicatedPreloadSelfTest.java        |   3 -
 ...heReplicatedPreloadStartStopEventsSelfTest.java |   3 -
 .../cache/eviction/DhtAndNearEvictionTest.java     |   7 +-
 .../cache/eviction/EvictionAbstractTest.java       |   3 -
 .../EvictionPolicyFactoryAbstractTest.java         |   3 -
 ...CacheConcurrentEvictionConsistencySelfTest.java |   7 +-
 .../GridCacheConcurrentEvictionsSelfTest.java      |   7 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java     |   3 -
 .../GridCacheEmptyEntriesLocalSelfTest.java        |   3 -
 .../GridCacheEmptyEntriesPartitionedSelfTest.java  |   3 -
 .../GridCacheEvictableEntryEqualsSelfTest.java     |   3 -
 .../eviction/GridCacheEvictionFilterSelfTest.java  |   3 -
 .../GridCacheEvictionLockUnlockSelfTest.java       |  11 +-
 .../eviction/GridCacheEvictionTouchSelfTest.java   |   7 +-
 .../lru/LruEvictionPolicyFactorySelfTest.java      |   3 -
 .../eviction/lru/LruEvictionPolicySelfTest.java    |   3 -
 .../lru/LruNearEvictionPolicySelfTest.java         |   3 -
 .../lru/LruNearOnlyNearEvictionPolicySelfTest.java |   3 -
 .../eviction/paged/PageEvictionMetricTest.java     |   3 -
 .../paged/PageEvictionMultinodeAbstractTest.java   |   3 -
 .../PageEvictionPagesRecyclingAndReusingTest.java  |   3 -
 .../paged/PageEvictionReadThroughTest.java         |   3 -
 .../eviction/paged/PageEvictionTouchOrderTest.java |   3 -
 .../PageEvictionWithRebalanceAbstractTest.java     |   3 -
 .../SortedEvictionPolicyPerformanceTest.java       |   3 -
 .../IgniteCacheClientNearCacheExpiryTest.java      |   3 -
 .../IgniteCacheExpiryPolicyAbstractTest.java       |   3 -
 ...niteCacheExpiryPolicyWithStoreAbstractTest.java |   3 -
 .../expiry/IgniteCacheLargeValueExpireTest.java    |   3 -
 ...niteCacheOnlyOneTtlCleanupThreadExistsTest.java |   3 -
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java    |   3 -
 .../IgniteCacheLoadAllAbstractTest.java            |  21 +-
 .../IgniteCacheLoaderWriterAbstractTest.java       |   3 -
 ...IgniteCacheNoLoadPreviousValueAbstractTest.java |   3 -
 .../IgniteCacheNoReadThroughAbstractTest.java      |   3 -
 .../IgniteCacheNoWriteThroughAbstractTest.java     |   3 -
 .../IgniteCacheStoreNodeRestartAbstractTest.java   |   3 -
 .../IgniteCacheStoreSessionAbstractTest.java       |   3 -
 ...teCacheStoreSessionWriteBehindAbstractTest.java |   3 -
 .../integration/IgniteCacheTxLoaderWriterTest.java |  14 +-
 .../integration/IgniteCacheTxLocalLoadAllTest.java |  11 +-
 .../IgniteCacheTxLocalNoLoadPreviousValueTest.java |  14 +-
 .../IgniteCacheTxLocalNoReadThroughTest.java       |  14 +-
 .../IgniteCacheTxLocalNoWriteThroughTest.java      |  14 +-
 ...eCacheTxNearEnabledNoLoadPreviousValueTest.java |  14 +-
 ...IgniteCacheTxNearEnabledNoWriteThroughTest.java |  14 +-
 .../IgniteCacheTxNoLoadPreviousValueTest.java      |  14 +-
 .../IgniteCacheTxNoReadThroughTest.java            |  14 +-
 .../IgniteCacheTxNoWriteThroughTest.java           |  14 +-
 .../integration/IgniteCacheTxStoreSessionTest.java |  17 +-
 ...cheTxStoreSessionWriteBehindCoalescingTest.java |  16 +-
 .../IgniteCacheTxStoreSessionWriteBehindTest.java  |  14 +-
 ...GridCacheAtomicLocalTckMetricsSelfTestImpl.java |   3 -
 .../local/GridCacheLocalBasicApiSelfTest.java      |  12 +-
 .../local/GridCacheLocalBasicStoreSelfTest.java    |  14 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java     |  15 +-
 .../cache/local/GridCacheLocalEventSelfTest.java   |  17 +-
 .../local/GridCacheLocalEvictionEventSelfTest.java |  13 +-
 .../cache/local/GridCacheLocalFullApiSelfTest.java |   3 -
 ...GridCacheLocalGetAndTransformStoreSelfTest.java |  14 +-
 .../local/GridCacheLocalIsolatedNodesSelfTest.java |   3 -
 .../local/GridCacheLocalIteratorsSelfTest.java     |   4 +-
 .../cache/local/GridCacheLocalLoadAllSelfTest.java |  15 +-
 .../cache/local/GridCacheLocalLockSelfTest.java    |  21 +-
 .../cache/local/GridCacheLocalMetricsSelfTest.java |  10 +-
 .../local/GridCacheLocalMultithreadedSelfTest.java |  21 +-
 .../local/GridCacheLocalTxExceptionSelfTest.java   |   4 +-
 .../GridCacheLocalTxMultiThreadedSelfTest.java     |  10 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java    |  10 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java     |  21 +-
 ...heAtomicNearEnabledMultiJvmFullApiSelfTest.java |   3 -
 ...eReplicatedNearOnlyMultiJvmFullApiSelfTest.java |   3 -
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |   3 -
 .../CacheMvccAbstractCoordinatorFailoverTest.java  |   5 -
 .../cache/mvcc/CacheMvccAbstractFeatureTest.java   |   4 +-
 .../cache/mvcc/CacheMvccClusterRestartTest.java    |   3 -
 .../mvcc/CacheMvccConfigurationValidationTest.java |   3 -
 ...eMvccIteratorWithConcurrentTransactionTest.java |   3 -
 ...cLocalEntriesWithConcurrentTransactionTest.java |   3 -
 .../cache/mvcc/CacheMvccOperationChecksTest.java   |  13 -
 ...acheMvccPartitionedCoordinatorFailoverTest.java |   5 -
 .../mvcc/CacheMvccProcessorLazyStartTest.java      |   3 -
 .../cache/mvcc/CacheMvccProcessorTest.java         |   3 -
 .../mvcc/CacheMvccRemoteTxOnNearNodeStartTest.java |   3 -
 ...MvccScanQueryWithConcurrentTransactionTest.java |   3 -
 ...CacheMvccSizeWithConcurrentTransactionTest.java |   3 -
 .../cache/mvcc/CacheMvccTransactionsTest.java      |   5 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |   3 -
 .../processors/cache/mvcc/CacheMvccVacuumTest.java |   3 -
 .../processors/cache/mvcc/MvccCachePeekTest.java   |   3 -
 .../cache/mvcc/MvccUnsupportedTxModesTest.java     |   3 -
 .../persistence/CheckpointReadLockFailureTest.java |   3 -
 ...niteBaselineAffinityTopologyActivationTest.java |   3 -
 .../IgniteDataStorageMetricsSelfTest.java          |   3 -
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java |   3 -
 .../IgnitePdsBinarySortObjectFieldsTest.java       |   3 -
 .../IgnitePdsCacheAssignmentNodeRestartsTest.java  |   3 -
 ...CacheConfigurationFileConsistencyCheckTest.java |   3 -
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |   3 -
 .../IgnitePdsCacheRebalancingAbstractTest.java     |   3 -
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |   3 -
 .../IgnitePdsContinuousRestartTest.java            |   3 -
 .../persistence/IgnitePdsCorruptedIndexTest.java   |   3 -
 .../persistence/IgnitePdsCorruptedStoreTest.java   |   3 -
 .../persistence/IgnitePdsDestroyCacheTest.java     |   3 -
 ...gnitePdsDestroyCacheWithoutCheckpointsTest.java |   3 -
 .../persistence/IgnitePdsDynamicCacheTest.java     |   3 -
 .../IgnitePdsExchangeDuringCheckpointTest.java     |   3 -
 ...PdsMarshallerMappingRestoreOnNodeStartTest.java |   3 -
 .../IgnitePdsNoSpaceLeftOnDeviceTest.java          |   3 -
 .../cache/persistence/IgnitePdsPageSizesTest.java  |   3 -
 .../IgnitePdsPartitionFilesDestroyTest.java        |   3 -
 .../IgnitePdsPartitionsStateRecoveryTest.java      |   3 -
 .../IgnitePdsRecoveryAfterFileCorruptionTest.java  |   3 -
 .../IgnitePdsRemoveDuringRebalancingTest.java      |   3 -
 .../persistence/IgnitePdsTaskCancelingTest.java    |   3 -
 .../IgnitePdsTxCacheRebalancingTest.java           |   3 -
 .../IgnitePersistentStoreCacheGroupsTest.java      |   3 -
 .../IgnitePersistentStoreDataStructuresTest.java   |   3 -
 ...gniteRebalanceScheduleResendPartitionsTest.java |   3 -
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   3 -
 ...NoChangeDuringRebalanceOnNonNodeAssignTest.java |   3 -
 .../MemoryPolicyInitializationTest.java            |   3 -
 .../PersistenceDirectoryWarningLoggingTest.java    |   3 -
 .../ClientAffinityAssignmentWithBaselineTest.java  |   3 -
 .../IgniteAbsentEvictionNodeOutOfBaselineTest.java |   3 -
 .../db/CheckpointBufferDeadlockTest.java           |   3 -
 .../persistence/db/IgniteLogicalRecoveryTest.java  |   3 -
 .../persistence/db/IgnitePdsCacheRestoreTest.java  |   3 -
 ...IgnitePdsCacheWalDisabledOnRebalancingTest.java |   3 -
 .../db/IgnitePdsDataRegionMetricsTest.java         |   3 -
 .../db/IgnitePdsMultiNodePutGetRestartTest.java    |   3 -
 ...itePdsPageEvictionDuringPartitionClearTest.java |   3 -
 .../persistence/db/IgnitePdsPageEvictionTest.java  |   3 -
 .../db/IgnitePdsPartitionPreloadTest.java          |   3 -
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |   3 -
 .../db/IgnitePdsReserveWalSegmentsTest.java        |   3 -
 .../db/IgnitePdsTransactionsHangTest.java          |   3 -
 .../db/IgnitePdsWholeClusterRestartTest.java       |   3 -
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |   3 -
 .../persistence/db/IgnitePdsWithTtlTest2.java      |   3 -
 .../IgniteShutdownOnSupplyMessageFailureTest.java  |   7 +-
 .../SlowHistoricalRebalanceSmallHistoryTest.java   |   3 -
 .../IgniteCheckpointDirtyPagesForLowLoadTest.java  |   3 -
 .../db/checkpoint/IgniteMassLoadSandboxTest.java   |   3 -
 .../DefaultPageSizeBackwardsCompatibilityTest.java |   3 -
 .../IgnitePdsCacheDestroyDuringCheckpointTest.java |   3 -
 .../db/file/IgnitePdsCacheIntegrationTest.java     |   3 -
 .../db/file/IgnitePdsCheckpointSimpleTest.java     |   3 -
 ...CheckpointSimulationWithRealCpDisabledTest.java |   3 -
 .../db/file/IgnitePdsDiskErrorsRecoveringTest.java |   3 -
 .../db/file/IgnitePdsNoActualWalHistoryTest.java   |   3 -
 .../db/file/IgnitePdsPageReplacementTest.java      |   3 -
 .../db/file/IgnitePdsThreadInterruptionTest.java   |   3 -
 .../IgniteUidAsConsistentIdMigrationTest.java      |   3 -
 .../db/wal/FsyncWalRolloverDoesNotBlockTest.java   |   3 -
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |   3 -
 ...ailIsReachedDuringIterationOverArchiveTest.java |   3 -
 .../db/wal/IgniteWalFlushFailoverTest.java         |   3 -
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |   3 -
 .../db/wal/IgniteWalFormatFileFailoverTest.java    |   3 -
 .../db/wal/IgniteWalHistoryReservationsTest.java   |   3 -
 .../IgniteWalIteratorExceptionDuringReadTest.java  |   3 -
 .../db/wal/IgniteWalIteratorSwitchSegmentTest.java |   3 -
 .../persistence/db/wal/IgniteWalRebalanceTest.java |   3 -
 .../db/wal/IgniteWalRecoveryPPCTest.java           |   3 -
 .../wal/IgniteWalRecoverySeveralRestartsTest.java  |   3 -
 .../db/wal/IgniteWalSerializerVersionTest.java     |   3 -
 .../db/wal/WalCompactionAfterRestartTest.java      |   3 -
 .../persistence/db/wal/WalCompactionTest.java      |   3 -
 .../db/wal/WalDeletionArchiveAbstractTest.java     |   3 -
 .../cache/persistence/db/wal/WalPathsTest.java     |   3 -
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java    |   3 -
 .../db/wal/WalRolloverRecordLoggingTest.java       |   3 -
 .../persistence/db/wal/WalRolloverTypesTest.java   |   3 -
 .../IgniteAbstractWalIteratorInvalidCrcTest.java   |   3 -
 .../crc/IgniteReplayWalIteratorInvalidCrcTest.java |   3 -
 .../db/wal/reader/IgniteWalReaderTest.java         |   3 -
 .../cache/persistence/file/FileDownloaderTest.java |   3 -
 .../metastorage/IgniteMetaStorageBasicTest.java    |   3 -
 .../persistence/pagemem/FillFactorMetricTest.java  |   3 -
 .../pagemem/PageIdDistributionTest.java            |   3 -
 .../pagemem/PageMemoryImplNoLoadTest.java          |   3 -
 .../persistence/pagemem/PageMemoryImplTest.java    |   3 -
 .../pagemem/PageMemoryNoStoreLeakTest.java         |   3 -
 .../pagemem/PagesWriteThrottleSandboxTest.java     |   3 -
 .../pagemem/PagesWriteThrottleSmokeTest.java       |   3 -
 .../IgniteChangeGlobalStateCacheTest.java          |   3 -
 .../IgniteChangeGlobalStateDataStreamerTest.java   |   3 -
 .../IgniteChangeGlobalStateDataStructureTest.java  |   3 -
 .../IgniteChangeGlobalStateFailOverTest.java       |   3 -
 .../IgniteChangeGlobalStateServiceTest.java        |   3 -
 .../IgniteChangeGlobalStateTest.java               |   3 -
 .../IgniteNoParrallelClusterIsAllowedTest.java     |   3 -
 .../standbycluster/IgniteStandByClusterTest.java   |   3 -
 .../join/JoinActiveNodeToActiveCluster.java        |   3 -
 .../join/JoinActiveNodeToInActiveCluster.java      |   3 -
 .../join/JoinInActiveNodeToActiveCluster.java      |   3 -
 .../join/JoinInActiveNodeToInActiveCluster.java    |   3 -
 ...inActiveNodeToActiveClusterWithPersistence.java |   3 -
 .../IgniteStandByClientReconnectTest.java          |   3 -
 ...niteStandByClientReconnectToNewClusterTest.java |   3 -
 .../wal/CpTriggeredWalDeltaConsistencyTest.java    |   3 -
 .../wal/ExplicitWalDeltaConsistencyTest.java       |   3 -
 .../wal/SegmentedRingByteBufferTest.java           |   3 -
 .../wal/SysPropWalDeltaConsistencyTest.java        |   3 -
 .../reader/StandaloneWalRecordsIteratorTest.java   |   3 -
 .../cache/query/CacheDataPageScanQueryTest.java    |   3 -
 .../cache/query/CacheScanQueryFailoverTest.java    |   3 -
 .../query/GridCacheQueryTransformerSelfTest.java   |   3 -
 .../cache/query/GridCircularQueueTest.java         |   3 -
 .../IgniteCacheQueryCacheDestroySelfTest.java      |   3 -
 .../cache/query/IndexingSpiQuerySelfTest.java      |   3 -
 .../cache/query/IndexingSpiQueryTxSelfTest.java    |   3 -
 .../ScanQueryOffheapExpiryPolicySelfTest.java      |   3 -
 .../continuous/CacheContinuousBatchAckTest.java    |   3 -
 ...ContinuousQueryAsyncFailoverMvccTxSelfTest.java |  10 +-
 ...acheContinuousQueryAsyncFilterListenerTest.java |   3 -
 ...ntinuousQueryConcurrentPartitionUpdateTest.java |   3 -
 .../CacheContinuousQueryCounterAbstractTest.java   |   3 -
 .../CacheContinuousQueryEventBufferTest.java       |   3 -
 .../CacheContinuousQueryExecuteInPrimaryTest.java  |   3 -
 ...nuousQueryFactoryFilterRandomOperationTest.java |   3 -
 ...cheContinuousQueryFailoverAbstractSelfTest.java |   3 -
 ...CacheContinuousQueryFailoverMvccTxSelfTest.java |  10 +-
 .../CacheContinuousQueryLostPartitionTest.java     |   3 -
 ...heContinuousQueryOperationFromCallbackTest.java |   3 -
 .../CacheContinuousQueryOperationP2PTest.java      |   3 -
 .../CacheContinuousQueryOrderingEventTest.java     |   3 -
 .../CacheContinuousQueryRandomOperationsTest.java  |   3 -
 .../CacheContinuousQueryVariationsTest.java        |  10 +-
 ...CacheContinuousWithTransformerFailoverTest.java |   3 -
 ...ontinuousWithTransformerReplicatedSelfTest.java |   3 -
 ...acheEntryProcessorExternalizableFailedTest.java |   3 -
 .../CacheEntryProcessorNonSerializableTest.java    |   3 -
 .../CacheKeepBinaryIterationNearEnabledTest.java   |   3 -
 .../CacheKeepBinaryIterationStoreEnabledTest.java  |   3 -
 .../continuous/CacheKeepBinaryIterationTest.java   |   3 -
 .../ClientReconnectContinuousQueryTest.java        |   3 -
 .../continuous/ContinuousQueryMarshallerTest.java  |   3 -
 .../ContinuousQueryPeerClassLoadingTest.java       |   3 -
 .../ContinuousQueryReassignmentTest.java           |   3 -
 ...ueryRemoteFilterMissingInClassPathSelfTest.java |   3 -
 .../GridCacheContinuousQueryAbstractSelfTest.java  |   3 -
 .../GridCacheContinuousQueryAtomicSelfTest.java    |   3 -
 .../GridCacheContinuousQueryConcurrentTest.java    |   3 -
 ...acheContinuousQueryMultiNodesFilteringTest.java |   3 -
 ...GridCacheContinuousQueryNodesFilteringTest.java |   3 -
 ...acheContinuousQueryPartitionedOnlySelfTest.java |   3 -
 ...cheContinuousQueryReplicatedAtomicSelfTest.java |   3 -
 ...GridCacheContinuousQueryReplicatedSelfTest.java |   3 -
 ...acheContinuousQueryReplicatedTxOneNodeTest.java |   3 -
 .../GridCacheContinuousQueryTxSelfTest.java        |   3 -
 .../IgniteCacheContinuousQueryBackupQueueTest.java |   3 -
 ...iteCacheContinuousQueryClientReconnectTest.java |   3 -
 .../IgniteCacheContinuousQueryClientTest.java      |   3 -
 ...niteCacheContinuousQueryImmutableEntryTest.java |   3 -
 ...gniteCacheContinuousQueryNoUnsubscribeTest.java |   3 -
 .../IgniteCacheContinuousQueryReconnectTest.java   |   3 -
 .../GridCacheWriteBehindStoreAbstractTest.java     |  21 +-
 .../store/GridCacheWriteBehindStoreLocalTest.java  |  14 +-
 ...CacheWriteBehindStoreMultithreadedSelfTest.java |   3 -
 ...iteBehindStorePartitionedMultiNodeSelfTest.java |   3 -
 .../store/GridCacheWriteBehindStoreSelfTest.java   |   3 -
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java    |   3 -
 ...nteCacheClientWriteBehindStoreAbstractTest.java |  20 +-
 ...cheClientWriteBehindStoreNonCoalescingTest.java |   3 -
 .../transactions/AtomicOperationsInTxTest.java     |   3 -
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |   3 -
 ...nsactionIntegrityWithSystemWorkerDeathTest.java |   3 -
 .../TxDataConsistencyOnCommitFailureTest.java      |   3 -
 .../cache/transactions/TxDeadlockCauseTest.java    |   3 -
 .../TxDeadlockDetectionMessageMarshallingTest.java |   3 -
 .../TxDeadlockDetectionNoHangsTest.java            |   3 -
 .../transactions/TxDeadlockDetectionTest.java      |   3 -
 .../TxDeadlockDetectionUnmasrhalErrorsTest.java    |   3 -
 .../processors/cache/transactions/TxLabelTest.java |   3 -
 .../transactions/TxMultiCacheAsyncOpsTest.java     |   3 -
 .../cache/transactions/TxOnCachesStartTest.java    |   3 -
 ...xOptimisticDeadlockDetectionCrossCacheTest.java |   3 -
 .../TxOptimisticDeadlockDetectionTest.java         |   3 -
 .../TxOptimisticOnPartitionExchangeTest.java       |   3 -
 .../TxOptimisticPrepareOnUnstableTopologyTest.java |   3 -
 ...PessimisticDeadlockDetectionCrossCacheTest.java |   3 -
 .../TxPessimisticDeadlockDetectionTest.java        |   3 -
 .../cache/transactions/TxRollbackAsyncTest.java    |   3 -
 .../TxRollbackAsyncWithPersistenceTest.java        |   4 -
 .../TxRollbackOnIncorrectParamsTest.java           |   3 -
 .../TxRollbackOnTimeoutOnePhaseCommitTest.java     |   3 -
 .../transactions/TxRollbackOnTimeoutTest.java      |   3 -
 .../TxRollbackOnTopologyChangeTest.java            |   3 -
 .../cache/transactions/TxStateChangeEventTest.java |   3 -
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |   3 -
 .../version/CacheVersionedEntryAbstractTest.java   |   3 -
 ...heVersionedEntryLocalTransactionalSelfTest.java |  15 +-
 .../closure/GridClosureProcessorRemoteTest.java    |   3 -
 .../closure/GridClosureProcessorSelfTest.java      |   3 -
 .../closure/GridClosureSerializationTest.java      |   3 -
 .../cluster/GridAddressResolverSelfTest.java       |   3 -
 .../cluster/GridUpdateNotifierSelfTest.java        |   3 -
 ...ridComputeJobExecutionErrorToLogManualTest.java |   3 -
 .../IgniteComputeConfigVariationsFullApiTest.java  |   3 -
 ...ComputeCustomExecutorConfigurationSelfTest.java |   3 -
 .../IgniteComputeCustomExecutorSelfTest.java       |   3 -
 .../compute/PublicThreadpoolStarvationTest.java    |   3 -
 .../distributed/DistributedConfigurationTest.java  |   3 -
 .../continuous/GridEventConsumeSelfTest.java       |   3 -
 .../continuous/GridMessageListenSelfTest.java      |   3 -
 .../IgniteContinuousQueryMetadataUpdateTest.java   |   3 -
 .../IgniteNoCustomEventsOnNodeStart.java           |   3 -
 .../processors/database/BPlusTreeSelfTest.java     |   3 -
 .../database/CacheFreeListImplSelfTest.java        |   3 -
 .../database/DataRegionMetricsSelfTest.java        |   3 -
 .../database/IgniteDbDynamicCacheSelfTest.java     |   3 -
 .../database/IgniteDbMemoryLeakAbstractTest.java   |   3 -
 .../database/IgniteDbPutGetAbstractTest.java       |   3 -
 .../database/IgniteDbPutGetWithCacheStoreTest.java |   3 -
 .../database/IgniteDbSingleNodeTinyPutGetTest.java |   3 -
 .../processors/database/IndexStorageSelfTest.java  |   3 -
 .../database/SwapPathConstructionSelfTest.java     |   3 -
 .../DataStreamProcessorMvccSelfTest.java           |   3 -
 .../datastreamer/DataStreamProcessorSelfTest.java  |   3 -
 ...amerClientReconnectAfterClusterRestartTest.java |   3 -
 .../datastreamer/DataStreamerImplSelfTest.java     |   3 -
 .../DataStreamerMultiThreadedSelfTest.java         |   3 -
 .../DataStreamerMultinodeCreateCacheTest.java      |   3 -
 .../datastreamer/DataStreamerTimeoutTest.java      |   3 -
 .../DataStreamerUpdateAfterLoadTest.java           |   3 -
 .../IgniteDataStreamerPerformanceTest.java         |   3 -
 .../processors/igfs/IgfsAbstractSelfTest.java      |   3 -
 .../processors/igfs/IgfsAttributesSelfTest.java    |   3 -
 .../igfs/IgfsBackupFailoverSelfTest.java           |   3 -
 ...fsBlockMessageSystemPoolStarvationSelfTest.java |   3 -
 ...IgfsCachePerBlockLruEvictionPolicySelfTest.java |   3 -
 .../processors/igfs/IgfsCacheSelfTest.java         |   3 -
 .../processors/igfs/IgfsDataManagerSelfTest.java   |   3 -
 .../processors/igfs/IgfsDualAbstractSelfTest.java  |   3 -
 .../processors/igfs/IgfsFileInfoSelfTest.java      |   3 -
 .../processors/igfs/IgfsFileMapSelfTest.java       |   3 -
 .../IgfsGroupDataBlockKeyMapperHashSelfTest.java   |   3 -
 ...calSecondaryFileSystemDualAbstractSelfTest.java |   3 -
 .../IgfsLocalSecondaryFileSystemProxySelfTest.java |   3 -
 .../processors/igfs/IgfsMetaManagerSelfTest.java   |   3 -
 .../processors/igfs/IgfsMetricsSelfTest.java       |   3 -
 .../processors/igfs/IgfsModesSelfTest.java         |   3 -
 .../processors/igfs/IgfsOneClientNodeTest.java     |   3 -
 .../igfs/IgfsPrimaryMultiNodeSelfTest.java         |   3 -
 ...PrimaryRelaxedConsistencyMultiNodeSelfTest.java |   3 -
 .../processors/igfs/IgfsProcessorSelfTest.java     |   3 -
 .../igfs/IgfsProcessorValidationSelfTest.java      |   3 -
 .../IgfsSecondaryFileSystemInjectionSelfTest.java  |   3 -
 ...gerIpcEndpointRegistrationAbstractSelfTest.java |   3 -
 ...cEndpointRegistrationOnLinuxAndMacSelfTest.java |   3 -
 ...erIpcEndpointRegistrationOnWindowsSelfTest.java |   9 +-
 .../internal/processors/igfs/IgfsSizeSelfTest.java |   3 -
 .../processors/igfs/IgfsStartCacheTest.java        |   3 -
 .../processors/igfs/IgfsStreamsSelfTest.java       |   3 -
 .../internal/processors/igfs/IgfsTaskSelfTest.java |   3 -
 .../IgfsByteDelimiterRecordResolverSelfTest.java   |   3 -
 .../IgfsFixedLengthRecordResolverSelfTest.java     |   3 -
 ...IgfsNewLineDelimiterRecordResolverSelfTest.java |   3 -
 .../IgfsStringDelimiterRecordResolverSelfTest.java |   3 -
 .../GridJobMetricsProcessorLoadTest.java           |   3 -
 .../IgniteMessagingConfigVariationFullApiTest.java |   3 -
 .../DistributedMetaStoragePersistentTest.java      |   3 -
 .../metastorage/DistributedMetaStorageTest.java    |   3 -
 .../odbc/OdbcConfigurationValidationSelfTest.java  |   3 -
 .../odbc/OdbcEscapeSequenceSelfTest.java           |   3 -
 .../processors/port/GridPortProcessorSelfTest.java |   3 -
 .../cache/GridCacheCommandHandlerSelfTest.java     |   3 -
 .../handlers/log/GridLogCommandHandlerTest.java    |   3 -
 .../query/GridQueryCommandHandlerTest.java         |   3 -
 .../top/CacheTopologyCommandHandlerTest.java       |   3 -
 .../service/ClosureServiceClientsNodesTest.java    |   3 -
 .../service/GridServiceClientNodeTest.java         |   3 -
 .../GridServiceContinuousQueryRedeployTest.java    |   3 -
 ...ridServiceDeploymentCompoundFutureSelfTest.java |   3 -
 ...dServiceDeploymentExceptionPropagationTest.java |   9 +-
 .../service/GridServicePackagePrivateSelfTest.java |   3 -
 .../GridServiceProcessorAbstractSelfTest.java      |   3 -
 .../GridServiceProcessorBatchDeploySelfTest.java   |   3 -
 ...ridServiceProcessorMultiNodeConfigSelfTest.java |   3 -
 .../GridServiceProcessorMultiNodeSelfTest.java     |   3 -
 .../service/GridServiceProcessorProxySelfTest.java |   3 -
 .../GridServiceProcessorSingleNodeSelfTest.java    |   3 -
 .../service/GridServiceProcessorStopSelfTest.java  |   3 -
 .../GridServiceProxyClientReconnectSelfTest.java   |   3 -
 .../service/GridServiceProxyNodeStopSelfTest.java  |   3 -
 .../service/GridServiceReassignmentSelfTest.java   |   3 -
 .../service/GridServiceSerializationSelfTest.java  |   3 -
 .../IgniteServiceConfigVariationsFullApiTest.java  |   3 -
 ...ployment2ClassLoadersDefaultMarshallerTest.java |   3 -
 ...eploymentClassLoadingDefaultMarshallerTest.java |   3 -
 .../IgniteServiceDynamicCachesSelfTest.java        |   3 -
 .../IgniteServiceProxyTimeoutInitializedTest.java  |   3 -
 .../service/IgniteServiceReassignmentTest.java     |   3 -
 ...mentDiscoveryListenerNotificationOrderTest.java |  11 +-
 ...mentNonSerializableStaticConfigurationTest.java |  13 +-
 .../service/ServiceDeploymentOnActivationTest.java |  13 +-
 .../ServiceDeploymentOnClientDisconnectTest.java   |   9 +-
 .../ServiceDeploymentOutsideBaselineTest.java      |   3 -
 .../ServiceDeploymentProcessAbstractTest.java      |   6 +-
 ...eDeploymentProcessingOnCoordinatorFailTest.java |   3 -
 ...eDeploymentProcessingOnCoordinatorLeftTest.java |   3 -
 ...ServiceDeploymentProcessingOnNodesFailTest.java |   3 -
 ...ServiceDeploymentProcessingOnNodesLeftTest.java |   3 -
 .../service/ServicePredicateAccessCacheTest.java   |   3 -
 .../service/SystemCacheNotConfiguredTest.java      |   3 -
 .../timeout/GridTimeoutProcessorSelfTest.java      |   3 -
 .../product/GridProductVersionSelfTest.java        |   3 -
 .../internal/sql/SqlParserBulkLoadSelfTest.java    |   3 -
 .../internal/sql/SqlParserCreateIndexSelfTest.java |   3 -
 .../internal/sql/SqlParserDropIndexSelfTest.java   |   3 -
 .../sql/SqlParserSetStreamingSelfTest.java         |   3 -
 .../SqlParserTransactionalKeywordsSelfTest.java    |   3 -
 .../ignite/internal/sql/SqlParserUserSelfTest.java |   3 -
 .../stat/IoStatisticsCachePersistenceSelfTest.java |   4 -
 .../internal/stat/IoStatisticsCacheSelfTest.java   |   3 -
 .../internal/stat/IoStatisticsManagerSelfTest.java |   3 -
 ...IoStatisticsMetricsLocalMXBeanImplSelfTest.java |   3 -
 .../ignite/internal/util/BitSetIntSetTest.java     |   3 -
 .../ignite/internal/util/GridArraysSelfTest.java   |   3 -
 .../internal/util/GridHandleTableSelfTest.java     |   3 -
 .../ignite/internal/util/IgniteDevOnlyLogTest.java |   3 -
 .../util/IgniteExceptionRegistrySelfTest.java      |   3 -
 .../ignite/internal/util/IgniteUtilsSelfTest.java  |   3 -
 .../ignite/internal/util/StripedExecutorTest.java  |   3 -
 .../util/future/GridCompoundFutureSelfTest.java    |   3 -
 .../util/future/GridEmbeddedFutureSelfTest.java    |   3 -
 .../util/future/GridFutureAdapterSelfTest.java     |   3 -
 .../internal/util/future/IgniteFutureImplTest.java |   3 -
 .../future/nio/GridNioEmbeddedFutureSelfTest.java  |   3 -
 .../util/future/nio/GridNioFutureSelfTest.java     |   3 -
 .../GridUnsafeDataOutputArraySizingSelfTest.java   |   3 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java     |   3 -
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java    |   3 -
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java    |   3 -
 .../ignite/internal/util/nio/GridNioSelfTest.java  |   3 -
 .../util/nio/GridNioSessionMetaKeySelfTest.java    |   3 -
 .../internal/util/nio/GridNioSslSelfTest.java      |   3 -
 .../nio/IgniteExceptionInNioWorkerSelfTest.java    |   3 -
 .../util/nio/impl/GridNioFilterChainSelfTest.java  |   3 -
 .../offheap/GridOffHeapMapAbstractSelfTest.java    |   3 -
 .../GridOffHeapMapPerformanceAbstractTest.java     |   3 -
 .../GridOffHeapPartitionedMapAbstractSelfTest.java |   3 -
 ...fHeapPartitionedMapPerformanceAbstractTest.java |   3 -
 .../offheap/unsafe/GridUnsafeMemorySelfTest.java   |   3 -
 .../unsafe/GridUnsafeStripedLruSefTest.java        |   3 -
 .../tostring/CircularStringBuilderSelfTest.java    |   3 -
 .../util/tostring/GridToStringBuilderSelfTest.java |   3 -
 .../tostring/IncludeSensitiveAbstractTest.java     |   3 -
 .../ignite/lang/GridByteArrayListSelfTest.java     |   3 -
 .../ignite/lang/GridFuncPerformanceTest.java       |   3 -
 .../lang/GridMetadataAwareAdapterLoadTest.java     |   3 -
 .../lang/GridMetadataAwareAdapterSelfTest.java     |   3 -
 .../apache/ignite/lang/GridSetWrapperSelfTest.java |   3 -
 .../org/apache/ignite/lang/GridTupleSelfTest.java  |   3 -
 .../java/org/apache/ignite/lang/GridXSelfTest.java |   3 -
 .../org/apache/ignite/lang/IgniteUuidSelfTest.java |   3 -
 ...GridBoundedConcurrentLinkedHashMapSelfTest.java |   3 -
 .../GridBoundedConcurrentOrderedMapSelfTest.java   |   3 -
 .../utils/GridBoundedPriorityQueueSelfTest.java    |   3 -
 .../utils/GridCircularBufferPerformanceTest.java   |   3 -
 .../lang/utils/GridCircularBufferSelfTest.java     |   3 -
 .../utils/GridConcurrentLinkedHashMapSelfTest.java |   3 -
 .../utils/GridConcurrentWeakHashSetSelfTest.java   |   3 -
 .../lang/utils/GridConsistentHashSelfTest.java     |   3 -
 .../lang/utils/GridLeanIdentitySetSelfTest.java    |   3 -
 .../lang/utils/GridLeanMapPerformanceTest.java     |   3 -
 .../ignite/lang/utils/GridLeanMapSelfTest.java     |   3 -
 .../ignite/lang/utils/GridListSetSelfTest.java     |   3 -
 .../ignite/lang/utils/GridStripedLockSelfTest.java |   3 -
 .../utils/IgniteOffheapReadWriteLockSelfTest.java  |   3 -
 .../loadtests/GridCacheMultiNodeLoadTest.java      |   3 -
 .../cache/GridCacheWriteBehindStoreLoadTest.java   |   3 -
 .../communication/GridIoManagerBenchmark0.java     |   3 -
 .../GridCachePartitionedAtomicLongLoadTest.java    |   3 -
 .../direct/multisplit/GridMultiSplitsLoadTest.java |   3 -
 .../GridMultiSplitsRedeployLoadTest.java           |   3 -
 .../GridSingleSplitsNewNodesAbstractLoadTest.java  |   3 -
 .../redeploy/GridSingleSplitsRedeployLoadTest.java |   3 -
 .../direct/session/GridSessionLoadTest.java        |   3 -
 .../direct/stealing/GridStealingLoadTest.java      |   3 -
 .../loadtests/hashmap/GridHashMapLoadTest.java     |   3 -
 .../DynamicProxySerializationMultiJvmSelfTest.java |   3 -
 .../marshaller/GridMarshallerAbstractTest.java     |   3 -
 .../GridMarshallerMappingConsistencyTest.java      |   3 -
 .../marshaller/GridMarshallerPerformanceTest.java  |   3 -
 .../marshaller/MarshallerContextSelfTest.java      |   3 -
 .../MarshallerEnumDeadlockMultiJvmTest.java        |   3 -
 .../GridMessagingNoPeerClassLoadingSelfTest.java   |   3 -
 .../ignite/messaging/GridMessagingSelfTest.java    |   3 -
 .../messaging/IgniteMessagingSendAsyncTest.java    |   3 -
 .../messaging/IgniteMessagingWithClientTest.java   |   3 -
 .../p2p/DeploymentClassLoaderCallableTest.java     |   3 -
 ...ridMultinodeRedeployContinuousModeSelfTest.java |   3 -
 .../GridMultinodeRedeployIsolatedModeSelfTest.java |   3 -
 .../GridMultinodeRedeployPrivateModeSelfTest.java  |   3 -
 .../GridMultinodeRedeploySharedModeSelfTest.java   |   3 -
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java    |   3 -
 .../p2p/GridP2PContinuousDeploymentSelfTest.java   |   3 -
 .../p2p/GridP2PDifferentClassLoaderSelfTest.java   |   3 -
 .../p2p/GridP2PDoubleDeploymentSelfTest.java       |   3 -
 .../ignite/p2p/GridP2PHotRedeploymentSelfTest.java |   3 -
 .../ignite/p2p/GridP2PJobClassLoaderSelfTest.java  |   3 -
 .../ignite/p2p/GridP2PLocalDeploymentSelfTest.java |   3 -
 .../GridP2PMissedResourceCacheSizeSelfTest.java    |   3 -
 .../apache/ignite/p2p/GridP2PNodeLeftSelfTest.java |   3 -
 .../ignite/p2p/GridP2PRecursionTaskSelfTest.java   |   3 -
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java     |   3 -
 .../ignite/p2p/GridP2PSameClassLoaderSelfTest.java |   3 -
 .../ignite/p2p/GridP2PTestTaskExecutionTest.java   |   3 -
 .../apache/ignite/p2p/GridP2PTimeoutSelfTest.java  |   3 -
 .../apache/ignite/p2p/GridP2PUndeploySelfTest.java |   3 -
 .../ignite/p2p/P2PScanQueryUndeployTest.java       |   3 -
 .../ignite/p2p/P2PStreamingClassLoaderTest.java    |   3 -
 .../apache/ignite/p2p/SharedDeploymentTest.java    |   3 -
 .../PlatformDefaultJavaObjectFactorySelfTest.java  |   3 -
 .../PlatformJavaObjectFactoryProxySelfTest.java    |   3 -
 .../ignite/plugin/PluginNodeValidationTest.java    |   3 -
 .../security/SecurityPermissionSetBuilderTest.java |   3 -
 .../ignite/services/ServiceThreadPoolSelfTest.java |   3 -
 ...ridSessionCancelSiblingsFromFutureSelfTest.java |   3 -
 .../GridSessionCancelSiblingsFromJobSelfTest.java  |   3 -
 .../GridSessionCancelSiblingsFromTaskSelfTest.java |   3 -
 .../session/GridSessionCheckpointSelfTest.java     |   3 -
 .../session/GridSessionCollisionSpiSelfTest.java   |   3 -
 .../GridSessionFutureWaitJobAttributeSelfTest.java |   3 -
 ...GridSessionFutureWaitTaskAttributeSelfTest.java |   3 -
 .../session/GridSessionJobFailoverSelfTest.java    |   3 -
 .../GridSessionJobWaitTaskAttributeSelfTest.java   |   3 -
 .../ignite/session/GridSessionLoadSelfTest.java    |   3 -
 .../GridSessionSetFutureAttributeSelfTest.java     |   3 -
 ...sionSetFutureAttributeWaitListenerSelfTest.java |   3 -
 .../GridSessionSetJobAttribute2SelfTest.java       |   3 -
 .../GridSessionSetJobAttributeOrderSelfTest.java   |   3 -
 .../GridSessionSetJobAttributeSelfTest.java        |   3 -
 ...SessionSetJobAttributeWaitListenerSelfTest.java |   3 -
 .../GridSessionSetTaskAttributeSelfTest.java       |   3 -
 .../GridSessionTaskWaitJobAttributeSelfTest.java   |   3 -
 .../session/GridSessionWaitAttributeSelfTest.java  |   3 -
 .../ignite/spi/GridSpiLocalHostInjectionTest.java  |   3 -
 .../ignite/spi/GridSpiStartStopAbstractTest.java   |   3 -
 .../ignite/spi/GridTcpSpiForwardingSelfTest.java   |   3 -
 .../checkpoint/GridCheckpointSpiAbstractTest.java  |   3 -
 .../cache/CacheCheckpointSpiConfigSelfTest.java    |   3 -
 .../CacheCheckpointSpiSecondCacheSelfTest.java     |   3 -
 .../jdbc/JdbcCheckpointSpiConfigSelfTest.java      |   3 -
 .../GridSharedFsCheckpointSpiConfigSelfTest.java   |   3 -
 ...SharedFsCheckpointSpiMultiThreadedSelfTest.java |   3 -
 ...FsCheckpointSpiMultipleDirectoriesSelfTest.java |   3 -
 .../GridFifoQueueCollisionSpiConfigSelfTest.java   |   3 -
 .../GridFifoQueueCollisionSpiSelfTest.java         |   3 -
 ...dJobStealingCollisionSpiAttributesSelfTest.java |   3 -
 .../GridJobStealingCollisionSpiConfigSelfTest.java |   3 -
 ...StealingCollisionSpiCustomTopologySelfTest.java |   7 +-
 .../GridJobStealingCollisionSpiSelfTest.java       |   3 -
 ...ridPriorityQueueCollisionSpiConfigSelfTest.java |   3 -
 .../GridPriorityQueueCollisionSpiSelfTest.java     |   3 -
 .../GridAbstractCommunicationSelfTest.java         |   3 -
 .../communication/GridCacheMessageSelfTest.java    |   3 -
 .../tcp/GridCacheDhtLockBackupSelfTest.java        |   3 -
 .../tcp/GridTcpCommunicationSpiAbstractTest.java   |   3 -
 ...pCommunicationSpiConcurrentConnectSelfTest.java |   3 -
 .../tcp/GridTcpCommunicationSpiConfigSelfTest.java |   3 -
 .../tcp/GridTcpCommunicationSpiLanLoadTest.java    |   3 -
 ...idTcpCommunicationSpiMultithreadedSelfTest.java |   3 -
 ...GridTcpCommunicationSpiRecoveryAckSelfTest.java |   3 -
 ...icationSpiRecoveryFailureDetectionSelfTest.java |   3 -
 .../GridTcpCommunicationSpiRecoverySelfTest.java   |   3 -
 ...ommunicationSpiTcpFailureDetectionSelfTest.java |   5 +-
 .../IgniteTcpCommunicationConnectOnInitTest.java   |   3 -
 ...TcpCommunicationRecoveryAckClosureSelfTest.java |   3 -
 .../tcp/TcpCommunicationSpiDropNodesTest.java      |   3 -
 .../tcp/TcpCommunicationSpiFaultyClientTest.java   |   3 -
 ...cpCommunicationSpiHalfOpenedConnectionTest.java |   3 -
 .../TcpCommunicationSpiSkipMessageSendTest.java    |   3 -
 .../tcp/TcpCommunicationStatisticsTest.java        |   3 -
 .../local/GridLocalDeploymentSpiSelfTest.java      |   3 -
 .../AbstractDiscoveryRandomStartStopTest.java      |   3 -
 .../spi/discovery/AbstractDiscoverySelfTest.java   |   3 -
 .../spi/discovery/AbstractDiscoveryTest.java       |   3 -
 .../spi/discovery/AuthenticationRestartTest.java   |   3 -
 .../ClusterMetricsSnapshotSerializeSelfTest.java   |   3 -
 .../FilterDataForClientNodeDiscoveryTest.java      |   3 -
 .../IgniteDiscoveryCacheReuseSelfTest.java         |   3 -
 .../discovery/LongClientConnectToClusterTest.java  |   3 -
 .../tcp/DiscoveryUnmarshalVulnerabilityTest.java   |   3 -
 .../discovery/tcp/IgniteClientConnectSslTest.java  |   3 -
 .../spi/discovery/tcp/IgniteClientConnectTest.java |   3 -
 ...gniteClientReconnectMassiveShutdownSslTest.java |   3 -
 .../IgniteClientReconnectMassiveShutdownTest.java  |   3 -
 .../TcpClientDiscoveryMarshallerCheckSelfTest.java |   3 -
 ...TcpClientDiscoverySpiCoordinatorChangeTest.java |   3 -
 ...cpClientDiscoverySpiFailureTimeoutSelfTest.java |   3 -
 .../tcp/TcpClientDiscoverySpiMulticastTest.java    |   3 -
 .../tcp/TcpClientDiscoverySpiSelfTest.java         |   3 -
 .../tcp/TcpClientDiscoveryUnresolvedHostTest.java  |   3 -
 .../tcp/TcpDiscoveryClientSuspensionSelfTest.java  |   3 -
 .../tcp/TcpDiscoveryConcurrentStartTest.java       |   3 -
 .../tcp/TcpDiscoveryIpFinderCleanerTest.java       |   3 -
 .../tcp/TcpDiscoveryMarshallerCheckSelfTest.java   |   3 -
 .../tcp/TcpDiscoveryMultiThreadedTest.java         |   3 -
 ...scoveryNodeAttributesUpdateOnReconnectTest.java |   3 -
 ...TcpDiscoveryNodeConfigConsistentIdSelfTest.java |   3 -
 .../tcp/TcpDiscoveryNodeConsistentIdSelfTest.java  |   3 -
 .../TcpDiscoveryPendingMessageDeliveryTest.java    |   3 -
 .../TcpDiscoveryReconnectUnstableTopologyTest.java |   3 -
 .../spi/discovery/tcp/TcpDiscoveryRestartTest.java |   3 -
 .../tcp/TcpDiscoverySegmentationPolicyTest.java    |   3 -
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java    |   3 -
 .../tcp/TcpDiscoverySnapshotHistoryTest.java       |   3 -
 .../tcp/TcpDiscoverySpiConfigSelfTest.java         |   3 -
 .../tcp/TcpDiscoverySpiFailureTimeoutSelfTest.java |   3 -
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |   3 -
 .../tcp/TcpDiscoverySpiReconnectDelayTest.java     |   3 -
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java       |   3 -
 .../tcp/TcpDiscoverySslParametersTest.java         |   3 -
 .../tcp/TcpDiscoverySslSecuredUnsecuredTest.java   |   3 -
 .../tcp/TcpDiscoverySslTrustedUntrustedTest.java   |   3 -
 .../tcp/TcpDiscoveryWithWrongServerTest.java       |   3 -
 .../TcpDiscoveryIpFinderAbstractSelfTest.java      |   3 -
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java     |   3 -
 .../TcpDiscoveryMulticastIpFinderSelfTest.java     |   3 -
 .../TcpDiscoverySharedFsIpFinderSelfTest.java      |   3 -
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java         |   3 -
 ...ridMemoryEventStorageMultiThreadedSelfTest.java |   3 -
 .../GridMemoryEventStorageSpiConfigSelfTest.java   |   3 -
 .../memory/GridMemoryEventStorageSpiSelfTest.java  |   3 -
 .../GridAlwaysFailoverSpiConfigSelfTest.java       |   3 -
 .../always/GridAlwaysFailoverSpiSelfTest.java      |   3 -
 .../GridJobStealingFailoverSpiConfigSelfTest.java  |   3 -
 .../GridJobStealingFailoverSpiOneNodeSelfTest.java |   3 -
 .../GridJobStealingFailoverSpiSelfTest.java        |   3 -
 .../never/GridNeverFailoverSpiSelfTest.java        |   3 -
 ...GridAdaptiveLoadBalancingSpiConfigSelfTest.java |   3 -
 ...aptiveLoadBalancingSpiMultipleNodeSelfTest.java |   3 -
 .../GridAdaptiveLoadBalancingSpiSelfTest.java      |   3 -
 .../GridInternalTasksLoadBalancingSelfTest.java    |   3 -
 ...adBalancingNotPerTaskMultithreadedSelfTest.java |   3 -
 ...oundRobinLoadBalancingSpiLocalNodeSelfTest.java |   3 -
 ...RobinLoadBalancingSpiMultipleNodesSelfTest.java |   3 -
 ...undRobinLoadBalancingSpiNotPerTaskSelfTest.java |   3 -
 ...obinLoadBalancingSpiTopologyChangeSelfTest.java |   3 -
 ...ightedRandomLoadBalancingSpiConfigSelfTest.java |   3 -
 ...GridWeightedRandomLoadBalancingSpiSelfTest.java |   3 -
 ...htedRandomLoadBalancingSpiWeightedSelfTest.java |   3 -
 .../startup/cmdline/GridCommandLineLoaderTest.java |   3 -
 .../GridCommandLineTransformerSelfTest.java        |   3 -
 .../properties/NotStringSystemPropertyTest.java    |   3 -
 .../startup/servlet/GridServletLoaderTest.java     |   3 -
 .../stream/socket/SocketStreamerSelfTest.java      |   3 -
 .../SocketStreamerUnmarshalVulnerabilityTest.java  |   3 -
 .../ignite/testframework/MvccFeatureChecker.java   |  51 ++-
 .../testframework/junits/GridAbstractTest.java     | 455 +++++++--------------
 .../junits/GridAbstractTestWithAssumption.java     |  50 +++
 .../IgniteCacheConfigVariationsAbstractTest.java   |   2 +-
 .../junits/IgniteConfigVariationsAbstractTest.java |  75 ++--
 .../junits/JUnit3TestLegacySupport.java            |   2 +-
 .../cache/GridAbstractCacheStoreSelfTest.java      |   3 -
 .../common/GridAbstractLifecycleAwareSelfTest.java |   3 -
 .../junits/common/GridCommonAbstractTest.java      |   9 -
 .../common/GridRollingRestartAbstractTest.java     |   2 +-
 .../junits/spi/GridSpiAbstractTest.java            |  53 ++-
 .../test/ConfigVariationsTestSuiteBuilderTest.java | 117 +++++-
 .../test/ListeningTestLoggerTest.java              |   3 -
 .../ignite/testsuites/IgniteBasicTestSuite.java    |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite9.java      |   2 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |   4 +-
 ...IgniteContinuousQueryConfigVariationsSuite.java |  24 +-
 .../GridThreadPoolExecutorServiceSelfTest.java     |   3 -
 .../org/apache/ignite/thread/GridThreadTest.java   |   3 -
 .../ignite/thread/IgniteThreadPoolSizeTest.java    |   3 -
 .../ignite/util/AttributeNodeFilterSelfTest.java   |   3 -
 .../ignite/util/GridCommandHandlerSslTest.java     |   3 -
 .../apache/ignite/util/GridCommandHandlerTest.java |   3 -
 ...GridConcurrentLinkedDequeMultiThreadedTest.java |   3 -
 .../util/GridConcurrentLinkedDequeSelfTest.java    |   3 -
 ...ncurrentLinkedHashMapMultiThreadedSelfTest.java |   3 -
 .../GridInternalTaskUnusedWalSegmentsTest.java     |   3 -
 .../apache/ignite/util/GridLogThrottleTest.java    |   3 -
 .../ignite/util/GridPartitionMapSelfTest.java      |   3 -
 .../org/apache/ignite/util/GridQueueSelfTest.java  |   3 -
 .../org/apache/ignite/util/GridRandomSelfTest.java |   3 -
 .../ignite/util/GridSnapshotLockSelfTest.java      |   3 -
 .../ignite/util/GridSpinReadWriteLockSelfTest.java |   3 -
 .../util/GridStringBuilderFactorySelfTest.java     |   3 -
 .../ignite/util/GridTopologyHeapSizeSelfTest.java  |   3 -
 .../org/apache/ignite/util/GridTransientTest.java  |   3 -
 .../ignite/util/mbeans/GridMBeanBaselineTest.java  |   3 -
 .../util/mbeans/GridMBeanDisableSelfTest.java      |   3 -
 .../util/mbeans/GridMBeanExoticNamesSelfTest.java  |   3 -
 .../ignite/util/mbeans/GridMBeanSelfTest.java      |   3 -
 .../util/mbeans/WorkersControlMXBeanTest.java      |   3 -
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   3 -
 .../file/IgniteNativeIoWithNoPersistenceTest.java  |   3 -
 .../IgnitePdsReplacementNativeIoTest.java          |   3 -
 .../ignite/sink/flink/FlinkIgniteSinkSelfTest.java |   3 -
 .../source/flink/FlinkIgniteSourceSelfTest.java    |   3 -
 .../apache/ignite/stream/flume/IgniteSinkTest.java |   3 -
 .../query/h2/H2IndexingAbstractGeoSelfTest.java    |   3 -
 .../hadoop/impl/HadoopAbstractSelfTest.java        |   4 +-
 .../hadoop/impl/HadoopCommandLineTest.java         |  23 +-
 .../hadoop/impl/HadoopFileSystemsTest.java         |   3 -
 .../processors/hadoop/impl/HadoopGroupingTest.java |   3 -
 .../hadoop/impl/HadoopJobTrackerSelfTest.java      |   3 -
 .../impl/HadoopMapReduceEmbeddedSelfTest.java      |   3 -
 .../impl/HadoopMapReduceErrorResilienceTest.java   |   3 -
 .../hadoop/impl/HadoopMapReduceTest.java           |   3 -
 .../hadoop/impl/HadoopNoHadoopMapReduceTest.java   |   3 -
 .../impl/HadoopSerializationWrapperSelfTest.java   |   3 -
 .../hadoop/impl/HadoopSnappyFullMapReduceTest.java |  10 +
 .../processors/hadoop/impl/HadoopSnappyTest.java   |   6 +-
 .../processors/hadoop/impl/HadoopSortingTest.java  |   3 -
 .../hadoop/impl/HadoopSplitWrapperSelfTest.java    |   3 -
 .../hadoop/impl/HadoopTaskExecutionSelfTest.java   |   3 -
 .../impl/HadoopTasksVersionsAbstractTest.java      |   3 -
 .../processors/hadoop/impl/HadoopTeraSortTest.java |   8 +-
 .../hadoop/impl/HadoopTxConfigCacheTest.java       |   3 -
 .../hadoop/impl/HadoopUserLibsSelfTest.java        |   3 -
 .../hadoop/impl/HadoopV2JobSelfTest.java           |   3 -
 .../hadoop/impl/HadoopValidationSelfTest.java      |   3 -
 .../impl/HadoopWeightedMapReducePlannerTest.java   |   3 -
 ...adoopClientProtocolMultipleServersSelfTest.java |   3 -
 .../impl/client/HadoopClientProtocolSelfTest.java  |   3 -
 .../KerberosHadoopFileSystemFactorySelfTest.java   |   3 -
 .../hadoop/impl/igfs/Hadoop1OverIgfsProxyTest.java |   3 -
 .../impl/igfs/HadoopFIleSystemFactorySelfTest.java |   3 -
 .../HadoopIgfs20FileSystemAbstractSelfTest.java    |   3 -
 ...oopIgfs20FileSystemLoopbackPrimarySelfTest.java |  11 +-
 .../impl/igfs/HadoopIgfsDualAbstractSelfTest.java  |   9 +-
 ...HadoopSecondaryFileSystemConfigurationTest.java |   3 -
 .../impl/igfs/IgfsNearOnlyMultiNodeSelfTest.java   |   9 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java    |   3 -
 ...adoopFileSystemClientBasedAbstractSelfTest.java |   3 -
 ...doopFileSystemClientBasedDualAsyncSelfTest.java |  11 +-
 ...adoopFileSystemClientBasedDualSyncSelfTest.java |  11 +-
 .../IgniteHadoopFileSystemClientBasedOpenTest.java |   3 -
 ...HadoopFileSystemClientBasedPrimarySelfTest.java |  11 +-
 ...teHadoopFileSystemClientBasedProxySelfTest.java |  11 +-
 .../igfs/IgniteHadoopFileSystemClientSelfTest.java |   3 -
 .../IgniteHadoopFileSystemHandshakeSelfTest.java   |   3 -
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java    |   3 -
 .../igfs/IgniteHadoopFileSystemLoggerSelfTest.java |   3 -
 .../IgniteHadoopFileSystemLoggerStateSelfTest.java |   3 -
 ...ileSystemLoopbackEmbeddedDualAsyncSelfTest.java |  12 +-
 ...FileSystemLoopbackEmbeddedDualSyncSelfTest.java |  12 +-
 ...pFileSystemLoopbackEmbeddedPrimarySelfTest.java |  12 +-
 ...ileSystemLoopbackEmbeddedSecondarySelfTest.java |  13 +-
 ...gniteHadoopFileSystemShmemAbstractSelfTest.java |   3 -
 ...ystemShmemExternalToClientAbstractSelfTest.java |   3 -
 .../HadoopConcurrentHashMultimapSelftest.java      |   3 -
 .../shuffle/collections/HadoopHashMapSelfTest.java |   3 -
 .../collections/HadoopSkipListSelfTest.java        |   3 -
 .../shuffle/streams/HadoopDataStreamSelfTest.java  |   3 -
 .../taskexecutor/HadoopExecutorServiceTest.java    |   3 -
 .../HadoopExternalTaskExecutionSelfTest.java       |   3 -
 .../HadoopExternalCommunicationSelfTest.java       |   3 -
 .../impl/util/BasicUserNameMapperSelfTest.java     |   3 -
 .../impl/util/ChainedUserNameMapperSelfTest.java   |   3 -
 .../impl/util/KerberosUserNameMapperSelfTest.java  |   3 -
 .../state/HadoopJobTrackerSelfTestState.java       |   2 +-
 .../HibernateL2CacheConfigurationSelfTest.java     |   3 -
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |   3 -
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |   3 -
 .../HibernateL2CacheStrategySelfTest.java          |   3 -
 .../CacheHibernateStoreFactorySelfTest.java        |   3 -
 .../HibernateL2CacheConfigurationSelfTest.java     |   3 -
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |   3 -
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |   3 -
 .../HibernateL2CacheStrategySelfTest.java          |   3 -
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |   3 -
 .../CacheHibernateStoreFactorySelfTest.java        |   3 -
 .../HibernateL2CacheConfigurationSelfTest.java     |   3 -
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |   3 -
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |   3 -
 .../HibernateL2CacheStrategySelfTest.java          |   3 -
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |   3 -
 .../CacheHibernateStoreFactorySelfTest.java        |   3 -
 .../query/h2/DmlStatementsProcessor.java           |   5 +
 .../processors/query/h2/IgniteH2Indexing.java      |   2 +-
 .../query/h2/opt/GridH2KeyValueRowOnheap.java      |  80 ++--
 .../query/h2/opt/GridH2RowDescriptor.java          |   9 +-
 .../query/h2/twostep/ReducePartitionMapper.java    |  30 +-
 ...finityKeyNameAndValueFieldNameConflictTest.java |   3 -
 .../processors/cache/BigEntryQueryTest.java        |   3 -
 ...aryMetadataConcurrentUpdateWithIndexesTest.java |   3 -
 .../cache/BinarySerializationQuerySelfTest.java    |   3 -
 .../cache/BinaryTypeMismatchLoggingTest.java       |   3 -
 .../CacheAbstractQueryDetailMetricsSelfTest.java   |   3 -
 .../cache/CacheAbstractQueryMetricsSelfTest.java   |   3 -
 .../cache/CacheBinaryKeyConcurrentQueryTest.java   |   3 -
 .../cache/CacheConfigurationP2PTest.java           |   3 -
 .../processors/cache/CacheIndexStreamerTest.java   |   3 -
 .../cache/CacheIteratorScanQueryTest.java          |   3 -
 .../CacheOffheapBatchIndexingMultiTypeTest.java    |   3 -
 .../CacheOffheapBatchIndexingSingleTypeTest.java   |   3 -
 .../cache/CacheOperationsWithExpirationTest.java   |   3 -
 .../processors/cache/CacheQueryBuildValueTest.java |   3 -
 .../cache/CacheQueryEvictDataLostTest.java         |   3 -
 .../cache/CacheQueryFilterExpiredTest.java         |   3 -
 .../cache/CacheQueryNewClientSelfTest.java         |   3 -
 .../CacheRandomOperationsMultithreadedTest.java    |   3 -
 .../CacheScanPartitionQueryFallbackSelfTest.java   |   3 -
 .../cache/CacheSqlQueryValueCopySelfTest.java      |   3 -
 .../ClientReconnectAfterClusterRestartTest.java    |   3 -
 .../cache/ClusterReadOnlyModeSqlTest.java          |   3 -
 .../processors/cache/DdlTransactionSelfTest.java   |   3 -
 .../cache/GridCacheCrossCacheQuerySelfTest.java    |   3 -
 .../cache/GridCacheDynamicLoadOnClientTest.java    |   3 -
 .../cache/GridCacheFullTextQuerySelfTest.java      |   3 -
 .../GridCacheLazyQueryPartitionsReleaseTest.java   |   3 -
 .../processors/cache/GridCacheOffHeapSelfTest.java |   3 -
 .../cache/GridCacheOffheapIndexEntryEvictTest.java |   3 -
 .../cache/GridCacheOffheapIndexGetSelfTest.java    |   3 -
 .../cache/GridCacheQueryIndexDisabledSelfTest.java |   3 -
 .../cache/GridCacheQuerySerializationSelfTest.java |   3 -
 .../cache/GridCacheQuerySimpleBenchmark.java       |   3 -
 .../cache/GridIndexingWithNoopSwapSelfTest.java    |   3 -
 .../IgniteBinaryObjectFieldsQuerySelfTest.java     |   3 -
 .../IgniteBinaryObjectQueryArgumentsTest.java      |   3 -
 .../IgniteCacheAbstractFieldsQuerySelfTest.java    |   3 -
 .../cache/IgniteCacheCollocatedQuerySelfTest.java  |   3 -
 .../IgniteCacheConfigVariationsQueryTest.java      |   3 -
 ...teCacheConfigurationPrimitiveTypesSelfTest.java |   3 -
 .../cache/IgniteCacheCrossCacheJoinRandomTest.java |   3 -
 .../cache/IgniteCacheDeleteSqlQuerySelfTest.java   |   3 -
 ...teCacheDistributedJoinCollocatedAndNotTest.java |   3 -
 ...teCacheDistributedJoinCustomAffinityMapper.java |   3 -
 .../IgniteCacheDistributedJoinNoIndexTest.java     |   3 -
 ...istributedJoinPartitionedAndReplicatedTest.java |   3 -
 ...iteCacheDistributedJoinQueryConditionsTest.java |   3 -
 .../cache/IgniteCacheDistributedJoinTest.java      |   3 -
 ...eCacheDuplicateEntityConfigurationSelfTest.java |   3 -
 .../IgniteCacheFieldsQueryNoDataSelfTest.java      |   3 -
 ...gniteCacheFullTextQueryNodeJoiningSelfTest.java |   3 -
 .../processors/cache/IgniteCacheGroupsSqlTest.java |   3 -
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |   3 -
 ...oinPartitionedAndReplicatedCollocationTest.java |   3 -
 ...gniteCacheJoinPartitionedAndReplicatedTest.java |   3 -
 .../IgniteCacheJoinQueryWithAffinityKeyTest.java   |   3 -
 .../cache/IgniteCacheLargeResultSelfTest.java      |   3 -
 ...ockPartitionOnAffinityRunAtomicCacheOpTest.java |   3 -
 .../IgniteCacheLockPartitionOnAffinityRunTest.java |   3 -
 ...PartitionOnAffinityRunWithCollisionSpiTest.java |   3 -
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java    |   3 -
 .../cache/IgniteCacheMultipleIndexedTypesTest.java |   3 -
 .../cache/IgniteCacheNoClassQuerySelfTest.java     |   3 -
 .../IgniteCacheObjectKeyIndexingSelfTest.java      |   3 -
 .../cache/IgniteCacheOffheapEvictQueryTest.java    |   3 -
 .../cache/IgniteCacheOffheapIndexScanTest.java     |   3 -
 .../IgniteCacheP2pUnmarshallingQueryErrorTest.java |   3 -
 ...CachePartitionedQueryMultiThreadedSelfTest.java |   3 -
 .../IgniteCachePrimitiveFieldsQuerySelfTest.java   |   3 -
 .../cache/IgniteCacheQueriesLoadTest1.java         |   7 +-
 .../cache/IgniteCacheQueryH2IndexingLeakTest.java  |   7 +-
 .../cache/IgniteCacheQueryIndexSelfTest.java       |   3 -
 .../cache/IgniteCacheQueryLoadSelfTest.java        |   3 -
 .../IgniteCacheQueryMultiThreadedSelfTest.java     |   3 -
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |   3 -
 .../IgniteCacheSqlInsertValidationSelfTest.java    |   5 +-
 .../cache/IgniteCacheSqlQueryErrorSelfTest.java    |   3 -
 .../IgniteCacheSqlQueryMultiThreadedSelfTest.java  |   3 -
 .../IgniteCacheStarvationOnRebalanceTest.java      |   3 -
 .../cache/IgniteCacheUnionDuplicatesTest.java      |   3 -
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |   3 -
 ...iteCheckClusterStateBeforeExecuteQueryTest.java |   3 -
 ...iteClientReconnectCacheQueriesFailoverTest.java |   3 -
 .../cache/IgniteClientReconnectQueriesTest.java    |   3 -
 .../cache/IgniteCrossCachesJoinsQueryTest.java     |   3 -
 .../cache/IgniteDynamicSqlRestoreTest.java         |   3 -
 .../cache/IgniteErrorOnRebalanceTest.java          |   3 -
 .../processors/cache/IncorrectQueryEntityTest.java |   3 -
 .../cache/QueryEntityCaseMismatchTest.java         |   3 -
 .../QueryJoinWithDifferentNodeFiltersTest.java     |   3 -
 .../processors/cache/SqlFieldsQuerySelfTest.java   |   3 -
 .../cache/StartCachesInParallelTest.java           |   3 -
 .../authentication/SqlUserCommandSelfTest.java     |   3 -
 .../CacheBlockOnCreateDestoryIndexTest.java        |   3 -
 .../distributed/CacheBlockOnSqlQueryTest.java      |   3 -
 ...heClientQueryReplicatedNodeRestartSelfTest.java |   3 -
 ...ributedPartitionQueryConfigurationSelfTest.java |   3 -
 ...tributedPartitionQueryNodeRestartsSelfTest.java |   3 -
 ...niteCacheDistributedPartitionQuerySelfTest.java |   3 -
 .../IgniteCacheDistributedQueryCancelSelfTest.java |   3 -
 ...tributedQueryStopOnCancelOrTimeoutSelfTest.java |   3 -
 .../IgniteCachePartitionedFieldsQuerySelfTest.java |   3 -
 .../near/IgniteCacheQueryNoRebalanceSelfTest.java  |   3 -
 .../near/IgniteCacheQueryNodeFailTest.java         |   3 -
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |   3 -
 .../near/IgniteCacheQueryNodeRestartSelfTest.java  |   3 -
 .../near/IgniteCacheQueryNodeRestartSelfTest2.java |   3 -
 ...opOnCancelOrTimeoutDistributedJoinSelfTest.java |   3 -
 .../near/IgniteSqlQueryWithBaselineTest.java       |   3 -
 ...FieldsQueryJoinNoPrimaryPartitionsSelfTest.java |   3 -
 .../IgniteCacheReplicatedFieldsQuerySelfTest.java  |   3 -
 .../IgniteCacheReplicatedQuerySelfTest.java        |   3 -
 .../cache/index/AbstractIndexingCommonTest.java    |   3 -
 .../processors/cache/index/BasicIndexTest.java     |   3 -
 .../index/ComplexPrimaryKeyUnwrapSelfTest.java     |   3 -
 .../index/ComplexSecondaryKeyUnwrapSelfTest.java   |   3 -
 .../index/DuplicateKeyValueClassesSelfTest.java    |   3 -
 .../DynamicColumnsAbstractConcurrentSelfTest.java  |   3 -
 .../index/DynamicIndexAbstractBasicSelfTest.java   |   3 -
 .../DynamicIndexAbstractConcurrentSelfTest.java    |   3 -
 .../cache/index/H2ConnectionLeaksSelfTest.java     |   3 -
 .../H2DynamicColumnsAbstractBasicSelfTest.java     |   3 -
 .../index/H2DynamicIndexAbstractSelfTest.java      |   3 -
 .../H2DynamicIndexingComplexAbstractTest.java      |   3 -
 .../cache/index/H2DynamicTableSelfTest.java        |   3 -
 .../cache/index/H2RowCachePageEvictionTest.java    |   3 -
 .../processors/cache/index/H2RowCacheSelfTest.java |   3 -
 .../cache/index/IgniteDecimalSelfTest.java         |   3 -
 .../processors/cache/index/LongIndexNameTest.java  |   3 -
 .../cache/index/MvccEmptyTransactionSelfTest.java  |   3 -
 .../index/OptimizedMarshallerIndexNameTest.java    |   3 -
 .../cache/index/QueryEntityValidationSelfTest.java |   3 -
 .../cache/index/SchemaExchangeSelfTest.java        |   3 -
 ...ransactionCommandsWithMvccDisabledSelfTest.java |   3 -
 ...ransactionsCommandsWithMvccEnabledSelfTest.java |   3 -
 .../cache/index/SqlTransactionsSelfTest.java       |   3 -
 .../local/IgniteCacheLocalFieldsQuerySelfTest.java |   3 -
 ...niteCacheLocalQueryCancelOrTimeoutSelfTest.java |   3 -
 .../cache/local/IgniteCacheLocalQuerySelfTest.java |   3 -
 .../CacheMvccAbstractContinuousQuerySelfTest.java  |   3 -
 ...acheMvccAbstractSqlCoordinatorFailoverTest.java |  15 +-
 .../cache/mvcc/CacheMvccBackupsAbstractTest.java   |   3 -
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |   3 -
 .../cache/mvcc/CacheMvccBulkLoadTest.java          |   3 -
 ...vccContinuousWithTransformerClientSelfTest.java |   3 -
 ...ntinuousWithTransformerPartitionedSelfTest.java |   3 -
 ...ontinuousWithTransformerReplicatedSelfTest.java |   3 -
 .../cache/mvcc/CacheMvccDmlSimpleTest.java         |   3 -
 ...cheMvccPartitionedSelectForUpdateQueryTest.java |   3 -
 ...eMvccPartitionedSqlCoordinatorFailoverTest.java |  17 +-
 ...MvccPartitionedSqlTxQueriesWithReducerTest.java |   3 -
 ...heMvccReplicatedSqlCoordinatorFailoverTest.java |   9 +
 .../mvcc/CacheMvccReplicatedSqlTxQueriesTest.java  |   3 -
 .../CacheMvccSelectForUpdateQueryAbstractTest.java |   3 -
 .../processors/cache/mvcc/CacheMvccSizeTest.java   |   3 -
 .../CacheMvccSqlConfigurationValidationTest.java   |   3 -
 .../cache/mvcc/CacheMvccSqlLockTimeoutTest.java    |   3 -
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |   3 -
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |   3 -
 ...cheMvccSqlTxQueriesWithReducerAbstractTest.java |   3 -
 .../cache/mvcc/CacheMvccSqlUpdateCountersTest.java |   3 -
 .../cache/mvcc/CacheMvccStreamingInsertTest.java   |   3 -
 .../cache/mvcc/CacheMvccTxNodeMappingTest.java     |   3 -
 .../cache/mvcc/CacheMvccTxRecoveryTest.java        |   3 -
 .../cache/mvcc/MvccDeadlockDetectionTest.java      |   3 -
 .../cache/mvcc/MvccRepeatableReadBulkOpsTest.java  |   3 -
 .../mvcc/MvccRepeatableReadOperationsTest.java     |   3 -
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |   3 -
 .../transaction/DmlInsideTransactionTest.java      |   3 -
 .../cache/ttl/CacheTtlAbstractSelfTest.java        |   3 -
 ...ntConnectorConfigurationValidationSelfTest.java |   3 -
 .../processors/client/IgniteDataStreamerTest.java  |   3 -
 .../IgniteDbSingleNodeWithIndexingPutGetTest.java  |   3 -
 ...niteDbSingleNodeWithIndexingWalRestoreTest.java |   3 -
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |   3 -
 .../IgnitePersistentStoreSchemaLoadTest.java       |   3 -
 .../database/IgniteTwoRegionsRebuildIndexTest.java |   3 -
 ...IgniteCacheGroupsSqlSegmentedIndexSelfTest.java |   3 -
 .../query/IgniteCachelessQueriesSelfTest.java      |   3 -
 .../query/IgniteQueryDedicatedPoolTest.java        |   3 -
 .../query/IgniteSqlDefaultValueTest.java           |   3 -
 .../query/IgniteSqlDistributedJoinSelfTest.java    |   3 -
 .../query/IgniteSqlEntryCacheModeAgnosticTest.java |   3 -
 .../query/IgniteSqlGroupConcatCollocatedTest.java  |   3 -
 .../IgniteSqlGroupConcatNotCollocatedTest.java     |   3 -
 .../query/IgniteSqlKeyValueFieldsTest.java         |   3 -
 .../query/IgniteSqlNotNullConstraintTest.java      |   3 -
 .../query/IgniteSqlParameterizedQueryTest.java     |   3 -
 .../query/IgniteSqlQueryParallelismTest.java       |   3 -
 .../processors/query/IgniteSqlRoutingTest.java     |   3 -
 .../query/IgniteSqlSchemaIndexingTest.java         |   3 -
 .../query/IgniteSqlSegmentedIndexSelfTest.java     |   3 -
 ...gniteSqlSkipReducerOnUpdateDmlFlagSelfTest.java |   3 -
 .../IgniteSqlSkipReducerOnUpdateDmlSelfTest.java   |   3 -
 .../query/IgniteSqlSplitterSelfTest.java           |   3 -
 .../processors/query/LazyQuerySelfTest.java        |   3 -
 .../query/MultipleStatementsSqlQuerySelfTest.java  |   3 -
 .../processors/query/RunningQueriesTest.java       |  29 +-
 .../processors/query/SqlIllegalSchemaSelfTest.java |   3 -
 .../SqlLocalQueryConnectionAndStatementTest.java   |   5 +-
 .../processors/query/SqlNestedQuerySelfTest.java   |   3 -
 .../processors/query/SqlPushDownFunctionTest.java  |   3 -
 .../processors/query/SqlQueryHistorySelfTest.java  |   3 -
 .../processors/query/SqlSchemaSelfTest.java        |   3 -
 .../processors/query/SqlSystemViewsSelfTest.java   |   3 -
 .../CacheQueryEntityWithDateTimeApiFieldsTest.java |   3 -
 .../query/h2/GridIndexRebuildSelfTest.java         |   3 -
 .../GridIndexRebuildWithMvccEnabledSelfTest.java   |   3 -
 .../query/h2/GridIndexingSpiAbstractSelfTest.java  |   3 -
 .../H2ResultSetIteratorNullifyOnEndSelfTest.java   |   3 -
 .../query/h2/H2StatementCacheSelfTest.java         |   3 -
 .../query/h2/IgniteSqlBigIntegerKeyTest.java       |   3 -
 .../query/h2/IgniteSqlQueryMinMaxTest.java         |   3 -
 .../query/h2/PreparedStatementExSelfTest.java      |   3 -
 .../processors/query/h2/QueryDataPageScanTest.java |   5 +-
 .../query/h2/ThreadLocalObjectPoolSelfTest.java    |   3 -
 .../query/h2/database/InlineIndexHelperTest.java   |   3 -
 .../query/h2/sql/BaseH2CompareQueryTest.java       |   3 -
 .../processors/query/h2/sql/ExplainSelfTest.java   |   3 -
 .../query/h2/sql/GridQueryParsingTest.java         |   3 -
 .../query/h2/sql/H2CompareBigQueryTest.java        |   3 -
 .../BetweenOperationExtractPartitionSelfTest.java  |   3 -
 .../query/h2/twostep/CacheQueryMemoryLeakTest.java |   3 -
 .../h2/twostep/CreateTableWithDateKeySelfTest.java |   3 -
 .../DisappearedCacheCauseRetryMessageSelfTest.java |   3 -
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |   3 -
 .../InOperationExtractPartitionSelfTest.java       |   3 -
 .../h2/twostep/JoinPartitionPruningSelfTest.java   |   3 -
 .../twostep/NonCollocatedRetryMessageSelfTest.java |   3 -
 ...neOrSinglePartitionsQueryOptimizationsTest.java |   3 -
 .../h2/twostep/RetryCauseMessageSelfTest.java      |   3 -
 .../h2/twostep/TableViewSubquerySelfTest.java      |   3 -
 ...achePartitionedAtomicColumnConstraintsTest.java |   3 -
 ...dTransactionalSnapshotColumnConstraintTest.java |   3 -
 ...dTransactionalSnapshotColumnConstraintTest.java |   3 -
 .../sql/IgniteSQLColumnConstraintsTest.java        |   3 -
 .../IgniteTransactionSQLColumnConstraintTest.java  |   3 -
 ...qlConnectorConfigurationValidationSelfTest.java |   3 -
 .../tcp/GridOrderedMessageCancelSelfTest.java      |   3 -
 .../org/apache/ignite/sqltests/BaseSqlTest.java    |   3 -
 .../apache/ignite/sqltests/PartitionedSqlTest.java |   3 -
 .../apache/ignite/sqltests/ReplicatedSqlTest.java  |   3 -
 .../util/GridCommandHandlerIndexingTest.java       |   3 -
 .../ignite/stream/jms11/IgniteJmsStreamerTest.java |   3 -
 .../cache/CacheJndiTmFactorySelfTest.java          |   3 -
 ...ridCacheJtaConfigurationValidationSelfTest.java |   3 -
 ...ridCacheJtaFactoryConfigValidationSelfTest.java |   3 -
 .../cache/GridJtaLifecycleAwareSelfTest.java       |   3 -
 .../cache/GridJtaTransactionManagerSelfTest.java   |   3 -
 .../cache/jta/AbstractCacheJtaSelfTest.java        |   3 -
 .../stream/kafka/KafkaIgniteStreamerSelfTest.java  |   3 -
 .../kafka/connect/IgniteSinkConnectorTest.java     |   3 -
 .../kafka/connect/IgniteSourceConnectorTest.java   |   3 -
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java    |   3 -
 .../logger/log4j2/Log4j2LoggerMarkerTest.java      |   3 -
 .../ignite/logger/log4j2/Log4j2LoggerSelfTest.java |   3 -
 .../ml/sparkmodelparser/SparkModelParser.java      |  44 ++
 .../ml/sparkmodelparser/SupportedSparkModels.java  |   3 +
 .../java/org/apache/ignite/ml/IgniteModel.java     |  24 +-
 .../ignite/ml/clustering/kmeans/KMeansTrainer.java |  31 +-
 .../ignite/ml/composition/CompositionUtils.java    |  53 ++-
 .../ml/composition/bagging/BaggedTrainer.java      |  42 +-
 .../composition/boosting/GDBLearningStrategy.java  |  16 +-
 .../ignite/ml/composition/boosting/GDBTrainer.java |  37 +-
 .../parallel/TrainersParallelComposition.java      |  19 +-
 .../sequential/ModelsSequentialComposition.java    |  10 +-
 .../sequential/TrainersSequentialComposition.java  | 138 ++++++-
 .../stacking/StackedDatasetTrainer.java            |  26 +-
 .../bootstrapping/BootstrappedDatasetBuilder.java  |  26 +-
 .../impl/bootstrapping/BootstrappedVector.java     |   2 +-
 .../ml/knn/ann/ANNClassificationTrainer.java       |  17 +-
 .../classification/KNNClassificationTrainer.java   |  27 +-
 .../ml/knn/regression/KNNRegressionModel.java      |   4 +-
 .../ml/knn/regression/KNNRegressionTrainer.java    |  23 +-
 .../ignite/ml/math/functions/IgniteFunction.java   |  13 +
 .../ml/math/primitives/vector/VectorUtils.java     |  26 +-
 .../ignite/ml/multiclass/OneVsRestTrainer.java     |  22 +-
 .../discrete/DiscreteNaiveBayesTrainer.java        | 112 ++---
 .../gaussian/GaussianNaiveBayesTrainer.java        |  26 +-
 .../java/org/apache/ignite/ml/nn/MLPTrainer.java   |  13 +-
 .../linear/LinearRegressionLSQRTrainer.java        |  13 +-
 .../linear/LinearRegressionSGDTrainer.java         |  12 +-
 .../logistic/LogisticRegressionSGDTrainer.java     |  13 +-
 .../apache/ignite/ml/structures/LabeledVector.java |   7 +-
 .../ignite/ml/structures/LabeledVectorSet.java     |   2 +-
 .../ml/svm/SVMLinearClassificationTrainer.java     |  18 +-
 .../ignite/ml/trainers/AdaptableDatasetModel.java  |   2 +-
 .../ml/trainers/AdaptableDatasetTrainer.java       |  61 ++-
 .../apache/ignite/ml/trainers/DatasetTrainer.java  | 100 ++++-
 .../ignite/ml/trainers/FeatureLabelExtractor.java  |  71 ++++
 .../ignite/ml/trainers/TrainerTransformers.java    |  29 +-
 .../org/apache/ignite/ml/tree/DecisionTree.java    |  15 +-
 .../tree/boosting/GDBOnTreesLearningStrategy.java  |   4 +-
 .../ml/tree/data/DecisionTreeDataBuilder.java      |  25 +-
 .../ml/tree/randomforest/RandomForestTrainer.java  |  10 +-
 .../ml/util/generators/DataStreamGenerator.java    |   6 +-
 .../primitives/vector/VectorGenerator.java         |   2 +-
 .../primitives/vector/VectorGeneratorsFamily.java  |   2 +-
 .../standard/GaussianMixtureDataStream.java        |   2 +-
 .../generators/standard/RegressionDataStream.java  |   2 +-
 .../util/generators/standard/RingsDataStream.java  |   3 +-
 .../standard/TwoSeparableClassesDataStream.java    |   2 +-
 .../test/java/org/apache/ignite/ml/TestUtils.java  |   7 +-
 .../apache/ignite/ml/common/KeepBinaryTest.java    |   3 -
 .../apache/ignite/ml/composition/BaggingTest.java  |   9 +-
 .../ml/composition/boosting/GDBTrainerTest.java    |  10 +-
 .../impl/cache/CacheBasedDatasetBuilderTest.java   |   3 -
 .../dataset/impl/cache/CacheBasedDatasetTest.java  |   3 -
 .../ml/environment/LearningEnvironmentTest.java    |   6 +-
 .../apache/ignite/ml/knn/LabeledVectorSetTest.java |   3 +-
 .../discrete/DiscreteNaiveBayesTrainerTest.java    |  11 +-
 .../ignite/ml/nn/MLPTrainerIntegrationTest.java    |   3 -
 .../MLPTrainerMnistIntegrationTest.java            |   3 -
 .../cursor/CacheBasedLabelPairCursorTest.java      |   3 -
 .../selection/scoring/evaluator/EvaluatorTest.java |   3 -
 ...onTreeClassificationTrainerIntegrationTest.java |   3 -
 ...cisionTreeRegressionTrainerIntegrationTest.java |   3 -
 .../DecisionTreeMNISTIntegrationTest.java          |   3 -
 .../util/generators/DataStreamGeneratorTest.java   |  12 +-
 .../ignite/stream/mqtt/IgniteMqttStreamerTest.java |   3 -
 .../protocols/http/jetty/RestSetupSimpleTest.java  |   3 -
 .../stream/rocketmq/RocketMQStreamerTest.java      |   3 -
 .../processors/schedule/GridScheduleSelfTest.java  |   3 -
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java       |   3 -
 .../spark/JavaStandaloneIgniteRDDSelfTest.java     |   3 -
 .../springdata/IgniteSpringDataCrudSelfTest.java   |   3 -
 .../IgniteSpringDataQueriesSelfTest.java           |   3 -
 .../springdata/IgniteSpringDataCrudSelfTest.java   |   3 -
 .../IgniteSpringDataQueriesSelfTest.java           |   3 -
 .../spring/GridSpringCacheManagerAbstractTest.java |   3 -
 .../GridSpringCacheManagerMultiJvmSelfTest.java    |   3 -
 .../SpringCacheManagerContextInjectionTest.java    |   3 -
 .../ignite/cache/spring/SpringCacheTest.java       |   3 -
 .../jdbc/CacheJdbcBlobStoreFactorySelfTest.java    |   3 -
 .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java    |   3 -
 .../SpringEncryptedCacheRestartTest.java           |   3 -
 .../ignite/internal/GridFactorySelfTest.java       |   3 -
 .../GridSpringBeanSerializationSelfTest.java       |  10 +-
 .../internal/IgniteDynamicCacheConfigTest.java     |   3 -
 .../ignite/internal/IgniteSpringBeanTest.java      |   3 -
 .../resource/GridLoggerInjectionSelfTest.java      |   3 -
 .../resource/GridResourceProcessorSelfTest.java    |   3 -
 .../resource/GridServiceInjectionSelfTest.java     |   3 -
 .../GridSpringResourceInjectionSelfTest.java       |   3 -
 .../GridTransformSpringInjectionSelfTest.java      |   3 -
 .../p2p/GridP2PUserVersionChangeSelfTest.java      |   3 -
 .../spring/IgniteExcludeInConfigurationTest.java   |   3 -
 .../IgniteStartFromStreamConfigurationTest.java    |   3 -
 .../GridServiceInjectionSpringResourceTest.java    |   3 -
 ...gniteSpringBeanSpringResourceInjectionTest.java |   3 -
 .../GridSpringTransactionManagerAbstractTest.java  |   3 -
 ...ringTransactionManagerContextInjectionTest.java |   3 -
 .../internal/IgniteNodeStartUtilsSelfTest.java     |   3 -
 .../IgniteProjectionStartStopRestartSelfTest.java  |   3 -
 .../stream/storm/StormIgniteStreamerSelfTest.java  |   3 -
 .../GridTaskUriDeploymentDeadlockSelfTest.java     |   3 -
 .../apache/ignite/p2p/GridP2PDisabledSelfTest.java |   3 -
 ...DeploymentClassLoaderMultiThreadedSelfTest.java |   3 -
 .../uri/GridUriDeploymentClassLoaderSelfTest.java  |   3 -
 ...idUriDeploymentClassloaderRegisterSelfTest.java |   3 -
 .../uri/GridUriDeploymentConfigSelfTest.java       |   3 -
 .../GridUriDeploymentFileProcessorSelfTest.java    |   3 -
 .../uri/GridUriDeploymentMd5CheckSelfTest.java     |   3 -
 ...DeploymentMultiScannersErrorThrottlingTest.java |   3 -
 .../GridUriDeploymentMultiScannersSelfTest.java    |   3 -
 .../uri/GridUriDeploymentSimpleSelfTest.java       |   3 -
 .../scanners/file/GridFileDeploymentSelfTest.java  |   3 -
 .../file/GridFileDeploymentUndeploySelfTest.java   |   3 -
 .../scanners/http/GridHttpDeploymentSelfTest.java  |   3 -
 .../org/apache/ignite/tools/GridToolsSelfTest.java |   3 -
 .../form-field/showValidationError.directive.ts    |  17 +-
 .../web-console-sidebar-navigation/style.scss      |   4 -
 .../internal/websession/WebSessionSelfTest.java    |   3 -
 .../yarn/IgniteApplicationMasterSelfTest.java      |   3 -
 .../stream/zeromq/IgniteZeroMqStreamerTest.java    |   3 -
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java     |   3 -
 ...iteCacheEntryListenerWithZkDiscoAtomicTest.java |   3 -
 .../ZookeeperDiscoverySuitePreprocessorTest.java   |   3 -
 .../discovery/zk/internal/ZookeeperClientTest.java |   3 -
 .../ZookeeperDiscoverySpiSaslFailedAuthTest.java   |   3 -
 ...ookeeperDiscoverySpiSaslSuccessfulAuthTest.java |   3 -
 2169 files changed, 3222 insertions(+), 7577 deletions(-)