You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2017/03/24 14:12:39 UTC

[49/50] [abbrv] ignite git commit: Merge branch master ignite-2.0 to ignite-3477

Merge branch master ignite-2.0 to ignite-3477


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

Branch: refs/heads/ignite-3477-master
Commit: 81ae2d83b0e7bcd8bb0cc14415afd57db450b84c
Parents: aaf23fd 48e78a9
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Fri Mar 24 13:02:59 2017 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Fri Mar 24 13:02:59 2017 +0300

----------------------------------------------------------------------
 .gitignore                                      |     2 +-
 assembly/release-fabric-base.xml                |     6 +
 config/hadoop/default-config.xml                |    29 -
 examples/config/filesystem/example-igfs.xml     |    27 -
 leak.patch                                      | 10521 +++++++++++++++++
 .../aop/aspectj/GridifyAspectJAspect.java       |    15 +-
 .../aspectj/GridifySetToSetAspectJAspect.java   |    15 +-
 .../aspectj/GridifySetToValueAspectJAspect.java |    15 +-
 .../aop/spring/GridifySetToSetSpringAspect.java |    15 +-
 .../spring/GridifySetToValueSpringAspect.java   |    15 +-
 .../gridify/aop/spring/GridifySpringAspect.java |    15 +-
 .../apache/ignite/gridify/AbstractAopTest.java  |     6 +-
 .../ignite/gridify/GridifySetToSetTarget.java   |    18 +-
 .../gridify/GridifySetToSetTargetInterface.java |    18 +-
 .../ignite/gridify/GridifySetToValueTarget.java |    16 +-
 .../GridifySetToValueTargetInterface.java       |    16 +-
 .../ignite/gridify/NonSpringAopSelfTest.java    |     2 +-
 .../ignite/gridify/SpringAopSelfTest.java       |     2 +-
 .../apache/ignite/gridify/TestAopTarget.java    |    16 +-
 .../ignite/gridify/TestAopTargetInterface.java  |    16 +-
 .../gridify/hierarchy/GridifyHierarchyTest.java |     2 +-
 .../ignite/gridify/hierarchy/SuperTarget.java   |     4 +-
 .../apache/ignite/p2p/P2PGridifySelfTest.java   |     8 +-
 .../singlesplit/SingleSplitsLoadTest.java       |     2 +-
 .../gridify/GridifySingleSplitLoadTest.java     |     6 +-
 .../org/test/gridify/ExternalAopTarget.java     |    16 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |     6 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |     4 +-
 .../s3/S3CheckpointManagerSelfTest.java         |     6 +-
 .../jmh/cache/JmhCacheAbstractBenchmark.java    |     6 +-
 .../internal/TaskEventSubjectIdSelfTest.java    |     4 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |     4 +-
 .../client/ClientDefaultCacheSelfTest.java      |     4 +-
 .../internal/client/ClientStartNodeTask.java    |    14 +-
 .../internal/client/ClientStopNodeTask.java     |     2 +-
 .../ClientTcpSslAuthenticationSelfTest.java     |     4 +-
 ...skExecutionAfterTopologyRestartSelfTest.java |     4 +-
 .../internal/client/ClientTestRestServer.java   |     6 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    17 +-
 .../integration/ClientAbstractSelfTest.java     |     4 +-
 .../integration/ClientPreferDirectSelfTest.java |     4 +-
 .../client/router/ClientFailedInitSelfTest.java |     4 +-
 .../client/router/RouterFactorySelfTest.java    |     4 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |    16 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |     4 +-
 ...cBinaryMarshallerMergeStatementSelfTest.java |     4 +-
 .../jdbc2/JdbcComplexQuerySelfTest.java         |     4 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |     4 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |     4 +-
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java  |     4 +-
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java |     4 +-
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |     4 +-
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java  |     4 +-
 .../jdbc2/JdbcPreparedStatementSelfTest.java    |     4 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |     4 +-
 .../internal/jdbc2/JdbcStatementSelfTest.java   |     4 +-
 .../rest/AbstractRestProcessorSelfTest.java     |     4 +-
 .../rest/ClientMemcachedProtocolSelfTest.java   |     4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |    29 +-
 .../rest/JettyRestProcessorSignedSelfTest.java  |     4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |     4 +-
 .../rest/RestMemcacheProtocolSelfTest.java      |     4 +-
 .../rest/RestProcessorMultiStartSelfTest.java   |     4 +-
 .../rest/RestProcessorStartSelfTest.java        |     8 +-
 .../rest/TaskCommandHandlerSelfTest.java        |     4 +-
 .../rest/protocols/tcp/MockNioSession.java      |     5 +-
 .../tcp/redis/RedisProtocolSelfTest.java        |     4 +-
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java   |     4 +-
 .../ignite/jdbc/JdbcConnectionSelfTest.java     |     6 +-
 .../ignite/jdbc/JdbcEmptyCacheSelfTest.java     |     4 +-
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java    |     4 +-
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |     4 +-
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |     4 +-
 .../jdbc/JdbcPreparedStatementSelfTest.java     |     4 +-
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |     4 +-
 .../ignite/jdbc/JdbcStatementSelfTest.java      |     4 +-
 .../src/test/resources/spring-server-node.xml   |     2 +-
 .../test/resources/spring-server-ssl-node.xml   |     2 +-
 .../src/main/java/org/apache/ignite/Ignite.java |    15 +-
 .../apache/ignite/IgniteSystemProperties.java   |     8 +
 .../main/java/org/apache/ignite/Ignition.java   |    43 +-
 .../org/apache/ignite/IgnitionListener.java     |     2 +-
 .../apache/ignite/binary/BinaryRawReader.java   |    13 +
 .../apache/ignite/binary/BinaryRawWriter.java   |    13 +
 .../org/apache/ignite/binary/BinaryReader.java  |    15 +
 .../org/apache/ignite/binary/BinaryWriter.java  |    15 +
 .../org/apache/ignite/cache/CacheManager.java   |     2 +-
 .../apache/ignite/cache/CacheTypeMetadata.java  |     4 +-
 .../org/apache/ignite/cache/QueryEntity.java    |     4 +-
 .../org/apache/ignite/cache/QueryIndex.java     |    25 +-
 .../affinity/fair/FairAffinityFunction.java     |    33 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |     4 +-
 .../org/apache/ignite/cache/query/SqlQuery.java |     6 +-
 .../apache/ignite/cache/query/TextQuery.java    |     4 +-
 .../apache/ignite/compute/gridify/Gridify.java  |    10 +
 .../ignite/compute/gridify/GridifySetToSet.java |    10 +
 .../compute/gridify/GridifySetToValue.java      |    10 +
 .../configuration/CacheConfiguration.java       |    69 +-
 .../configuration/FileSystemConfiguration.java  |    75 +-
 .../configuration/IgniteConfiguration.java      |   131 +-
 .../local/LocalIgfsSecondaryFileSystem.java     |     6 +-
 .../apache/ignite/internal/GridComponent.java   |    48 +-
 .../apache/ignite/internal/GridDiagnostic.java  |    16 +-
 .../ignite/internal/GridJobSiblingImpl.java     |     4 +-
 .../ignite/internal/GridKernalContext.java      |    28 +-
 .../ignite/internal/GridKernalContextImpl.java  |    52 +-
 .../ignite/internal/GridKernalGatewayImpl.java  |    22 +-
 .../apache/ignite/internal/GridLoggerProxy.java |    25 +-
 .../ignite/internal/GridPluginComponent.java    |    21 +-
 .../org/apache/ignite/internal/GridTopic.java   |     3 +
 .../ignite/internal/IgniteComputeImpl.java      |    15 +-
 .../apache/ignite/internal/IgniteKernal.java    |   203 +-
 .../internal/IgniteNeedReconnectException.java  |    40 +
 .../ignite/internal/IgniteNodeAttributes.java   |    10 +-
 .../ignite/internal/IgniteTransactionsEx.java   |     8 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   286 +-
 .../ignite/internal/MappingStoreTask.java       |    59 +
 .../internal/MarshallerContextAdapter.java      |   211 -
 .../ignite/internal/MarshallerContextImpl.java  |   689 +-
 .../internal/MarshallerMappingFileStore.java    |   174 +
 .../ignite/internal/MarshallerPlatformIds.java  |    30 +
 .../internal/binary/BinaryClassDescriptor.java  |   103 +-
 .../ignite/internal/binary/BinaryContext.java   |    21 +-
 .../internal/binary/BinaryFieldAccessor.java    |    79 +-
 .../binary/BinaryMetadataCollector.java         |    11 +
 .../internal/binary/BinaryObjectImpl.java       |    50 +-
 .../binary/BinaryObjectOffheapImpl.java         |     9 +
 .../internal/binary/BinaryReaderExImpl.java     |   344 +-
 .../binary/BinarySerializedFieldComparator.java |     3 +
 .../ignite/internal/binary/BinaryUtils.java     |   147 +-
 .../ignite/internal/binary/BinaryWriteMode.java |     6 +
 .../internal/binary/BinaryWriterExImpl.java     |    82 +-
 .../internal/binary/GridBinaryMarshaller.java   |     8 +-
 .../binary/builder/BinaryBuilderReader.java     |    37 +
 .../GridClientConnectionManagerAdapter.java     |     2 +-
 .../connection/GridClientNioTcpConnection.java  |     2 +-
 .../GridClientOptimizedMarshaller.java          |    16 +-
 .../client/router/impl/GridTcpRouterImpl.java   |     4 +-
 .../internal/cluster/ClusterGroupAdapter.java   |    10 +-
 .../cluster/ClusterNodeLocalMapImpl.java        |     2 +-
 .../internal/cluster/IgniteClusterImpl.java     |     2 +-
 .../internal/igfs/common/IgfsMarshaller.java    |     4 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |     4 +-
 .../apache/ignite/internal/jdbc2/JdbcUtils.java |     4 +-
 .../internal/managers/GridManagerAdapter.java   |    27 +-
 .../checkpoint/GridCheckpointManager.java       |     4 +-
 .../managers/communication/GridIoManager.java   |   114 +-
 .../communication/GridIoMessageFactory.java     |    38 +-
 .../managers/communication/GridIoPolicy.java    |    10 +-
 .../deployment/GridDeploymentCommunication.java |     6 +-
 .../discovery/GridDiscoveryManager.java         |    94 +-
 .../eventstorage/GridEventStorageManager.java   |     8 +-
 .../failover/GridFailoverContextImpl.java       |    11 -
 .../managers/failover/GridFailoverManager.java  |     3 -
 .../processors/GridProcessorAdapter.java        |    21 +-
 .../affinity/GridAffinityProcessor.java         |     2 +-
 .../processors/cache/CacheObjectContext.java    |     3 +-
 .../cache/CachePartitionExchangeWorkerTask.java |    29 +
 .../internal/processors/cache/CacheType.java    |     8 +-
 .../cache/DynamicCacheChangeBatch.java          |    14 +
 .../processors/cache/GridCacheAdapter.java      |   103 +-
 .../processors/cache/GridCacheAtomicFuture.java |     5 +-
 .../cache/GridCacheClearAllRunnable.java        |     1 +
 .../processors/cache/GridCacheContext.java      |    14 +-
 .../cache/GridCacheDeploymentManager.java       |     8 +-
 .../processors/cache/GridCacheEventManager.java |     4 +-
 .../cache/GridCacheEvictionManager.java         |     9 +-
 .../processors/cache/GridCacheGateway.java      |     3 +-
 .../processors/cache/GridCacheIoManager.java    |    95 +-
 .../processors/cache/GridCacheMessage.java      |    17 +-
 .../processors/cache/GridCacheMvccManager.java  |    50 +-
 .../GridCachePartitionExchangeManager.java      |   189 +-
 .../processors/cache/GridCacheProcessor.java    |   350 +-
 .../processors/cache/GridCacheProxyImpl.java    |     6 +-
 .../processors/cache/GridCacheReturn.java       |     6 +-
 .../cache/GridCacheSharedContext.java           |    17 +-
 .../cache/GridCacheSharedTtlCleanupManager.java |     2 +-
 .../processors/cache/GridCacheTtlManager.java   |     4 +-
 .../processors/cache/GridCacheUtils.java        |    19 +-
 .../cache/GridDeferredAckMessageSender.java     |    17 +-
 .../cache/IgniteCacheOffheapManagerImpl.java    |     4 +-
 .../processors/cache/IgniteCacheProxy.java      |     4 +-
 .../processors/cache/IgniteInternalCache.java   |     5 +-
 .../processors/cache/KeyCacheObjectImpl.java    |    74 +-
 .../IgniteCacheDatabaseSharedManager.java       |     2 +-
 .../distributed/GridCacheCommittedTxInfo.java   |   117 -
 .../distributed/GridDistributedBaseMessage.java |     2 +-
 .../GridDistributedCacheAdapter.java            |     2 +-
 .../distributed/GridDistributedLockRequest.java |    40 +-
 .../GridDistributedTxFinishRequest.java         |   217 +-
 .../GridDistributedTxFinishResponse.java        |    75 +-
 .../distributed/GridDistributedTxMapping.java   |    45 +-
 .../GridDistributedTxPrepareRequest.java        |   205 +-
 .../GridDistributedTxPrepareResponse.java       |    76 +-
 .../GridDistributedTxRemoteAdapter.java         |    59 +-
 .../GridDistributedUnlockRequest.java           |    32 +-
 .../dht/GridClientPartitionTopology.java        |    15 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |    13 +-
 .../distributed/dht/GridDhtLocalPartition.java  |     4 +-
 .../distributed/dht/GridDhtLockRequest.java     |     3 +-
 .../dht/GridDhtPartitionTopology.java           |     9 +
 .../dht/GridDhtPartitionTopologyImpl.java       |    36 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |    57 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |    47 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |   251 +-
 .../dht/GridDhtTxFinishResponse.java            |    70 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   160 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |    28 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   195 +-
 .../dht/GridDhtTxPrepareRequest.java            |   138 +-
 .../dht/GridDhtTxPrepareResponse.java           |   117 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |     3 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |   298 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |   392 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   927 +-
 .../GridDhtAtomicDeferredUpdateResponse.java    |    68 +-
 .../dht/atomic/GridDhtAtomicNearResponse.java   |   314 +
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |   102 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |   277 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    89 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   325 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   124 +-
 ...idNearAtomicAbstractSingleUpdateRequest.java |   498 +-
 .../GridNearAtomicAbstractUpdateFuture.java     |   468 +-
 .../GridNearAtomicAbstractUpdateRequest.java    |   499 +-
 .../GridNearAtomicCheckUpdateRequest.java       |   175 +
 .../atomic/GridNearAtomicFullUpdateRequest.java |   512 +-
 ...GridNearAtomicSingleUpdateFilterRequest.java |    24 +-
 .../GridNearAtomicSingleUpdateFuture.java       |   603 +-
 ...GridNearAtomicSingleUpdateInvokeRequest.java |    38 +-
 .../GridNearAtomicSingleUpdateRequest.java      |    63 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   964 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |   378 +-
 .../dht/atomic/NearCacheUpdates.java            |   335 +
 .../distributed/dht/atomic/UpdateErrors.java    |   222 +
 .../dht/colocated/GridDhtColocatedCache.java    |    14 +-
 .../colocated/GridDhtColocatedLockFuture.java   |    61 +-
 .../dht/preloader/GridDhtPartitionDemander.java |     9 +-
 .../GridDhtPartitionsExchangeFuture.java        |    54 +-
 .../distributed/near/GridNearAtomicCache.java   |    27 +-
 .../distributed/near/GridNearGetRequest.java    |    53 +-
 .../distributed/near/GridNearLockFuture.java    |    24 +-
 .../distributed/near/GridNearLockRequest.java   |   206 +-
 .../distributed/near/GridNearLockResponse.java  |    12 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    72 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |    41 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |    13 +
 .../GridNearPessimisticTxPrepareFuture.java     |    67 +-
 .../near/GridNearSingleGetRequest.java          |    46 +-
 .../near/GridNearTransactionalCache.java        |    10 +-
 .../near/GridNearTxFinishFuture.java            |   176 +-
 .../near/GridNearTxFinishRequest.java           |   174 +-
 .../near/GridNearTxFinishResponse.java          |    36 +-
 .../cache/distributed/near/GridNearTxLocal.java |  2708 ++++-
 .../near/GridNearTxPrepareFutureAdapter.java    |    22 +-
 .../near/GridNearTxPrepareRequest.java          |   254 +-
 .../near/GridNearTxPrepareResponse.java         |    86 +-
 .../distributed/near/GridNearTxRemote.java      |     4 +-
 .../distributed/near/GridNearUnlockRequest.java |     2 +-
 .../distributed/near/IgniteTxMappingsImpl.java  |     4 +-
 .../near/IgniteTxMappingsSingleImpl.java        |     6 +-
 .../cache/query/GridCacheQueryAdapter.java      |     4 +-
 .../cache/query/GridCacheQueryManager.java      |    64 +-
 .../continuous/CacheContinuousQueryHandler.java |     2 +-
 .../store/GridCacheStoreManagerAdapter.java     |   144 +-
 .../cache/store/GridCacheWriteBehindStore.java  |    16 +-
 .../cache/transactions/IgniteInternalTx.java    |    80 +-
 .../transactions/IgniteTransactionsImpl.java    |    12 +-
 .../cache/transactions/IgniteTxAdapter.java     |   165 +-
 .../cache/transactions/IgniteTxEntry.java       |    48 +-
 .../cache/transactions/IgniteTxHandler.java     |   157 +-
 .../IgniteTxImplicitSingleStateImpl.java        |     4 +-
 .../transactions/IgniteTxLocalAdapter.java      |  2807 +----
 .../cache/transactions/IgniteTxLocalEx.java     |   146 +-
 .../cache/transactions/IgniteTxManager.java     |   299 +-
 .../cache/transactions/IgniteTxRemoteEx.java    |    11 +
 .../IgniteTxRemoteStateAdapter.java             |     2 +-
 .../cache/transactions/IgniteTxState.java       |     2 +-
 .../cache/transactions/IgniteTxStateImpl.java   |     4 +-
 .../transactions/TransactionProxyImpl.java      |    13 +-
 .../cacheobject/IgniteCacheObjectProcessor.java |     5 +-
 .../IgniteCacheObjectProcessorImpl.java         |    24 +-
 .../processors/clock/GridClockServer.java       |     2 +-
 .../clock/GridClockSyncProcessor.java           |     4 +-
 .../processors/closure/AffinityTask.java        |     6 -
 .../closure/GridClosureProcessor.java           |    41 +-
 .../processors/cluster/ClusterProcessor.java    |    55 +-
 .../cluster/GridClusterStateProcessor.java      |    19 +-
 .../processors/cluster/GridUpdateNotifier.java  |    14 +-
 .../continuous/GridContinuousProcessor.java     |   148 +-
 .../datastreamer/DataStreamProcessor.java       |     6 +-
 .../datastreamer/DataStreamerImpl.java          |     2 +-
 .../datastructures/DataStructuresProcessor.java |    32 +-
 .../datastructures/GridCacheAtomicLongImpl.java |    18 +-
 .../GridCacheAtomicReferenceImpl.java           |     6 +-
 .../GridCacheAtomicSequenceImpl.java            |     4 +-
 .../GridCacheAtomicStampedImpl.java             |     6 +-
 .../GridCacheCountDownLatchImpl.java            |     6 +-
 .../datastructures/GridCacheLockImpl.java       |    11 +-
 .../datastructures/GridCacheSemaphoreImpl.java  |    18 +-
 .../GridTransactionalCacheQueueImpl.java        |    10 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java |     5 +-
 .../internal/processors/igfs/IgfsContext.java   |     8 +-
 .../processors/igfs/IgfsDataManager.java        |    74 +-
 .../internal/processors/igfs/IgfsFileImpl.java  |     5 +-
 .../igfs/IgfsFragmentizerManager.java           |     4 +-
 .../internal/processors/igfs/IgfsImpl.java      |    32 +-
 .../processors/igfs/IgfsIpcHandler.java         |     2 +-
 .../processors/igfs/IgfsMetaManager.java        |   100 +-
 .../processors/igfs/IgfsNoopProcessor.java      |     2 +-
 .../internal/processors/igfs/IgfsProcessor.java |   131 +-
 .../internal/processors/igfs/IgfsServer.java    |     6 +-
 .../processors/igfs/IgfsServerManager.java      |     2 +-
 .../processors/igfs/IgfsThreadFactory.java      |     6 +-
 .../internal/processors/igfs/IgfsUtils.java     |   320 +-
 .../igfs/client/IgfsClientAbstractCallable.java |    23 +-
 .../igfs/client/IgfsClientAffinityCallable.java |     6 +-
 .../igfs/client/IgfsClientDeleteCallable.java   |     6 +-
 .../igfs/client/IgfsClientExistsCallable.java   |     5 +-
 .../igfs/client/IgfsClientInfoCallable.java     |     5 +-
 .../client/IgfsClientListFilesCallable.java     |     5 +-
 .../client/IgfsClientListPathsCallable.java     |     5 +-
 .../igfs/client/IgfsClientMkdirsCallable.java   |     6 +-
 .../igfs/client/IgfsClientRenameCallable.java   |     6 +-
 .../igfs/client/IgfsClientSetTimesCallable.java |     6 +-
 .../igfs/client/IgfsClientSizeCallable.java     |     5 +-
 .../igfs/client/IgfsClientSummaryCallable.java  |     5 +-
 .../igfs/client/IgfsClientUpdateCallable.java   |     6 +-
 .../meta/IgfsClientMetaIdsForPathCallable.java  |     5 +-
 .../meta/IgfsClientMetaInfoForPathCallable.java |     5 +-
 .../meta/IgfsClientMetaUnlockCallable.java      |     8 +-
 .../secondary/local/LocalFileSystemUtils.java   |    25 +
 .../processors/job/GridJobProcessor.java        |     6 +-
 .../internal/processors/job/GridJobWorker.java  |     4 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |     3 +-
 .../marshaller/ClientRequestFuture.java         |   183 +
 .../GridMarshallerMappingProcessor.java         |   363 +
 .../processors/marshaller/MappedName.java       |    63 +
 .../marshaller/MappingAcceptedMessage.java      |    71 +
 .../marshaller/MappingExchangeResult.java       |    96 +
 .../marshaller/MappingProposedMessage.java      |   137 +
 .../marshaller/MappingUpdatedListener.java      |    29 +
 .../marshaller/MarshallerMappingItem.java       |    99 +
 .../marshaller/MarshallerMappingTransport.java  |   212 +
 .../MissingMappingRequestMessage.java           |   146 +
 .../MissingMappingResponseMessage.java          |   169 +
 .../processors/odbc/OdbcMessageParser.java      |    13 +-
 .../internal/processors/odbc/OdbcProcessor.java |     6 +-
 .../processors/odbc/OdbcRequestHandler.java     |     2 +
 .../platform/PlatformAbstractTarget.java        |     8 +
 .../platform/PlatformAsyncResult.java           |    41 +
 .../platform/PlatformContextImpl.java           |    10 +-
 .../processors/platform/PlatformIgnition.java   |    34 +-
 .../platform/PlatformNoopProcessor.java         |     5 +
 .../platform/PlatformPluginExtension.java       |    39 +
 .../processors/platform/PlatformProcessor.java  |     7 +
 .../platform/PlatformProcessorImpl.java         |    73 +-
 .../processors/platform/PlatformTarget.java     |    10 +
 .../platform/PlatformTargetProxy.java           |     9 +
 .../platform/PlatformTargetProxyImpl.java       |    39 +
 .../cache/PlatformCacheEntryProcessorImpl.java  |     6 +-
 .../callback/PlatformCallbackGateway.java       |   119 +
 .../platform/callback/PlatformCallbackOp.java   |    21 +
 .../platform/compute/PlatformAbstractJob.java   |     2 +-
 .../plugin/PlatformPluginProcessor.java         |    46 +
 .../cache/PlatformCachePluginConfiguration.java |    51 +
 .../cache/PlatformCachePluginProvider.java      |   121 +
 .../utils/PlatformConfigurationUtils.java       |   143 +
 .../platform/utils/PlatformUtils.java           |    56 +-
 .../processors/plugin/CachePluginManager.java   |     8 +-
 .../plugin/IgnitePluginProcessor.java           |    84 +-
 .../internal/processors/pool/PoolProcessor.java |    10 +-
 .../processors/port/GridPortProcessor.java      |     2 +-
 .../query/GridQueryIndexDescriptor.java         |     4 +-
 .../processors/query/GridQueryIndexType.java    |    32 -
 .../processors/query/GridQueryIndexing.java     |    17 +-
 .../processors/query/GridQueryProcessor.java    |  2302 +---
 .../processors/query/GridQueryProperty.java     |    21 +-
 .../query/QueryIndexDescriptorImpl.java         |   111 +
 .../processors/query/QueryTypeCandidate.java    |    66 +
 .../query/QueryTypeDescriptorImpl.java          |   359 +
 .../processors/query/QueryTypeIdKey.java        |    94 +
 .../processors/query/QueryTypeNameKey.java      |    68 +
 .../internal/processors/query/QueryUtils.java   |  1003 ++
 .../query/property/QueryBinaryProperty.java     |   269 +
 .../query/property/QueryClassProperty.java      |   130 +
 .../query/property/QueryFieldAccessor.java      |    67 +
 .../query/property/QueryMethodsAccessor.java    |    82 +
 .../query/property/QueryPropertyAccessor.java   |    53 +
 .../property/QueryReadOnlyMethodsAccessor.java  |    71 +
 .../resource/GridResourceProcessor.java         |     2 +-
 .../processors/rest/GridRestProcessor.java      |     8 +-
 .../cluster/GridChangeStateCommandHandler.java  |     1 +
 .../handlers/task/GridTaskCommandHandler.java   |     4 +-
 .../version/GridVersionCommandHandler.java      |     2 +-
 .../rest/protocols/tcp/GridTcpRestProtocol.java |     2 +-
 .../request/GridRestChangeStateRequest.java     |     2 +-
 .../service/GridServiceProcessor.java           |   153 +-
 .../session/GridTaskSessionProcessor.java       |     2 +-
 .../processors/task/GridTaskProcessor.java      |     4 +-
 .../processors/task/GridTaskWorker.java         |    13 +-
 .../timeout/GridTimeoutProcessor.java           |     6 +-
 .../suggestions/GridPerformanceSuggestions.java |     6 +-
 .../ignite/internal/util/IgniteUtils.java       |   103 +-
 .../ignite/internal/util/StripedExecutor.java   |    38 +-
 .../util/future/GridCompoundFuture.java         |    11 +-
 .../internal/util/ipc/IpcToNioAdapter.java      |     7 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |    22 +-
 .../nio/GridConnectionBytesVerifyFilter.java    |     7 +-
 .../util/nio/GridNioAsyncNotifyFilter.java      |    23 +-
 .../internal/util/nio/GridNioCodecFilter.java   |     9 +-
 .../util/nio/GridNioEmbeddedFuture.java         |     7 +
 .../ignite/internal/util/nio/GridNioFilter.java |    12 +-
 .../internal/util/nio/GridNioFilterAdapter.java |     7 +-
 .../internal/util/nio/GridNioFilterChain.java   |    15 +-
 .../util/nio/GridNioFinishedFuture.java         |     5 -
 .../ignite/internal/util/nio/GridNioFuture.java |     7 -
 .../internal/util/nio/GridNioFutureImpl.java    |    18 +-
 .../ignite/internal/util/nio/GridNioServer.java |   131 +-
 .../internal/util/nio/GridNioSession.java       |     7 +-
 .../internal/util/nio/GridNioSessionImpl.java   |     9 +-
 .../util/nio/GridNioSessionMetaKey.java         |     5 +-
 .../util/nio/GridShmemCommunicationClient.java  |     6 +-
 .../util/nio/GridTcpNioCommunicationClient.java |    13 +-
 .../internal/util/nio/SessionWriteRequest.java  |     7 -
 .../internal/util/nio/ssl/GridNioSslFilter.java |    12 +-
 .../util/nio/ssl/GridNioSslHandler.java         |    29 +-
 .../util/tostring/GridToStringBuilder.java      |     2 +-
 .../ignite/internal/util/worker/GridWorker.java |    22 +-
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |    26 +-
 .../visor/node/VisorBasicConfiguration.java     |    12 +-
 .../visor/node/VisorIgfsConfiguration.java      |     4 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |     8 +-
 .../node/VisorNodeDataCollectorJobResult.java   |    16 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |     2 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |    10 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java |    25 +-
 .../ignite/marshaller/MarshallerContext.java    |    23 +-
 .../optimized/OptimizedMarshallerUtils.java     |    12 +-
 .../apache/ignite/mxbean/IgnitionMXBean.java    |    14 +-
 ...PlatformCachePluginConfigurationClosure.java |    31 +
 ...mCachePluginConfigurationClosureFactory.java |    37 +
 .../PlatformPluginConfigurationClosure.java     |    30 +
 ...atformPluginConfigurationClosureFactory.java |    37 +
 .../java/org/apache/ignite/spi/IgniteSpi.java   |     6 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |    20 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |     6 +
 .../org/apache/ignite/spi/IgniteSpiThread.java  |     6 +-
 .../ignite/spi/IgniteSpiThreadFactory.java      |    10 +-
 .../checkpoint/cache/CacheCheckpointSpi.java    |     4 +-
 .../spi/checkpoint/jdbc/JdbcCheckpointSpi.java  |     2 +-
 .../spi/checkpoint/noop/NoopCheckpointSpi.java  |     2 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |    12 +-
 .../sharedfs/SharedFsTimeoutTask.java           |     6 +-
 .../fifoqueue/FifoQueueCollisionSpi.java        |     4 +-
 .../jobstealing/JobStealingCollisionSpi.java    |     4 +-
 .../spi/collision/noop/NoopCollisionSpi.java    |     2 +-
 .../PriorityQueueCollisionSpi.java              |     4 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    22 +-
 .../deployment/local/LocalDeploymentSpi.java    |     4 +-
 .../ignite/spi/discovery/DiscoveryDataBag.java  |   299 +
 .../spi/discovery/DiscoverySpiDataExchange.java |    15 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   259 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   124 +-
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |    12 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    93 +-
 .../tcp/internal/DiscoveryDataPacket.java       |   345 +
 .../tcp/internal/TcpDiscoveryNode.java          |     6 +-
 .../TcpDiscoveryJoinRequestMessage.java         |    18 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |    10 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |    78 +-
 .../memory/MemoryEventStorageSpi.java           |     4 +-
 .../ignite/spi/failover/FailoverContext.java    |    10 -
 .../spi/failover/always/AlwaysFailoverSpi.java  |     4 +-
 .../jobstealing/JobStealingFailoverSpi.java     |     4 +-
 .../spi/failover/never/NeverFailoverSpi.java    |     4 +-
 .../spi/indexing/noop/NoopIndexingSpi.java      |     2 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |     4 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |     4 +-
 .../WeightedRandomLoadBalancingSpi.java         |     4 +-
 .../ignite/startup/BasicWarmupClosure.java      |     2 +-
 .../startup/cmdline/CommandLineStartup.java     |     6 +-
 .../org/apache/ignite/stream/StreamVisitor.java |     2 +-
 .../ignite/stream/socket/SocketStreamer.java    |     6 +-
 .../thread/IgniteStripedThreadPoolExecutor.java |     6 +-
 .../org/apache/ignite/thread/IgniteThread.java  |    74 +-
 .../ignite/thread/IgniteThreadFactory.java      |    18 +-
 .../ignite/thread/IgniteThreadPoolExecutor.java |    12 +-
 .../resources/META-INF/classnames.properties    |     1 -
 .../test/config/default-spring-url-testing.xml  |     2 +-
 modules/core/src/test/config/igfs-loopback.xml  |    27 -
 modules/core/src/test/config/igfs-shmem.xml     |    27 -
 .../core/src/test/config/load/dsi-load-base.xml |     2 +-
 .../test/config/loaders/grid-cfg-2-grids.xml    |     4 +-
 .../core/src/test/config/loaders/grid-cfg.xml   |     2 +-
 .../config/websession/example-cache-client.xml  |     2 +-
 .../test/config/websession/example-cache2.xml   |     2 +-
 .../test/config/websession/spring-cache-1.xml   |     2 +-
 .../test/config/websession/spring-cache-2.xml   |     2 +-
 .../test/config/websession/spring-cache-3.xml   |     2 +-
 .../org.apache.ignite.plugin.PluginProvider     |     1 +
 ...atformCachePluginConfigurationClosureFactory |     1 +
 ...rm.PlatformPluginConfigurationClosureFactory |     1 +
 .../GridCacheAffinityBackupsSelfTest.java       |     4 +-
 .../ignite/IgniteCacheAffinitySelfTest.java     |     6 +-
 .../cache/IgniteWarmupClosureSelfTest.java      |     4 +-
 .../affinity/AffinityClientNodeSelfTest.java    |     6 +-
 ...ityFunctionBackupFilterAbstractSelfTest.java |     4 +-
 ...unctionExcludeNeighborsAbstractSelfTest.java |     4 +-
 .../affinity/AffinityHistoryCleanupTest.java    |     4 +-
 .../fair/FairAffinityDynamicCacheSelfTest.java  |     4 +-
 .../fair/FairAffinityFunctionNodesSelfTest.java |     4 +-
 .../affinity/fair/FairAffinityNodesRestart.java |   130 +
 .../local/LocalAffinityFunctionTest.java        |     4 +-
 ...cheStoreSessionListenerAbstractSelfTest.java |     4 +-
 ...heStoreSessionListenerLifecycleSelfTest.java |     4 +-
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |     4 +-
 .../IgniteCacheExpiryStoreLoadSelfTest.java     |     4 +-
 .../store/StoreResourceInjectionSelfTest.java   |     4 +-
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |     4 +-
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |     4 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |     4 +-
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |    64 +-
 .../igfs/IgfsFragmentizerAbstractSelfTest.java  |    21 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |     3 +-
 .../internal/ClusterGroupAbstractTest.java      |     4 +-
 .../internal/ClusterGroupHostsSelfTest.java     |     4 +-
 .../ignite/internal/ClusterMetricsSelfTest.java |     4 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |     4 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |     4 +-
 .../ignite/internal/GridAffinityMappedTest.java |    11 +-
 .../internal/GridAffinityP2PSelfTest.java       |    11 +-
 .../ignite/internal/GridAffinitySelfTest.java   |    10 +-
 .../GridAlwaysFailoverSpiFailSelfTest.java      |     4 +-
 .../internal/GridCacheRecreateLockTest.java     |     2 +-
 .../internal/GridCancelUnusedJobSelfTest.java   |     6 +-
 .../GridCancelledJobsMetricsSelfTest.java       |     4 +-
 .../GridCollisionJobsContextSelfTest.java       |    10 +-
 .../internal/GridCommunicationSelfTest.java     |     2 +-
 ...omputationBinarylizableClosuresSelfTest.java |     4 +-
 .../GridContinuousJobAnnotationSelfTest.java    |     4 +-
 .../ignite/internal/GridDeploymentSelfTest.java |    16 +-
 .../internal/GridDiscoveryEventSelfTest.java    |     4 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |     6 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |     2 +-
 ...ventStorageRuntimeConfigurationSelfTest.java |     4 +-
 .../internal/GridFactoryVmShutdownTest.java     |     2 +-
 ...ridFailFastNodeFailureDetectionSelfTest.java |     6 +-
 .../GridFailedInputParametersSelfTest.java      |     2 +-
 .../GridFailoverCustomTopologySelfTest.java     |     4 +-
 .../ignite/internal/GridFailoverSelfTest.java   |     4 +-
 .../GridFailoverTaskWithPredicateSelfTest.java  |     6 +-
 .../internal/GridFailoverTopologySelfTest.java  |     4 +-
 .../ignite/internal/GridGetOrStartSelfTest.java |     8 +-
 .../ignite/internal/GridHomePathSelfTest.java   |     8 +-
 .../GridJobCheckpointCleanupSelfTest.java       |     6 +-
 .../GridJobCollisionCancelSelfTest.java         |     4 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |     4 +-
 .../internal/GridJobStealingSelfTest.java       |     4 +-
 .../GridJobStealingZeroActiveJobsSelfTest.java  |     6 +-
 .../internal/GridLifecycleAwareSelfTest.java    |     4 +-
 .../internal/GridLifecycleBeanSelfTest.java     |    16 +-
 .../GridLocalEventListenerSelfTest.java         |     6 +-
 .../internal/GridMultipleJobsSelfTest.java      |     6 +-
 .../internal/GridMultipleSpisSelfTest.java      |     4 +-
 .../GridMultipleVersionsDeploymentSelfTest.java |     4 +-
 .../GridMultithreadedJobStealingSelfTest.java   |     4 +-
 .../ignite/internal/GridNodeLocalSelfTest.java  |     2 +-
 .../internal/GridNodeMetricsLogSelfTest.java    |     4 +-
 .../GridNodeVisorAttributesSelfTest.java        |     4 +-
 .../internal/GridNonHistoryMetricsSelfTest.java |     4 +-
 .../GridProjectionForCachesSelfTest.java        |    18 +-
 ...ectionLocalJobMultipleArgumentsSelfTest.java |     4 +-
 .../internal/GridReleaseTypeSelfTest.java       |     4 +-
 .../internal/GridRuntimeExceptionSelfTest.java  |     8 +-
 .../internal/GridSpiExceptionSelfTest.java      |     8 +-
 .../ignite/internal/GridStartStopSelfTest.java  |     6 +-
 .../internal/GridStopWithWaitSelfTest.java      |    12 +-
 .../GridTaskFailoverAffinityRunTest.java        |     6 +-
 .../GridTaskFutureImplStopGridSelfTest.java     |     8 +-
 .../GridTaskInstanceExecutionSelfTest.java      |     2 +-
 .../internal/GridTaskJobRejectSelfTest.java     |     4 +-
 .../internal/GridTaskListenerSelfTest.java      |     2 +-
 .../internal/GridTaskMapAsyncSelfTest.java      |     6 +-
 .../internal/GridTaskResultCacheSelfTest.java   |     4 +-
 .../internal/GridTaskTimeoutSelfTest.java       |     8 +-
 .../IgniteClientReconnectAbstractTest.java      |     4 +-
 .../IgniteClientReconnectApiExceptionTest.java  |     4 +-
 .../IgniteClientReconnectCacheTest.java         |    20 +-
 ...niteClientReconnectFailoverAbstractTest.java |     4 +-
 .../IgniteClientReconnectFailoverTest.java      |     4 +-
 .../IgniteClientReconnectStreamerTest.java      |     4 +-
 .../ignite/internal/IgniteClientRejoinTest.java |   378 +
 .../IgniteComputeEmptyClusterGroupTest.java     |     4 +-
 .../internal/IgniteExecutorServiceTest.java     |    14 +-
 ...gniteExplicitImplicitDeploymentSelfTest.java |     4 +-
 .../IgniteLocalNodeMapBeforeStartTest.java      |     2 +-
 ...RoundRobinErrorAfterClientReconnectTest.java |     6 +-
 .../IgniteSlowClientDetectionSelfTest.java      |     7 +-
 ...UpdateNotifierPerClusterSettingSelfTest.java |     4 +-
 .../MarshallerContextLockingSelfTest.java       |    67 +-
 .../ignite/internal/TaskNodeRestartTest.java    |     4 +-
 .../internal/TestRecordingCommunicationSpi.java |    33 +-
 .../BinaryArrayIdentityResolverSelfTest.java    |     4 +-
 .../BinaryConfigurationConsistencySelfTest.java |     4 +-
 .../internal/binary/BinaryEnumsSelfTest.java    |     4 +-
 .../BinaryFieldIdentityResolverSelfTest.java    |     4 +-
 ...ryIdentityResolverConfigurationSelfTest.java |     4 +-
 .../binary/BinaryMarshallerSelfTest.java        |   119 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |     4 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java |     4 +-
 ...ilderSimpleNameLowerCaseMappersSelfTest.java |     4 +-
 .../binary/BinaryObjectExceptionSelfTest.java   |   209 +
 .../binary/BinaryObjectToStringSelfTest.java    |     4 +-
 .../BinarySerialiedFieldComparatorSelfTest.java |     4 +-
 .../internal/binary/BinaryTreeSelfTest.java     |     2 +-
 .../binary/GridBinaryAffinityKeySelfTest.java   |     6 +-
 ...GridBinaryMarshallerCtxDisabledSelfTest.java |    42 +-
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |     4 +-
 ...CaseBinaryMappersBinaryMetaDataSelfTest.java |     4 +-
 ...GridManagerLocalMessageListenerSelfTest.java |     6 +-
 .../managers/GridNoopManagerSelfTest.java       |     2 +-
 .../GridCheckpointManagerAbstractSelfTest.java  |    33 +-
 .../checkpoint/GridCheckpointTaskSelfTest.java  |     4 +-
 ...idCommunicationManagerListenersSelfTest.java |     6 +-
 .../GridCommunicationSendMessageSelfTest.java   |     8 +-
 .../communication/GridIoManagerSelfTest.java    |    28 +-
 .../IgniteCommunicationBalanceTest.java         |     4 +-
 .../communication/IgniteIoTestMessagesTest.java |     4 +-
 .../IgniteVariousConnectionNumberTest.java      |     6 +-
 .../GridDeploymentManagerStopSelfTest.java      |     2 +-
 .../GridDeploymentMessageCountSelfTest.java     |     6 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |     6 +-
 .../GridDiscoveryManagerAttributesSelfTest.java |    10 +-
 .../IgniteTopologyPrintFormatSelfTest.java      |     8 +-
 .../events/GridEventStorageManagerSelfTest.java |     4 +-
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java |     4 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |     4 +-
 .../BinaryObjectOffHeapUnswapTemporaryTest.java |     4 +-
 .../cache/CacheAffinityCallSelfTest.java        |     6 +-
 .../CacheAtomicSingleMessageCountSelfTest.java  |     4 +-
 .../cache/CacheClientStoreSelfTest.java         |     6 +-
 ...cheDhtLocalPartitionAfterRemoveSelfTest.java |     4 +-
 .../cache/CacheEntryProcessorCopySelfTest.java  |     4 +-
 .../cache/CacheEnumOperationsAbstractTest.java  |     4 +-
 ...CacheExchangeMessageDuplicatedStateTest.java |     6 +-
 .../cache/CacheFutureExceptionSelfTest.java     |     6 +-
 .../cache/CacheGetEntryAbstractTest.java        |     4 +-
 ...erceptorPartitionCounterLocalSanityTest.java |     4 +-
 ...torPartitionCounterRandomOperationsTest.java |     4 +-
 .../CacheMetricsForClusterGroupSelfTest.java    |     4 +-
 .../processors/cache/CacheNamesSelfTest.java    |     4 +-
 .../CacheNamesWithSpecialCharactersTest.java    |     4 +-
 .../cache/CacheNearReaderUpdateTest.java        |     4 +-
 .../cache/CacheOffheapMapEntrySelfTest.java     |     6 +-
 .../CachePutEventListenerErrorSelfTest.java     |     4 +-
 .../processors/cache/CachePutIfAbsentTest.java  |     4 +-
 .../cache/CacheReadThroughRestartSelfTest.java  |     6 +-
 .../cache/CacheRebalancingSelfTest.java         |    18 +-
 .../CacheSerializableTransactionsTest.java      |     4 +-
 .../CacheStartupInDeploymentModesTest.java      |     4 +-
 .../cache/CacheStopAndDestroySelfTest.java      |     6 +-
 .../CacheStoreUsageMultinodeAbstractTest.java   |    10 +-
 .../cache/CacheSwapUnswapGetTest.java           |     4 +-
 .../processors/cache/CacheTxFastFinishTest.java |     4 +-
 .../CacheTxNotAllowReadFromBackupTest.java      |     4 +-
 .../processors/cache/CrossCacheLockTest.java    |     6 +-
 .../cache/CrossCacheTxRandomOperationsTest.java |     6 +-
 .../EntryVersionConsistencyReadThroughTest.java |     4 +-
 ...idAbstractCacheInterceptorRebalanceTest.java |     4 +-
 ...ridCacheAbstractByteArrayValuesSelfTest.java |     4 +-
 .../GridCacheAbstractFailoverSelfTest.java      |    16 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |    20 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    |    24 +-
 .../GridCacheAbstractRemoveFailureTest.java     |     6 +-
 .../cache/GridCacheAbstractSelfTest.java        |    10 +-
 .../cache/GridCacheAbstractTxReadTest.java      |     8 +-
 ...acheAbstractUsersAffinityMapperSelfTest.java |     4 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |     4 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |     6 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |     4 +-
 ...eAtomicEntryProcessorDeploymentSelfTest.java |     4 +-
 .../GridCacheAtomicMessageCountSelfTest.java    |    26 +-
 .../cache/GridCacheBasicApiAbstractTest.java    |     4 +-
 .../cache/GridCacheBasicStoreAbstractTest.java  |     4 +-
 ...acheBasicStoreMultithreadedAbstractTest.java |     4 +-
 .../cache/GridCacheClearAllSelfTest.java        |     4 +-
 .../cache/GridCacheClearLocallySelfTest.java    |    10 +-
 .../cache/GridCacheClearSelfTest.java           |     4 +-
 .../cache/GridCacheConcurrentMapSelfTest.java   |     4 +-
 .../cache/GridCacheConcurrentMapTest.java       |     4 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    18 +-
 .../GridCacheConditionalDeploymentSelfTest.java |     4 +-
 ...idCacheConfigurationConsistencySelfTest.java |     4 +-
 ...ridCacheConfigurationValidationSelfTest.java |    40 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |     4 +-
 .../cache/GridCacheDeploymentSelfTest.java      |    22 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |    12 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |     4 +-
 .../GridCacheFinishPartitionsSelfTest.java      |     4 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |     4 +-
 ...idCacheGetAndTransformStoreAbstractTest.java |     4 +-
 .../cache/GridCacheIncrementTransformTest.java  |     4 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |     8 +-
 .../cache/GridCacheIteratorPerformanceTest.java |     4 +-
 .../cache/GridCacheKeyCheckSelfTest.java        |     4 +-
 .../processors/cache/GridCacheLeakTest.java     |     4 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |     4 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |     4 +-
 .../GridCacheMarshallerTxAbstractTest.java      |     4 +-
 .../GridCacheMarshallingNodeJoinSelfTest.java   |     4 +-
 .../cache/GridCacheMemoryModeSelfTest.java      |     4 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |     4 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |     4 +-
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |     4 +-
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |     4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |     4 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |     4 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |     4 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |     2 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |     4 +-
 ...heOffHeapTieredEvictionAbstractSelfTest.java |     4 +-
 .../cache/GridCacheOffheapUpdateSelfTest.java   |     4 +-
 .../GridCacheOnCopyFlagAbstractSelfTest.java    |     4 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |     4 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |     4 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |     4 +-
 ...hePartitionedProjectionAffinitySelfTest.java |     4 +-
 .../cache/GridCachePartitionedWritesTest.java   |     4 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |     4 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    10 +-
 .../GridCacheQueryIndexingDisabledSelfTest.java |     4 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |     4 +-
 .../GridCacheReferenceCleanupSelfTest.java      |     4 +-
 .../cache/GridCacheReloadSelfTest.java          |     4 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |     6 +-
 .../GridCacheReturnValueTransferSelfTest.java   |     4 +-
 .../cache/GridCacheSlowTxWarnTest.java          |     4 +-
 .../processors/cache/GridCacheStopSelfTest.java |     4 +-
 ...ridCacheStoreManagerDeserializationTest.java |     6 +-
 .../cache/GridCacheStorePutxSelfTest.java       |     4 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |     4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |     4 +-
 ...acheTcpClientDiscoveryMultiThreadedTest.java |     4 +-
 .../processors/cache/GridCacheTestStore.java    |     2 -
 .../GridCacheTtlManagerEvictionSelfTest.java    |     4 +-
 .../GridCacheTtlManagerNotificationTest.java    |     4 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |     4 +-
 .../GridCacheValueBytesPreloadingSelfTest.java  |    10 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |     4 +-
 .../GridCacheVariableTopologySelfTest.java      |     4 +-
 .../cache/GridCacheVersionMultinodeTest.java    |     4 +-
 .../GridCacheVersionTopologyChangeTest.java     |     4 +-
 .../cache/GridLocalIgniteSerializationTest.java |    10 +-
 ...ProjectionForCachesOnDaemonNodeSelfTest.java |     4 +-
 .../IgniteCacheAbstractStopBusySelfTest.java    |     6 +-
 .../cache/IgniteCacheAbstractTest.java          |    10 +-
 ...IgniteCacheBinaryEntryProcessorSelfTest.java |     6 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |     6 +-
 ...teCacheConfigurationDefaultTemplateTest.java |     4 +-
 .../IgniteCacheConfigurationTemplateTest.java   |     4 +-
 .../IgniteCacheContainsKeyAbstractSelfTest.java |     8 +-
 ...niteCacheCopyOnReadDisabledAbstractTest.java |     4 +-
 .../cache/IgniteCacheCreateRestartSelfTest.java |     4 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |     9 +-
 ...niteCacheEntryListenerExpiredEventsTest.java |     4 +-
 .../IgniteCacheEntryProcessorCallTest.java      |     8 +-
 .../IgniteCacheEntryProcessorNodeJoinTest.java  |     4 +-
 ...niteCacheExpireAndUpdateConsistencyTest.java |     4 +-
 ...IgniteCacheGetCustomCollectionsSelfTest.java |     4 +-
 .../cache/IgniteCacheIncrementTxTest.java       |     6 +-
 ...gniteCacheInvokeReadThroughAbstractTest.java |     4 +-
 ...gniteCacheLoadRebalanceEvictionSelfTest.java |     4 +-
 .../IgniteCacheManyAsyncOperationsTest.java     |     6 +-
 .../cache/IgniteCacheNearLockValueSelfTest.java |     6 +-
 .../IgniteCacheP2pUnmarshallingErrorTest.java   |     8 +-
 ...gniteCacheP2pUnmarshallingNearErrorTest.java |     4 +-
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java |     6 +-
 .../IgniteCachePartitionMapUpdateTest.java      |     4 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |     8 +-
 .../cache/IgniteCachePutAllRestartTest.java     |     4 +-
 .../IgniteCachePutStackOverflowSelfTest.java    |     4 +-
 .../IgniteCacheReadThroughEvictionSelfTest.java |     2 +-
 .../IgniteCacheReadThroughStoreCallTest.java    |     4 +-
 ...iteCacheScanPredicateDeploymentSelfTest.java |     6 +-
 .../cache/IgniteCacheSerializationSelfTest.java |     6 +-
 .../cache/IgniteCacheStartStopLoadTest.java     |     4 +-
 .../cache/IgniteCacheStoreCollectionTest.java   |     4 +-
 .../IgniteCacheStoreValueAbstractTest.java      |     8 +-
 .../IgniteCacheTopologySafeGetSelfTest.java     |     4 +-
 .../cache/IgniteCacheTxPreloadNoWriteTest.java  |     4 +-
 .../cache/IgniteCachingProviderSelfTest.java    |     8 +-
 .../IgniteClientAffinityAssignmentSelfTest.java |     4 +-
 .../IgniteDaemonNodeMarshallerCacheTest.java    |     4 +-
 .../cache/IgniteDynamicCacheAndNodeStop.java    |     4 +-
 .../cache/IgniteDynamicCacheFilterTest.java     |     4 +-
 ...eDynamicCacheStartNoExchangeTimeoutTest.java |     6 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java  |     4 +-
 ...niteDynamicCacheStartStopConcurrentTest.java |     4 +-
 ...niteDynamicCacheWithConfigStartSelfTest.java |     4 +-
 .../IgniteDynamicClientCacheStartSelfTest.java  |     8 +-
 .../cache/IgniteInternalCacheTypesTest.java     |    17 +-
 ...iteMarshallerCacheClassNameConflictTest.java |   278 +
 ...lerCacheClientRequestsMappingOnMissTest.java |   341 +
 ...eMarshallerCacheConcurrentReadWriteTest.java |     4 +-
 .../cache/IgniteOnePhaseCommitNearSelfTest.java |    10 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |    10 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |    10 +-
 .../IgniteStartCacheInTransactionSelfTest.java  |     4 +-
 .../cache/IgniteStaticCacheStartSelfTest.java   |     4 +-
 .../cache/IgniteSystemCacheOnClientTest.java    |    29 +-
 ...gniteTopologyValidatorAbstractCacheTest.java |    10 +-
 ...niteTopologyValidatorGridSplitCacheTest.java |     2 +-
 .../processors/cache/IgniteTxAbstractTest.java  |     4 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |     4 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |     8 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    10 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |     4 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |     4 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |     8 +-
 .../MarshallerCacheJobRunNodeRestartTest.java   |     4 +-
 .../cache/OffHeapTieredTransactionSelfTest.java |     4 +-
 ...heapCacheMetricsForClusterGroupSelfTest.java |     4 +-
 ...sExchangeOnDiscoveryHistoryOverflowTest.java |     2 +-
 .../CacheKeepBinaryWithInterceptorTest.java     |     4 +-
 .../GridBinaryCacheEntryMemorySizeSelfTest.java |    21 +-
 ...ryDuplicateIndexObjectsAbstractSelfTest.java |     8 +-
 ...acheBinaryObjectUserClassloaderSelfTest.java |    10 +-
 ...naryObjectsAbstractDataStreamerSelfTest.java |     4 +-
 ...aryObjectsAbstractMultiThreadedSelfTest.java |     4 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |     4 +-
 .../GridCacheBinaryStoreAbstractSelfTest.java   |     4 +-
 ...yStoreBinariesSimpleNameMappersSelfTest.java |     4 +-
 ...ntNodeBinaryObjectMetadataMultinodeTest.java |     4 +-
 ...CacheClientNodeBinaryObjectMetadataTest.java |     6 +-
 .../DataStreamProcessorBinarySelfTest.java      |     4 +-
 .../GridDataStreamerImplSelfTest.java           |     4 +-
 .../GridCacheAffinityRoutingBinarySelfTest.java |     4 +-
 ...sNearPartitionedByteArrayValuesSelfTest.java |     4 +-
 ...sPartitionedOnlyByteArrayValuesSelfTest.java |     4 +-
 .../dht/GridCacheMemoryModeBinarySelfTest.java  |     4 +-
 ...dCacheOffHeapTieredAtomicBinarySelfTest.java |     4 +-
 .../GridCacheOffHeapTieredBinarySelfTest.java   |     4 +-
 ...fHeapTieredEvictionAtomicBinarySelfTest.java |     4 +-
 ...acheOffHeapTieredEvictionBinarySelfTest.java |     4 +-
 ...IgniteCacheAbstractExecutionContextTest.java |     8 +-
 ...niteCacheContinuousExecutionContextTest.java |     4 +-
 ...IgniteCacheIsolatedExecutionContextTest.java |     4 +-
 ...niteCacheP2PDisableExecutionContextTest.java |     4 +-
 .../IgniteCachePrivateExecutionContextTest.java |     4 +-
 .../IgniteCacheSharedExecutionContextTest.java  |     4 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |    46 +-
 ...actQueueFailoverDataConsistencySelfTest.java |     4 +-
 .../GridCacheQueueCleanupSelfTest.java          |     4 +-
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |     6 +-
 .../GridCacheSequenceApiSelfAbstractTest.java   |     4 +-
 .../IgniteAtomicLongApiAbstractSelfTest.java    |     4 +-
 .../IgniteAtomicsAbstractTest.java              |     4 +-
 .../IgniteClientDataStructuresAbstractTest.java |     6 +-
 .../IgniteCollectionAbstractTest.java           |     4 +-
 .../IgniteDataStructureUniqueNameTest.java      |     4 +-
 .../IgniteDataStructureWithJobTest.java         |     4 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |     2 +-
 ...SemaphoreFailoverSafeReleasePermitsTest.java |     4 +-
 ...achePartitionedAtomicSequenceTxSelfTest.java |     4 +-
 ...idCachePartitionedNodeRestartTxSelfTest.java |     4 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |     4 +-
 .../CacheAbstractRestartSelfTest.java           |     6 +-
 .../distributed/CacheAffinityEarlyTest.java     |     4 +-
 ...acheAsyncOperationsFailoverAbstractTest.java |     8 +-
 .../distributed/CacheAsyncOperationsTest.java   |     6 +-
 .../CacheGetFutureHangsSelfTest.java            |     4 +-
 .../CacheGetInsideLockChangingTopologyTest.java |     4 +-
 ...ffinityAssignmentNodeJoinValidationTest.java |     4 +-
 .../CacheLateAffinityAssignmentTest.java        |    59 +-
 ...CacheLoadingConcurrentGridStartSelfTest.java |    12 +-
 .../CacheLockReleaseNodeLeaveTest.java          |     4 +-
 .../CachePutAllFailoverAbstractTest.java        |     8 +-
 .../CacheTryLockMultithreadedTest.java          |     4 +-
 ...tractDistributedByteArrayValuesSelfTest.java |     4 +-
 .../GridCacheAbstractJobExecutionTest.java      |     8 +-
 .../GridCacheAbstractNodeRestartSelfTest.java   |     4 +-
 ...tractPartitionedByteArrayValuesSelfTest.java |     4 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java   |     4 +-
 .../GridCacheBasicOpAbstractTest.java           |     4 +-
 .../GridCacheClientModesAbstractSelfTest.java   |    24 +-
 ...ientModesTcpClientDiscoveryAbstractTest.java |     4 +-
 ...acheEntrySetIterationPreloadingSelfTest.java |     4 +-
 .../distributed/GridCacheEventAbstractTest.java |     2 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |     4 +-
 .../distributed/GridCacheLockAbstractTest.java  |     4 +-
 .../distributed/GridCacheMixedModeSelfTest.java |    12 +-
 .../GridCacheMultiNodeAbstractTest.java         |     4 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |     4 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |     8 +-
 .../GridCacheNodeFailureAbstractTest.java       |     4 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |     8 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |     4 +-
 .../GridCachePreloadEventsAbstractSelfTest.java |     4 +-
 .../GridCachePreloadLifecycleAbstractTest.java  |     4 +-
 ...GridCachePreloadRestartAbstractSelfTest.java |     4 +-
 .../GridCacheTransformEventSelfTest.java        |     4 +-
 ...yMetadataUpdateChangingTopologySelfTest.java |    11 +-
 ...niteBinaryMetadataUpdateNodeRestartTest.java |     4 +-
 .../distributed/IgniteCache150ClientsTest.java  |     6 +-
 ...micMessageRecoveryPairedConnectionsTest.java |     4 +-
 ...niteCacheClientNodeChangingTopologyTest.java |    22 +-
 .../IgniteCacheClientNodeConcurrentStart.java   |     6 +-
 ...teCacheClientNodePartitionsExchangeTest.java |     8 +-
 .../IgniteCacheClientReconnectTest.java         |     4 +-
 ...acheConnectionRecovery10ConnectionsTest.java |     4 +-
 .../IgniteCacheConnectionRecoveryTest.java      |     4 +-
 .../IgniteCacheCreatePutMultiNodeSelfTest.java  |     4 +-
 .../distributed/IgniteCacheCreatePutTest.java   |     4 +-
 .../distributed/IgniteCacheGetRestartTest.java  |     6 +-
 .../distributed/IgniteCacheManyClientsTest.java |     4 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java |     6 +-
 ...eCacheMessageRecoveryIdleConnectionTest.java |     4 +-
 .../IgniteCacheMessageWriteTimeoutTest.java     |     4 +-
 .../IgniteCacheNearOffheapGetSelfTest.java      |    12 +-
 .../IgniteCacheNearRestartRollbackSelfTest.java |    12 +-
 .../IgniteCacheNodeJoinAbstractTest.java        |     4 +-
 .../distributed/IgniteCachePrimarySyncTest.java |     4 +-
 .../IgniteCachePutGetRestartAbstractTest.java   |    10 +-
 .../IgniteCacheReadFromBackupTest.java          |     4 +-
 .../IgniteCacheServerNodeConcurrentStart.java   |     4 +-
 .../IgniteCacheSingleGetMessageTest.java        |     4 +-
 .../IgniteCacheSizeFailoverTest.java            |     4 +-
 .../IgniteCacheSystemTransactionsSelfTest.java  |    29 +-
 .../IgniteCacheTxFairAffinityNodeJoinTest.java  |     4 +-
 .../IgniteCacheTxIteratorSelfTest.java          |     4 +-
 ...arDisabledFairAffinityPutGetRestartTest.java |     4 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |    16 +-
 .../IgniteTxCachePrimarySyncTest.java           |     6 +-
 ...teSynchronizationModesMultithreadedTest.java |     4 +-
 ...iteTxConsistencyRestartAbstractSelfTest.java |    10 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |    14 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |    12 +-
 .../IgniteTxPreloadAbstractTest.java            |     4 +-
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |     4 +-
 ...heAbstractTransformWriteThroughSelfTest.java |     4 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java     |     4 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |    41 +-
 .../dht/GridCacheColocatedDebugTest.java        |     4 +-
 ...eColocatedOptimisticTransactionSelfTest.java |     4 +-
 ...dCacheColocatedTxSingleThreadedSelfTest.java |     4 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |     4 +-
 .../dht/GridCacheDhtEntrySetSelfTest.java       |     4 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |     4 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |     4 +-
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |     4 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |     4 +-
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |     4 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |     9 +-
 .../GridCacheDhtPreloadDisabledSelfTest.java    |     6 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |     4 +-
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |    10 +-
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |     4 +-
 .../dht/GridCacheDhtPreloadPerformanceTest.java |     4 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |     4 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |    16 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |     8 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |     4 +-
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |     4 +-
 .../dht/GridCacheGlobalLoadTest.java            |     4 +-
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...ePartitionedNearDisabledMetricsSelfTest.java |     8 +-
 ...idCachePartitionedPreloadEventsSelfTest.java |     4 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |     6 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |     4 +-
 ...ridCachePartitionedUnloadEventsSelfTest.java |     4 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java     |    10 +-
 .../dht/GridNearCacheTxNodeFailureSelfTest.java |     4 +-
 ...gniteAtomicLongChangingTopologySelfTest.java |     4 +-
 .../IgniteCacheCommitDelayTxRecoveryTest.java   |     4 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |     4 +-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |     6 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java    |     8 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |     4 +-
 ...artitionedBackupNodeFailureRecoveryTest.java |     4 +-
 ...woBackupsPrimaryNodeFailureRecoveryTest.java |     4 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |    13 +-
 .../IgniteCachePutRetryAbstractSelfTest.java    |    41 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |     2 +-
 .../dht/IgniteCacheTxRecoveryRollbackTest.java  |   501 +
 .../dht/IgniteCrossCacheTxSelfTest.java         |     4 +-
 .../AtomicPutAllChangingTopologyTest.java       |     2 +-
 .../atomic/GridCacheAtomicFailoverSelfTest.java |     4 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |     6 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |     4 +-
 ...AtomicPrimaryWriteOrderFailoverSelfTest.java |     4 +-
 .../atomic/IgniteCacheAtomicProtocolTest.java   |   883 ++
 ...tionedMultiNodeLongTxTimeoutFullApiTest.java |     4 +-
 ...nabledMultiNodeLongTxTimeoutFullApiTest.java |     4 +-
 ...nlyFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |     4 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |     4 +-
 ...yOnReadDisabledMultiNodeFullApiSelfTest.java |     4 +-
 ...micFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |     4 +-
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |     4 +-
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |     4 +-
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |     4 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |     4 +-
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |     4 +-
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |     4 +-
 ...idCacheAtomicPartitionedMetricsSelfTest.java |     4 +-
 ...derFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 .../near/GridCacheGetStoreErrorSelfTest.java    |     4 +-
 .../near/GridCacheNearEvictionSelfTest.java     |     4 +-
 .../near/GridCacheNearJobExecutionSelfTest.java |     4 +-
 .../near/GridCacheNearMetricsSelfTest.java      |     4 +-
 .../near/GridCacheNearMultiGetSelfTest.java     |     8 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |     4 +-
 ...nlyFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |    10 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |     4 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |     4 +-
 .../GridCacheNearPartitionedClearSelfTest.java  |     4 +-
 .../GridCacheNearReaderPreloadSelfTest.java     |     6 +-
 .../near/GridCacheNearReadersSelfTest.java      |    24 +-
 .../near/GridCacheNearTxForceKeyTest.java       |     4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |     4 +-
 .../near/GridCacheNearTxPreloadSelfTest.java    |     4 +-
 ...AffinityExcludeNeighborsPerformanceTest.java |     4 +-
 ...rtitionedAffinityHashIdResolverSelfTest.java |     4 +-
 .../GridCachePartitionedAffinitySelfTest.java   |    20 +-
 .../near/GridCachePartitionedBasicApiTest.java  |     4 +-
 .../GridCachePartitionedBasicOpSelfTest.java    |     4 +-
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |     4 +-
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |     4 +-
 ...yOnReadDisabledMultiNodeFullApiSelfTest.java |     4 +-
 .../near/GridCachePartitionedEventSelfTest.java |     2 +-
 .../GridCachePartitionedEvictionSelfTest.java   |     4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |     4 +-
 ...GridCachePartitionedFilteredPutSelfTest.java |     4 +-
 .../GridCachePartitionedFullApiSelfTest.java    |     8 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |     4 +-
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |     4 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |     4 +-
 .../near/GridCachePartitionedLockSelfTest.java  |     4 +-
 .../GridCachePartitionedMetricsSelfTest.java    |     8 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |    79 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |    12 +-
 ...onedMultiNodeP2PDisabledFullApiSelfTest.java |     4 +-
 .../GridCachePartitionedMultiNodeSelfTest.java  |     4 +-
 ...ePartitionedMultiThreadedPutGetSelfTest.java |     4 +-
 .../near/GridCachePartitionedNestedTxTest.java  |     4 +-
 ...edNoStripedPoolMultiNodeFullApiSelfTest.java |    35 -
 ...GridCachePartitionedNodeFailureSelfTest.java |     4 +-
 .../GridCachePartitionedNodeRestartTest.java    |     4 +-
 ...ePartitionedOptimisticTxNodeRestartTest.java |     4 +-
 ...achePartitionedPreloadLifecycleSelfTest.java |     4 +-
 .../GridCachePartitionedStorePutSelfTest.java   |     4 +-
 ...GridCachePartitionedTxConcurrentGetTest.java |     4 +-
 ...GridCachePartitionedTxMultiNodeSelfTest.java |     4 +-
 ...CachePartitionedTxMultiThreadedSelfTest.java |     4 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    11 +-
 ...achePartitionedTxSingleThreadedSelfTest.java |     4 +-
 .../GridCachePartitionedTxTimeoutSelfTest.java  |     4 +-
 .../near/GridCachePutArrayValueSelfTest.java    |     4 +-
 ...idCacheRendezvousAffinityClientSelfTest.java |     4 +-
 .../near/GridPartitionedBackupLoadSelfTest.java |     4 +-
 .../near/IgniteCacheNearOnlyTxTest.java         |     6 +-
 .../near/IgniteCacheNearTxRollbackTest.java     |     4 +-
 .../near/NearCacheMultithreadedUpdateTest.java  |     4 +-
 .../near/NearCachePutAllMultinodeTest.java      |     4 +-
 .../near/NearCacheSyncUpdateTest.java           |     4 +-
 .../near/NoneRebalanceModeSelfTest.java         |     4 +-
 ...cingDelayedPartitionMapExchangeSelfTest.java |     4 +-
 .../GridCacheRebalancingAsyncSelfTest.java      |     4 +-
 .../GridCacheRebalancingOrderingTest.java       |     6 +-
 .../GridCacheRebalancingSyncCheckDataTest.java  |     4 +-
 .../GridCacheRebalancingSyncSelfTest.java       |     6 +-
 ...eRebalancingUnmarshallingFailedSelfTest.java |     4 +-
 ...xcludeNeighborsMultiNodeFullApiSelfTest.java |     4 +-
 ...tedFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...xcludeNeighborsMultiNodeFullApiSelfTest.java |     4 +-
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...stractReplicatedByteArrayValuesSelfTest.java |     4 +-
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |     4 +-
 ...nedFairAffinityMultiNodeFullApiSelfTest.java |     4 +-
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |     4 +-
 .../GridCacheReplicatedBasicApiTest.java        |     4 +-
 .../GridCacheReplicatedBasicOpSelfTest.java     |     4 +-
 .../GridCacheReplicatedEvictionSelfTest.java    |     4 +-
 .../GridCacheReplicatedFullApiSelfTest.java     |     4 +-
 .../GridCacheReplicatedJobExecutionTest.java    |     4 +-
 .../GridCacheReplicatedMarshallerTxTest.java    |     4 +-
 .../GridCacheReplicatedMetricsSelfTest.java     |     4 +-
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |     4 +-
 .../GridCacheReplicatedMultiNodeSelfTest.java   |     4 +-
 .../GridCacheReplicatedNodeFailureSelfTest.java |     4 +-
 .../GridCacheReplicatedTxConcurrentGetTest.java |     4 +-
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |     4 +-
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |     4 +-
 ...CacheReplicatedTxSingleThreadedSelfTest.java |     4 +-
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |     4 +-
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |     6 +-
 .../GridCacheSyncReplicatedPreloadSelfTest.java |     4 +-
 .../replicated/GridReplicatedTxPreloadTest.java |     4 +-
 .../IgniteCacheSyncRebalanceModeSelfTest.java   |     4 +-
 ...CacheReplicatedPreloadLifecycleSelfTest.java |     4 +-
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |     4 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |    14 +-
 ...eplicatedPreloadStartStopEventsSelfTest.java |     4 +-
 .../cache/eviction/EvictionAbstractTest.java    |     4 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |     4 +-
 ...heConcurrentEvictionConsistencySelfTest.java |     4 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |     4 +-
 .../GridCacheDistributedEvictionsSelfTest.java  |     4 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |     4 +-
 .../GridCacheEvictionFilterSelfTest.java        |     4 +-
 .../GridCacheEvictionLockUnlockSelfTest.java    |     4 +-
 .../GridCacheEvictionTouchSelfTest.java         |     4 +-
 ...cheSynchronousEvictionsFailoverSelfTest.java |     4 +-
 .../lru/LruNearEvictionPolicySelfTest.java      |     4 +-
 .../LruNearOnlyNearEvictionPolicySelfTest.java  |     4 +-
 .../SortedEvictionPolicyPerformanceTest.java    |     4 +-
 .../IgniteCacheClientNearCacheExpiryTest.java   |     6 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |     4 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |     4 +-
 .../expiry/IgniteCacheTtlCleanupSelfTest.java   |     4 +-
 .../IgniteCacheLoadAllAbstractTest.java         |     4 +-
 ...iteCacheNoLoadPreviousValueAbstractTest.java |     8 +-
 .../IgniteCacheNoReadThroughAbstractTest.java   |     8 +-
 .../IgniteCacheNoWriteThroughAbstractTest.java  |     8 +-
 ...IgniteCacheStoreNodeRestartAbstractTest.java |     6 +-
 .../IgniteCacheStoreSessionAbstractTest.java    |     6 +-
 ...acheStoreSessionWriteBehindAbstractTest.java |     6 +-
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |     4 +-
 .../GridCacheAtomicLocalMetricsSelfTest.java    |     4 +-
 .../local/GridCacheLocalBasicApiSelfTest.java   |     4 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java  |     4 +-
 .../local/GridCacheLocalFullApiSelfTest.java    |     4 +-
 .../local/GridCacheLocalLoadAllSelfTest.java    |     4 +-
 .../local/GridCacheLocalMetricsSelfTest.java    |     8 +-
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |     4 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java |     4 +-
 ...LocalCacheOffHeapAndSwapMetricsSelfTest.java |     4 +-
 .../BinaryTxCacheLocalEntriesSelfTest.java      |     8 +-
 .../GridCacheQueryTransformerSelfTest.java      |     4 +-
 .../GridCacheSwapScanQueryAbstractSelfTest.java |     4 +-
 .../cache/query/IndexingSpiQuerySelfTest.java   |     2 +-
 .../cache/query/IndexingSpiQueryTxSelfTest.java |     8 +-
 .../continuous/CacheContinuousBatchAckTest.java |    12 +-
 ...heContinuousBatchForceServerModeAckTest.java |     8 +-
 ...eContinuousQueryAsyncFilterListenerTest.java |     6 +-
 ...CacheContinuousQueryCounterAbstractTest.java |     8 +-
 ...acheContinuousQueryExecuteInPrimaryTest.java |     4 +-
 ...ContinuousQueryFailoverAbstractSelfTest.java |    21 +-
 .../CacheContinuousQueryLostPartitionTest.java  |     6 +-
 ...ontinuousQueryOperationFromCallbackTest.java |     4 +-
 .../CacheContinuousQueryOperationP2PTest.java   |     4 +-
 .../CacheContinuousQueryOrderingEventTest.java  |     4 +-
 ...acheContinuousQueryRandomOperationsTest.java |     4 +-
 .../CacheContinuousQueryVariationsTest.java     |     6 +-
 ...eEntryProcessorExternalizableFailedTest.java |     4 +-
 .../CacheEntryProcessorNonSerializableTest.java |     4 +-
 .../CacheKeepBinaryIterationTest.java           |     4 +-
 .../ClientReconnectContinuousQueryTest.java     |     2 +-
 ...yRemoteFilterMissingInClassPathSelfTest.java |     4 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    12 +-
 .../GridCacheContinuousQueryConcurrentTest.java |     6 +-
 ...eContinuousQueryMultiNodesFilteringTest.java |    10 +-
 ...eContinuousQueryReplicatedTxOneNodeTest.java |     4 +-
 ...niteCacheContinuousQueryBackupQueueTest.java |     4 +-
 ...CacheContinuousQueryClientReconnectTest.java |     4 +-
 .../IgniteCacheContinuousQueryClientTest.java   |     4 +-
 ...eCacheContinuousQueryImmutableEntryTest.java |     6 +-
 ...teCacheContinuousQueryNoUnsubscribeTest.java |     4 +-
 ...IgniteCacheContinuousQueryReconnectTest.java |     4 +-
 ...BehindStorePartitionedMultiNodeSelfTest.java |     4 +-
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java |     4 +-
 ...CacheClientWriteBehindStoreAbstractTest.java |    12 +-
 .../TxDeadlockDetectionNoHangsTest.java         |     4 +-
 .../transactions/TxDeadlockDetectionTest.java   |     4 +-
 ...timisticDeadlockDetectionCrossCacheTest.java |     4 +-
 .../TxOptimisticDeadlockDetectionTest.java      |    34 +-
 ...simisticDeadlockDetectionCrossCacheTest.java |     4 +-
 .../TxPessimisticDeadlockDetectionTest.java     |     4 +-
 ...edEntryPartitionedAtomicOffHeapSelfTest.java |     4 +-
 ...PartitionedTransactionalOffHeapSelfTest.java |     4 +-
 ...nedEntryReplicatedAtomicOffHeapSelfTest.java |     4 +-
 ...yReplicatedTransactionalOffHeapSelfTest.java |     4 +-
 .../clock/GridTimeSyncProcessorSelfTest.java    |     4 +-
 .../closure/GridClosureProcessorRemoteTest.java |     2 +-
 .../closure/GridClosureProcessorSelfTest.java   |     4 +-
 .../closure/GridClosureSerializationTest.java   |     4 +-
 .../cluster/GridAddressResolverSelfTest.java    |     6 +-
 ...ComputeJobExecutionErrorToLogManualTest.java |     4 +-
 .../compute/PublicThreadpoolStarvationTest.java |     4 +-
 .../continuous/GridEventConsumeSelfTest.java    |     4 +-
 .../continuous/GridMessageListenSelfTest.java   |     4 +-
 .../IgniteNoCustomEventsOnNodeStart.java        |     4 +-
 .../DataStreamProcessorSelfTest.java            |    10 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |     4 +-
 .../DataStreamerMultiThreadedSelfTest.java      |     4 +-
 .../DataStreamerMultinodeCreateCacheTest.java   |     4 +-
 .../datastreamer/DataStreamerTimeoutTest.java   |     4 +-
 .../DataStreamerUpdateAfterLoadTest.java        |     4 +-
 .../IgniteDataStreamerPerformanceTest.java      |     4 +-
 .../igfs/IgfsAbstractBaseSelfTest.java          |    23 +-
 .../igfs/IgfsBackupFailoverSelfTest.java        |    20 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |    23 +-
 ...sCachePerBlockLruEvictionPolicySelfTest.java |    22 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |    23 +-
 .../processors/igfs/IgfsCommonAbstractTest.java |     8 +-
 .../igfs/IgfsDataManagerSelfTest.java           |    37 +-
 .../processors/igfs/IgfsMaxSizeSelfTest.java    |    12 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |    10 +-
 .../processors/igfs/IgfsMetricsSelfTest.java    |    20 +-
 .../processors/igfs/IgfsModesSelfTest.java      |    55 +-
 .../processors/igfs/IgfsOneClientNodeTest.java  |    17 +-
 .../processors/igfs/IgfsProcessorSelfTest.java  |    29 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   |   324 +-
 ...gfsSecondaryFileSystemInjectionSelfTest.java |     8 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    21 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |    31 +-
 .../processors/igfs/IgfsStartCacheTest.java     |    30 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |    50 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |    10 +-
 .../IgfsAbstractRecordResolverSelfTest.java     |    10 +-
 ...niteMessagingConfigVariationFullApiTest.java |     6 +-
 .../odbc/OdbcProcessorValidationSelfTest.java   |     2 +-
 .../service/ClosureServiceClientsNodesTest.java |    10 +-
 .../service/GridServiceClientNodeTest.java      |     4 +-
 .../GridServiceContinuousQueryRedeployTest.java |   167 +
 .../GridServiceProcessorAbstractSelfTest.java   |     4 +-
 ...GridServiceProxyClientReconnectSelfTest.java |     6 +-
 .../GridServiceProxyNodeStopSelfTest.java       |     4 +-
 .../GridServiceSerializationSelfTest.java       |     6 +-
 ...gniteServiceConfigVariationsFullApiTest.java |     4 +-
 ...yment2ClassLoadersDefaultMarshallerTest.java |    18 +-
 ...oymentClassLoadingDefaultMarshallerTest.java |    16 +-
 .../IgniteServiceDynamicCachesSelfTest.java     |     4 +-
 ...gniteServiceProxyTimeoutInitializedTest.java |     6 +-
 .../service/IgniteServiceReassignmentTest.java  |     4 +-
 .../ServicePredicateAccessCacheTest.java        |     4 +-
 .../internal/util/IgniteUtilsSelfTest.java      |    66 +
 .../nio/GridNioEmbeddedFutureSelfTest.java      |     2 +-
 .../util/future/nio/GridNioFutureSelfTest.java  |    25 +-
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |    30 +-
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |     6 +-
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |     2 +-
 .../internal/util/nio/GridNioSelfTest.java      |     2 +-
 .../internal/util/nio/GridNioSslSelfTest.java   |     2 +-
 .../nio/IgniteExceptionInNioWorkerSelfTest.java |     6 +-
 .../nio/impl/GridNioFilterChainSelfTest.java    |    12 +-
 .../loadtests/GridCacheMultiNodeLoadTest.java   |     4 +-
 .../communication/GridIoManagerBenchmark.java   |     4 +-
 .../communication/GridIoManagerBenchmark0.java  |    18 +-
 .../GridTcpCommunicationBenchmark.java          |     2 +-
 .../GridCachePartitionedAtomicLongLoadTest.java |     4 +-
 .../multisplit/GridMultiSplitsLoadTest.java     |     4 +-
 .../GridMultiSplitsRedeployLoadTest.java        |     2 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |     8 +-
 .../GridSingleSplitsRedeployLoadTest.java       |     2 +-
 .../direct/session/GridSessionLoadTest.java     |     2 +-
 .../direct/stealing/GridStealingLoadTest.java   |     4 +-
 .../ignite/loadtests/job/GridJobLoadTest.java   |     6 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |     2 +-
 ...namicProxySerializationMultiJvmSelfTest.java |     4 +-
 .../marshaller/GridMarshallerAbstractTest.java  |    15 +-
 .../marshaller/MarshallerContextSelfTest.java   |   150 +-
 .../marshaller/MarshallerContextTestImpl.java   |    33 +-
 .../OptimizedMarshallerEnumSelfTest.java        |    25 +-
 .../OptimizedMarshallerNodeFailoverTest.java    |     4 +-
 ...GridMessagingNoPeerClassLoadingSelfTest.java |     4 +-
 .../ignite/messaging/GridMessagingSelfTest.java |     4 +-
 .../IgniteMessagingWithClientTest.java          |     6 +-
 .../p2p/GridAbstractMultinodeRedeployTest.java  |     4 +-
 .../GridP2PContinuousDeploymentSelfTest.java    |    18 +-
 .../GridP2PDifferentClassLoaderSelfTest.java    |     4 +-
 .../p2p/GridP2PDoubleDeploymentSelfTest.java    |     4 +-
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |     4 +-
 .../p2p/GridP2PJobClassLoaderSelfTest.java      |     4 +-
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |     4 +-
 .../GridP2PMissedResourceCacheSizeSelfTest.java |     4 +-
 .../ignite/p2p/GridP2PNodeLeftSelfTest.java     |     4 +-
 .../p2p/GridP2PRecursionTaskSelfTest.java       |     4 +-
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |     4 +-
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |     4 +-
 .../ignite/p2p/GridP2PTimeoutSelfTest.java      |     4 +-
 .../ignite/p2p/GridP2PUndeploySelfTest.java     |     6 +-
 .../platform/PlatformComputeEchoTask.java       |    18 +
 .../PlatformJavaObjectFactoryProxySelfTest.java |     2 +-
 .../ignite/platform/PlatformStopIgniteTask.java |    10 +-
 .../platform/plugin/PlatformTestPlugin.java     |    27 +
 .../plugin/PlatformTestPluginConfiguration.java |    63 +
 ...rmTestPluginConfigurationClosureFactory.java |    61 +
 .../plugin/PlatformTestPluginException.java     |    34 +
 .../plugin/PlatformTestPluginExtension.java     |    51 +
 .../plugin/PlatformTestPluginProvider.java      |   103 +
 .../plugin/PlatformTestPluginTarget.java        |   231 +
 .../cache/PlatformGetCachePluginsTask.java      |    85 +
 .../PlatformTestCachePluginConfiguration.java   |    55 +
 ...formTestCachePluginConfigurationClosure.java |    48 +
 .../cache/PlatformTestCachePluginProvider.java  |    72 +
 ...SessionCancelSiblingsFromFutureSelfTest.java |     6 +-
 ...ridSessionCancelSiblingsFromJobSelfTest.java |     6 +-
 ...idSessionCancelSiblingsFromTaskSelfTest.java |     6 +-
 .../GridSessionCheckpointAbstractSelfTest.java  |     2 +-
 .../GridSessionCollisionSpiSelfTest.java        |     2 +-
 ...idSessionFutureWaitJobAttributeSelfTest.java |     6 +-
 ...dSessionFutureWaitTaskAttributeSelfTest.java |     6 +-
 .../session/GridSessionJobFailoverSelfTest.java |     4 +-
 ...GridSessionJobWaitTaskAttributeSelfTest.java |     6 +-
 .../ignite/session/GridSessionLoadSelfTest.java |     4 +-
 .../GridSessionSetFutureAttributeSelfTest.java  |     6 +-
 ...nSetFutureAttributeWaitListenerSelfTest.java |     6 +-
 .../GridSessionSetJobAttributeSelfTest.java     |     6 +-
 ...sionSetJobAttributeWaitListenerSelfTest.java |     6 +-
 .../GridSessionSetTaskAttributeSelfTest.java    |     6 +-
 ...GridSessionTaskWaitJobAttributeSelfTest.java |     6 +-
 .../GridSessionWaitAttributeSelfTest.java       |     8 +-
 .../spi/GridSpiStartStopAbstractTest.java       |     2 +-
 .../spi/GridTcpSpiForwardingSelfTest.java       |    10 +-
 .../CacheCheckpointSpiSecondCacheSelfTest.java  |     4 +-
 .../GridAbstractCommunicationSelfTest.java      |     4 +-
 .../communication/GridCacheMessageSelfTest.java |     6 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |     4 +-
 .../GridTcpCommunicationSpiAbstractTest.java    |     4 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |     4 +-
 .../GridTcpCommunicationSpiConfigSelfTest.java  |     2 +-
 .../tcp/GridTcpCommunicationSpiLanTest.java     |     2 +-
 ...cpCommunicationSpiMultithreadedSelfTest.java |     4 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |     4 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |     4 +-
 .../tcp/IgniteCacheSslStartStopSelfTest.java    |     4 +-
 ...CommunicationRecoveryAckClosureSelfTest.java |     4 +-
 .../discovery/AbstractDiscoverySelfTest.java    |     9 +-
 ...gniteClientReconnectMassiveShutdownTest.java |     4 +-
 ...pClientDiscoveryMarshallerCheckSelfTest.java |     6 +-
 .../tcp/TcpClientDiscoverySpiMulticastTest.java |     4 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |    64 +-
 .../tcp/TcpDiscoveryConcurrentStartTest.java    |     4 +-
 .../TcpDiscoveryMarshallerCheckSelfTest.java    |     4 +-
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |     8 +-
 ...veryNodeAttributesUpdateOnReconnectTest.java |   110 +
 ...DiscoveryNodeConfigConsistentIdSelfTest.java |     6 +-
 .../TcpDiscoveryNodeConsistentIdSelfTest.java   |     4 +-
 .../discovery/tcp/TcpDiscoveryRestartTest.java  |     4 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |   139 +-
 .../tcp/TcpDiscoverySnapshotHistoryTest.java    |     4 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |     2 +-
 .../tcp/TcpDiscoverySpiStartStopSelfTest.java   |    11 +-
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java    |     4 +-
 .../TcpDiscoverySslSecuredUnsecuredTest.java    |   185 +
 .../discovery/tcp/TcpDiscoverySslSelfTest.java  |     4 +-
 .../tcp/TestReconnectPluginProvider.java        |   118 +
 .../discovery/tcp/TestReconnectProcessor.java   |    93 +
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java      |     2 +-
 .../spi/failover/GridFailoverTestContext.java   |     7 +-
 .../GridInternalTasksLoadBalancingSelfTest.java |     6 +-
 .../ignite/startup/GridVmNodesStarter.java      |     4 +-
 .../stream/socket/SocketStreamerSelfTest.java   |     4 +-
 .../testframework/GridSpiTestContext.java       |     5 +
 .../ignite/testframework/GridTestNode.java      |     2 +-
 .../ignite/testframework/GridTestUtils.java     |    10 +-
 .../configvariations/ConfigFactory.java         |     8 +-
 .../ConfigVariationsFactory.java                |     6 +-
 .../testframework/junits/GridAbstractTest.java  |   213 +-
 ...IgniteCacheConfigVariationsAbstractTest.java |    12 +-
 .../IgniteConfigVariationsAbstractTest.java     |    12 +-
 .../junits/common/GridAbstractExamplesTest.java |     2 +-
 .../junits/common/GridCommonAbstractTest.java   |    15 +-
 .../common/GridRollingRestartAbstractTest.java  |     6 +-
 .../junits/multijvm/IgniteNodeRunner.java       |    55 +-
 .../junits/multijvm/IgniteProcessProxy.java     |   109 +-
 .../junits/spi/GridSpiAbstractConfigTest.java   |     2 +-
 .../junits/spi/GridSpiAbstractTest.java         |    13 +-
 .../testsuites/IgniteBinaryBasicTestSuite.java  |     5 +
 .../IgniteBinaryObjectsTestSuite.java           |     2 +
 .../IgniteCacheFullApiSelfTestSuite.java        |     6 +-
 .../IgniteCacheRestartTestSuite2.java           |     3 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |     1 +
 .../testsuites/IgniteCacheTestSuite5.java       |     5 +
 .../IgniteCacheTxRecoverySelfTestSuite.java     |     3 +
 .../IgniteClientReconnectTestSuite.java         |     2 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |     2 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |     5 +
 .../ignite/thread/IgniteThreadPoolSizeTest.java |     8 -
 .../util/AttributeNodeFilterSelfTest.java       |     4 +-
 .../apache/ignite/util/GridRandomSelfTest.java  |    17 -
 .../util/GridTopologyHeapSizeSelfTest.java      |     4 +-
 .../org.apache.ignite.plugin.PluginProvider     |     1 +
 .../h2/GridBinaryH2IndexingGeoSelfTest.java     |     4 +-
 modules/hadoop/pom.xml                          |     7 +
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |   190 +-
 .../hadoop/impl/igfs/HadoopIgfsUtils.java       |     6 +
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java     |    99 +-
 .../hadoop/impl/v1/HadoopV1MapTask.java         |     2 +-
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |    10 +-
 .../hadoop/shuffle/HadoopShuffle.java           |     5 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |     6 +-
 .../HadoopEmbeddedTaskExecutor.java             |     2 +-
 .../taskexecutor/HadoopExecutorService.java     |    10 +-
 .../external/HadoopExternalTaskExecutor.java    |     2 +-
 .../HadoopExternalCommunication.java            |    29 +-
 .../communication/HadoopIpcToNioAdapter.java    |     7 +-
 .../communication/HadoopMarshallerFilter.java   |    10 +-
 .../test/config/hadoop-fs-open-test/grid-0.xml  |   126 +
 .../test/config/hadoop-fs-open-test/grid-1.xml  |   126 +
 .../test/config/hadoop-fs-open-test/grid-2.xml  |   126 +
 .../test/config/igfs-cli-config-dual-async.xml  |   135 +
 .../test/config/igfs-cli-config-dual-sync.xml   |   133 +
 .../src/test/config/igfs-cli-config-primary.xml |   124 +
 .../src/test/config/igfs-cli-config-proxy.xml   |   133 +
 .../impl/HadoopAbstractMapReduceTest.java       |    12 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |    28 +-
 .../hadoop/impl/HadoopGroupingTest.java         |     4 +-
 .../hadoop/impl/HadoopJobTrackerSelfTest.java   |     4 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |     4 +-
 .../impl/HadoopNoHadoopMapReduceTest.java       |     4 +-
 .../hadoop/impl/HadoopSortingExternalTest.java  |     8 +-
 .../hadoop/impl/HadoopSortingTest.java          |     4 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |     4 +-
 .../hadoop/impl/HadoopTeraSortTest.java         |     4 +-
 .../hadoop/impl/HadoopValidationSelfTest.java   |     4 +-
 .../HadoopClientProtocolEmbeddedSelfTest.java   |     4 +-
 ...opClientProtocolMultipleServersSelfTest.java |     4 +-
 .../impl/igfs/Hadoop1DualAbstractTest.java      |     6 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |    10 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |    74 +-
 ...Igfs20FileSystemLoopbackPrimarySelfTest.java |     4 +-
 ...oopIgfs20FileSystemShmemPrimarySelfTest.java |     4 +-
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |    14 +-
 ...oopSecondaryFileSystemConfigurationTest.java |    91 +-
 .../igfs/IgfsNearOnlyMultiNodeSelfTest.java     |    14 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |   204 +-
 ...opFileSystemClientBasedAbstractSelfTest.java |   193 +
 ...pFileSystemClientBasedDualAsyncSelfTest.java |    38 +
 ...opFileSystemClientBasedDualSyncSelfTest.java |    38 +
 ...niteHadoopFileSystemClientBasedOpenTest.java |   305 +
 ...oopFileSystemClientBasedPrimarySelfTest.java |    38 +
 ...adoopFileSystemClientBasedProxySelfTest.java |    37 +
 .../IgniteHadoopFileSystemClientSelfTest.java   |    60 +-
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |   107 +-
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java |    53 +-
 ...niteHadoopFileSystemLoggerStateSelfTest.java |    24 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |     4 +-
 ...oopbackExternalToClientAbstractSelfTest.java |    61 +
 ...opbackExternalToClientDualAsyncSelfTest.java |    33 +
 ...oopbackExternalToClientDualSyncSelfTest.java |    33 +
 ...LoopbackExternalToClientPrimarySelfTest.java |    33 +
 ...emLoopbackExternalToClientProxySelfTest.java |    33 +
 ...condaryFileSystemInitializationSelfTest.java |    34 +-
 ...teHadoopFileSystemShmemAbstractSelfTest.java |     4 +-
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 -
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 -
 ...emShmemExternalToClientAbstractSelfTest.java |   106 +
 ...mShmemExternalToClientDualAsyncSelfTest.java |    33 +
 ...emShmemExternalToClientDualSyncSelfTest.java |    33 +
 ...temShmemExternalToClientPrimarySelfTest.java |    33 +
 ...ystemShmemExternalToClientProxySelfTest.java |    33 +
 .../HadoopExternalTaskExecutionSelfTest.java    |    16 +-
 .../testsuites/IgniteHadoopTestSuite.java       |    21 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |    17 +-
 .../HibernateReadWriteAccessStrategy.java       |    12 +-
 .../cache/hibernate/HibernateRegionFactory.java |    25 +-
 .../src/test/config/factory-cache1.xml          |     2 +-
 .../HibernateL2CacheConfigurationSelfTest.java  |    20 +-
 .../hibernate/HibernateL2CacheSelfTest.java     |    24 +-
 .../HibernateL2CacheTransactionalSelfTest.java  |     4 +-
 .../query/h2/DmlStatementsProcessor.java        |   100 +-
 .../processors/query/h2/IgniteH2Indexing.java   |    46 +-
 .../query/h2/dml/UpdatePlanBuilder.java         |   109 +-
 .../query/h2/opt/GridH2IndexBase.java           |    10 -
 .../processors/query/h2/opt/GridH2Table.java    |    33 -
 .../query/h2/opt/GridH2TreeIndex.java           |    34 -
 .../query/h2/opt/GridLuceneIndex.java           |     4 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |     8 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |     7 +-
 ...CacheAbstractQueryDetailMetricsSelfTest.java |     4 +-
 .../CacheAbstractQueryMetricsSelfTest.java      |     4 +-
 .../CacheBinaryKeyConcurrentQueryTest.java      |     4 +-
 .../cache/CacheIndexStreamerTest.java           |     4 +-
 .../cache/CacheIndexingOffheapCleanupTest.java  |    21 -
 .../CacheOffheapBatchIndexingBaseTest.java      |     4 +-
 .../cache/CacheQueryBuildValueTest.java         |     4 +-
 .../cache/CacheQueryNewClientSelfTest.java      |     4 +-
 .../CacheRandomOperationsMultithreadedTest.java |     4 +-
 ...CacheScanPartitionQueryFallbackSelfTest.java |     6 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   |     6 +-
 .../ClientReconnectAfterClusterRestartTest.java |     6 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |     4 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |     4 +-
 .../cache/GridCacheOffHeapSelfTest.java         |     4 +-
 .../GridCacheOffheapIndexEntryEvictTest.java    |     4 +-
 .../cache/GridCacheOffheapIndexGetSelfTest.java |     4 +-
 .../GridCacheQueryIndexDisabledSelfTest.java    |     4 +-
 .../GridCacheQuerySerializationSelfTest.java    |     4 +-
 .../cache/GridCacheQuerySimpleBenchmark.java    |     4 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java |     4 +-
 .../IgniteBinaryObjectFieldsQuerySelfTest.java  |     6 +-
 .../IgniteBinaryObjectQueryArgumentsTest.java   |     4 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |    25 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |     8 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   105 +-
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java |     6 +-
 .../IgniteCacheCollocatedQuerySelfTest.java     |     4 +-
 ...acheConfigurationPrimitiveTypesSelfTest.java |     4 +-
 .../IgniteCacheCrossCacheJoinRandomTest.java    |     4 +-
 ...acheDistributedJoinCollocatedAndNotTest.java |     4 +-
 ...acheDistributedJoinCustomAffinityMapper.java |     4 +-
 .../IgniteCacheDistributedJoinNoIndexTest.java  |     4 +-
 ...ributedJoinPartitionedAndReplicatedTest.java |     4 +-
 ...CacheDistributedJoinQueryConditionsTest.java |     4 +-
 .../cache/IgniteCacheDistributedJoinTest.java   |     4 +-
 ...cheDuplicateEntityConfigurationSelfTest.java |     4 +-
 .../IgniteCacheFieldsQueryNoDataSelfTest.java   |     4 +-
 ...teCacheFullTextQueryNodeJoiningSelfTest.java |     4 +-
 .../IgniteCacheInsertSqlQuerySelfTest.java      |    26 +-
 ...PartitionedAndReplicatedCollocationTest.java |     4 +-
 ...teCacheJoinPartitionedAndReplicatedTest.java |     4 +-
 ...IgniteCacheJoinQueryWithAffinityKeyTest.java |     4 +-
 .../cache/IgniteCacheLargeResultSelfTest.java   |     4 +-
 ...eLockPartitionOnAffinityRunAbstractTest.java |     4 +-
 ...PartitionOnAffinityRunAtomicCacheOpTest.java |     4 +-
 ...titionOnAffinityRunWithCollisionSpiTest.java |     6 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |    24 +
 .../cache/IgniteCacheNoClassQuerySelfTest.java  |     4 +-
 .../cache/IgniteCacheOffheapEvictQueryTest.java |     4 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java  |     4 +-
 ...CacheOffheapTieredMultithreadedSelfTest.java |     4 +-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |     4 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |     4 +-
 ...IgniteCachePrimitiveFieldsQuerySelfTest.java |     4 +-
 .../cache/IgniteCacheQueriesLoadTest1.java      |     4 +-
 .../IgniteCacheQueryH2IndexingLeakTest.java     |     4 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java     |     8 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |     4 +-
 ...gniteCacheSqlQueryMultiThreadedSelfTest.java |     4 +-
 .../IgniteCacheStarvationOnRebalanceTest.java   |     4 +-
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |    65 +-
 ...ClientReconnectCacheQueriesFailoverTest.java |     4 +-
 .../cache/IgniteClientReconnectQueriesTest.java |     4 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |     4 +-
 .../cache/IncorrectCacheTypeMetadataTest.java   |     4 +-
 .../cache/IncorrectQueryEntityTest.java         |     4 +-
 ...lientQueryReplicatedNodeRestartSelfTest.java |    10 +-
 ...niteCacheDistributedQueryCancelSelfTest.java |     6 +-
 ...butedQueryStopOnCancelOrTimeoutSelfTest.java |     6 +-
 ...artitionedFieldsQueryP2PEnabledSelfTest.java |     4 +-
 ...achePartitionedQueryP2PDisabledSelfTest.java |     4 +-
 ...cheQueryAbstractDistributedJoinSelfTest.java |     6 +-
 .../near/IgniteCacheQueryNodeFailTest.java      |     4 +-
 .../IgniteCacheQueryNodeRestartSelfTest.java    |     4 +-
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |     4 +-
 ...ReplicatedFieldsQueryP2PEnabledSelfTest.java |     4 +-
 ...CacheReplicatedQueryP2PDisabledSelfTest.java |     4 +-
 ...eCacheLocalQueryCancelOrTimeoutSelfTest.java |     4 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java     |     4 +-
 .../query/IgniteSqlQueryDedicatedPoolTest.java  |   110 +
 .../query/IgniteSqlSplitterSelfTest.java        |    43 +-
 .../query/h2/GridH2IndexRebuildTest.java        |   261 -
 .../h2/GridIndexingSpiAbstractSelfTest.java     |    35 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |    54 -
 .../h2/sql/AbstractH2CompareQueryTest.java      |     4 +-
 .../query/h2/sql/GridQueryParsingTest.java      |     4 +-
 .../FetchingQueryCursorStressTest.java          |     2 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java   |     4 +-
 .../IgniteCacheQuerySelfTestSuite.java          |     4 +-
 .../processors/cache/jta/CacheJtaManager.java   |     3 +-
 .../processors/cache/jta/CacheJtaResource.java  |     8 +-
 .../cache/AbstractCacheJtaSelfTest.java         |     8 +-
 ...CacheJtaConfigurationValidationSelfTest.java |     4 +-
 ...CacheJtaFactoryConfigValidationSelfTest.java |     4 +-
 .../cache/GridJtaLifecycleAwareSelfTest.java    |     4 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |     6 +-
 .../log4j2/GridLog4j2CorrectFileNameTest.java   |     6 +-
 .../log4j2/GridLog4j2InitializedTest.java       |     2 +-
 .../logger/log4j2/Log4j2LoggerSelfTest.java     |     6 +-
 .../log4j2/Log4j2LoggerVerboseModeSelfTest.java |     6 +-
 .../IgniteAbstractOsgiContextActivator.java     |     2 +-
 .../activators/BasicIgniteTestActivator.java    |     2 +-
 .../include/ignite/binary/binary_object.h       |    22 +-
 .../include/ignite/binary/binary_raw_reader.h   |    19 +
 .../include/ignite/binary/binary_raw_writer.h   |    15 +
 .../include/ignite/binary/binary_reader.h       |    21 +
 .../binary/include/ignite/binary/binary_type.h  |     8 +-
 .../include/ignite/binary/binary_writer.h       |    17 +
 .../include/ignite/impl/binary/binary_common.h  |    12 +
 .../ignite/impl/binary/binary_object_header.h   |     9 +-
 .../ignite/impl/binary/binary_object_impl.h     |    61 +-
 .../ignite/impl/binary/binary_reader_impl.h     |   159 +-
 .../ignite/impl/binary/binary_type_updater.h    |     2 +-
 .../include/ignite/impl/binary/binary_utils.h   |    25 +-
 .../ignite/impl/binary/binary_writer_impl.h     |    46 +-
 .../binary/binary_array_identity_resolver.cpp   |     2 +-
 .../cpp/binary/src/binary/binary_raw_reader.cpp |    10 +
 .../cpp/binary/src/binary/binary_raw_writer.cpp |    10 +
 .../cpp/binary/src/binary/binary_reader.cpp     |    12 +-
 .../cpp/binary/src/binary/binary_writer.cpp     |    10 +
 .../src/impl/binary/binary_object_header.cpp    |    26 +-
 .../src/impl/binary/binary_object_impl.cpp      |    61 +-
 .../src/impl/binary/binary_reader_impl.cpp      |   177 +-
 .../src/impl/binary/binary_type_manager.cpp     |     2 +-
 .../cpp/binary/src/impl/binary/binary_utils.cpp |    12 +
 .../src/impl/binary/binary_writer_impl.cpp      |   105 +-
 modules/platforms/cpp/common/Makefile.am        |     4 +-
 .../platforms/cpp/common/include/Makefile.am    |     1 +
 .../common/include/ignite/common/concurrent.h   |    29 +-
 .../include/ignite/common/platform_utils.h      |     6 +-
 .../cpp/common/include/ignite/common/utils.h    |    78 +-
 .../cpp/common/include/ignite/ignite_error.h    |     2 +-
 .../platforms/cpp/common/include/ignite/time.h  |   138 +
 .../include/ignite/common/dynamic_load_os.h     |   131 +
 .../os/linux/src/common/dynamic_load_os.cpp     |    90 +
 .../os/linux/src/common/platform_utils.cpp      |    18 +-
 .../win/include/ignite/common/dynamic_load_os.h |   133 +
 .../os/win/src/common/dynamic_load_os.cpp       |   115 +
 .../common/os/win/src/common/platform_utils.cpp |    26 +-
 .../cpp/common/project/vs/common.vcxproj        |     4 +
 .../common/project/vs/common.vcxproj.filters    |    12 +
 .../platforms/cpp/common/src/common/utils.cpp   |    33 +-
 .../platforms/cpp/common/src/ignite_error.cpp   |    68 +-
 modules/platforms/cpp/common/src/time.cpp       |    83 +
 modules/platforms/cpp/core-test/Makefile.am     |     6 +-
 .../cpp/core-test/config/cache-query.xml        |    23 +
 .../core-test/include/ignite/binary_test_defs.h |   106 +-
 .../include/ignite/binary_test_utils.h          |    53 +
 .../cpp/core-test/include/ignite/test_type.h    |    21 +-
 .../cpp/core-test/project/vs/core-test.vcxproj  |     3 +
 .../project/vs/core-test.vcxproj.filters        |     9 +
 .../cpp/core-test/src/binary_object_test.cpp    |   116 +-
 .../src/binary_reader_writer_raw_test.cpp       |   735 +-
 .../core-test/src/binary_reader_writer_test.cpp |   911 +-
 .../cpp/core-test/src/binary_session_test.cpp   |    18 +
 .../cpp/core-test/src/cache_invoke_test.cpp     |   525 +
 .../cpp/core-test/src/cache_query_test.cpp      |    65 +-
 .../platforms/cpp/core-test/src/cache_test.cpp  |    17 +-
 .../cpp/core-test/src/cluster_test.cpp          |    81 +
 .../cpp/core-test/src/date_time_test.cpp        |   287 +
 .../cpp/core-test/src/interop_memory_test.cpp   |     3 +-
 .../platforms/cpp/core-test/src/test_utils.cpp  |     6 +-
 modules/platforms/cpp/core/Makefile.am          |     1 +
 modules/platforms/cpp/core/include/Makefile.am  |    10 +-
 .../cpp/core/include/ignite/cache/cache.h       |   217 +-
 .../ignite/cache/cache_entry_processor.h        |   111 +
 .../include/ignite/cache/mutable_cache_entry.h  |   176 +
 .../include/ignite/cache/query/query_argument.h |   134 -
 .../include/ignite/cache/query/query_cursor.h   |     2 +-
 .../core/include/ignite/cache/query/query_sql.h |    16 +-
 .../ignite/cache/query/query_sql_fields.h       |    16 +-
 .../platforms/cpp/core/include/ignite/ignite.h  |    18 +
 .../cpp/core/include/ignite/ignite_binding.h    |   119 +
 .../include/ignite/ignite_binding_context.h     |    88 +
 .../core/include/ignite/ignite_configuration.h  |     2 -
 .../impl/binary/binary_type_updater_impl.h      |     2 +-
 .../impl/cache/cache_entry_processor_holder.h   |   282 +
 .../core/include/ignite/impl/cache/cache_impl.h |    71 +-
 .../ignite/impl/cache/query/query_argument.h    |   137 +
 .../ignite/impl/cluster/cluster_group_impl.h    |    77 +
 .../include/ignite/impl/ignite_binding_impl.h   |   121 +
 .../include/ignite/impl/ignite_environment.h    |    61 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |    50 +-
 .../ignite/impl/interop/interop_target.h        |    39 +-
 .../core/include/ignite/impl/module_manager.h   |   131 +
 .../cpp/core/include/ignite/impl/operations.h   |    62 +-
 .../platforms/cpp/core/project/vs/core.vcxproj  |    11 +-
 .../cpp/core/project/vs/core.vcxproj.filters    |    36 +-
 modules/platforms/cpp/core/src/ignite.cpp       |    12 +-
 modules/platforms/cpp/core/src/ignition.cpp     |   343 +-
 .../impl/binary/binary_type_updater_impl.cpp    |     2 +-
 .../cpp/core/src/impl/cache/cache_impl.cpp      |    74 +-
 .../continuous/continuous_query_handle_impl.cpp |     2 +-
 .../core/src/impl/cache/query/query_impl.cpp    |     8 +-
 .../src/impl/cluster/cluster_group_impl.cpp     |    64 +
 .../cpp/core/src/impl/ignite_environment.cpp    |    92 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |    32 +-
 .../core/src/impl/interop/interop_target.cpp    |    51 +-
 .../src/impl/transactions/transactions_impl.cpp |    14 +-
 .../cpp/jni/include/ignite/jni/exports.h        |     2 +
 .../platforms/cpp/jni/include/ignite/jni/java.h |     6 +-
 .../cpp/jni/include/ignite/jni/utils.h          |    78 +-
 .../platforms/cpp/jni/os/linux/src/utils.cpp    |   227 +-
 modules/platforms/cpp/jni/os/win/src/utils.cpp  |   233 +-
 modules/platforms/cpp/jni/project/vs/module.def |     2 +
 modules/platforms/cpp/jni/src/exports.cpp       |     8 +
 modules/platforms/cpp/jni/src/java.cpp          |    76 +-
 .../cpp/odbc-test/config/queries-default.xml    |     2 +-
 .../odbc-test/include/sql_test_suite_fixture.h  |     7 +-
 .../platforms/cpp/odbc-test/include/test_type.h |    33 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |     1 +
 .../project/vs/odbc-test.vcxproj.filters        |     3 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |     1 -
 .../src/application_data_buffer_test.cpp        |   224 +-
 .../platforms/cpp/odbc-test/src/cursor_test.cpp |     6 +-
 .../cpp/odbc-test/src/queries_test.cpp          |   107 +-
 .../src/sql_date_time_functions_test.cpp        |     5 +
 .../src/sql_esc_convert_function_test.cpp       |     8 +-
 .../odbc-test/src/sql_test_suite_fixture.cpp    |    33 +-
 .../cpp/odbc-test/src/sql_types_test.cpp        |    24 +-
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |     7 +
 .../ignite/odbc/app/application_data_buffer.h   |    15 +
 .../cpp/odbc/include/ignite/odbc/message.h      |     2 +-
 .../cpp/odbc/include/ignite/odbc/type_traits.h  |     5 +-
 .../cpp/odbc/install/install_amd64.cmd          |    10 +-
 .../platforms/cpp/odbc/install/install_x86.cmd  |     6 +-
 .../odbc/src/app/application_data_buffer.cpp    |   184 +
 .../platforms/cpp/odbc/src/app/parameter.cpp    |     7 +
 modules/platforms/cpp/odbc/src/column.cpp       |    19 +
 modules/platforms/cpp/odbc/src/type_traits.cpp  |    13 +-
 modules/platforms/cpp/odbc/src/utility.cpp      |    17 +-
 .../Apache.Ignite.AspNet.Tests/App.config       |     6 +-
 .../IgniteOutputCacheProviderTest.cs            |     2 +-
 .../IgniteSessionStateStoreProviderTest.cs      |     2 +-
 .../Apache.Ignite.AspNet/Impl/ConfigUtil.cs     |     4 +-
 .../SchemaTest.cs                               |     2 +-
 .../Apache.Ignite.Core.Tests.csproj             |    10 +
 .../Binary/BinaryBuilderSelfTest.cs             |    22 +-
 .../Binary/BinaryReaderWriterTest.cs            |     8 +
 .../Cache/Affinity/AffinityFieldTest.cs         |     2 +-
 .../Cache/Affinity/AffinityFunctionTest.cs      |     4 +-
 .../Cache/Affinity/AffinityTest.cs              |     2 +-
 .../Cache/CacheAbstractTest.cs                  |     2 +-
 .../Cache/CacheConfigurationTest.cs             |    15 +-
 .../Cache/CacheDynamicStartTest.cs              |     2 +-
 .../Cache/CacheMetricsTest.cs                   |     2 +-
 .../Cache/CacheNearTest.cs                      |     4 +-
 .../Cache/Query/CacheLinqTest.cs                |     2 +-
 .../Cache/Query/CacheQueriesTest.cs             |     2 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |     4 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |     2 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |     2 +-
 .../Cache/Store/CacheStoreTest.cs               |     2 +-
 .../Compute/ComputeApiTest.cs                   |    87 +-
 .../Cache/Affinity/affinity-function2.xml       |     2 +-
 .../Config/Compute/compute-grid1.xml            |     2 +-
 .../Config/Compute/compute-grid2.xml            |     2 +-
 .../Config/Compute/compute-grid3.xml            |     2 +-
 .../Config/Lifecycle/lifecycle-beans.xml        |     2 +-
 .../Config/Lifecycle/lifecycle-no-beans.xml     |     2 +-
 .../Config/start-test-grid1.xml                 |     2 +-
 .../Config/start-test-grid2.xml                 |     2 +-
 .../ConsoleRedirectTest.cs                      |     4 +-
 .../Dataload/DataStreamerTest.cs                |     2 +-
 .../Dataload/DataStreamerTestTopologyChange.cs  |     2 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |    30 +-
 .../IgniteConfigurationSectionTest.cs           |     2 +-
 .../IgniteConfigurationSerializerTest.cs        |    86 +-
 .../IgniteConfigurationTest.cs                  |    21 +-
 .../Log/CustomLoggerTest.cs                     |     2 +-
 .../Cache/CacheJavaPluginConfiguration.cs       |    45 +
 .../Plugin/Cache/CacheJavaPluginTest.cs         |   113 +
 .../Plugin/Cache/CachePlugin.cs                 |   127 +
 .../Plugin/Cache/CachePluginConfiguration.cs    |    64 +
 .../Plugin/Cache/CachePluginTest.cs             |   218 +
 .../Plugin/PluginTest.cs                        |   342 +
 .../Plugin/TestIgnitePlugin.cs                  |    39 +
 .../Plugin/TestIgnitePluginConfiguration.cs     |    53 +
 .../Plugin/TestIgnitePluginException.cs         |    64 +
 .../Plugin/TestIgnitePluginProvider.cs          |   153 +
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |     2 +-
 .../SerializationTest.cs                        |     2 +-
 .../dotnet/Apache.Ignite.Core.Tests/app.config  |     4 +-
 .../Apache.Ignite.Core.Tests/custom_app.config  |     2 +-
 .../Apache.Ignite.Core.csproj                   |    20 +
 .../Binary/BinaryArrayEqualityComparer.cs       |     5 +-
 .../Cache/Configuration/CacheConfiguration.cs   |    46 +
 .../Cache/Configuration/QueryEntity.cs          |     2 +-
 .../Common/ExceptionFactory.cs                  |    31 +
 .../Apache.Ignite.Core/Common/IgniteGuid.cs     |    47 +-
 .../Apache.Ignite.Core/Common/JavaException.cs  |    62 +-
 .../Communication/Tcp/TcpCommunicationSpi.cs    |     2 +-
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |     2 +-
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |     2 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |     7 +-
 .../Apache.Ignite.Core/Events/JobEvent.cs       |     4 +-
 .../Apache.Ignite.Core/Events/TaskEvent.cs      |     2 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |    10 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |    78 +-
 .../IgniteConfigurationSection.xsd              |    49 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |     2 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |     2 +-
 .../Impl/Binary/BinaryReader.cs                 |     4 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |    16 +-
 .../Impl/Binary/BinaryUtils.cs                  |    55 +-
 .../Impl/Binary/BinaryWriter.cs                 |     6 +-
 .../Impl/Binary/Io/BinaryHeapStream.cs          |     3 +
 .../Impl/Binary/Marshaller.cs                   |     4 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |   276 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    96 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |    26 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |     6 +
 .../Impl/Memory/PlatformMemoryStream.cs         |     4 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |    99 +-
 .../Impl/Plugin/Cache/CachePluginContext.cs     |    82 +
 .../Impl/Plugin/Cache/CachePluginProcessor.cs   |    77 +
 .../Plugin/Cache/CachePluginProviderProxy.cs    |    75 +
 .../Plugin/Cache/ICachePluginProviderProxy.cs   |    52 +
 .../Impl/Plugin/IPluginProviderProxy.cs         |    74 +
 .../Impl/Plugin/PluginContext.cs                |   100 +
 .../Impl/Plugin/PluginProcessor.cs              |   359 +
 .../Impl/Plugin/PluginProviderProxy.cs          |    90 +
 .../Transactions/CacheTransactionManager.cs     |    13 +
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |     6 +
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |     9 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |    94 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |    12 +
 .../Interop/IPlatformTarget.cs                  |   103 +
 .../Cache/CachePluginProviderTypeAttribute.cs   |    52 +
 .../Plugin/Cache/ICachePluginConfiguration.cs   |    66 +
 .../Plugin/Cache/ICachePluginContext.cs         |    47 +
 .../Plugin/Cache/ICachePluginProvider.cs        |    52 +
 .../Plugin/IPluginConfiguration.cs              |    61 +
 .../Apache.Ignite.Core/Plugin/IPluginContext.cs |    76 +
 .../Plugin/IPluginProvider.cs                   |    69 +
 .../Apache.Ignite.Core/Plugin/PluginCallback.cs |    29 +
 .../Plugin/PluginNotFoundException.cs           |    65 +
 .../Plugin/PluginProviderTypeAttribute.cs       |    52 +
 .../App.config                                  |     4 +-
 .../EntityFrameworkCacheInitializationTest.cs   |     2 +-
 .../EntityFrameworkCacheTest.cs                 |     2 +-
 .../IgniteDbConfiguration.cs                    |     4 +-
 .../Misc/ClientReconnectExample.cs              |     2 +-
 .../scala/org/apache/ignite/scalar/scalar.scala |    17 +-
 .../test/resources/spring-ping-pong-partner.xml |     2 +-
 .../scalar/tests/ScalarProjectionSpec.scala     |     4 +-
 .../schedule/IgniteScheduleProcessor.java       |     2 +-
 .../processors/schedule/ScheduleFutureImpl.java |     4 +-
 .../org/apache/ignite/spark/IgniteContext.scala |     2 +-
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |    14 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |     6 +-
 .../org/apache/ignite/spark/IgniteRDDSpec.scala |     6 +-
 .../org/apache/ignite/IgniteSpringBean.java     |     2 +-
 .../ignite/cache/spring/SpringCacheManager.java |    42 +-
 .../spring/SpringTransactionManager.java        |    50 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |     2 +-
 .../src/test/config/jdbc-pojo-store-obj.xml     |     2 +-
 modules/spring/src/test/config/node1.xml        |     2 +-
 modules/spring/src/test/config/store-cache1.xml |     2 +-
 .../src/test/java/config/ignite-test-config.xml |     2 +-
 .../test/java/config/spring-transactions.xml    |     2 +-
 .../spring/GridSpringCacheManagerSelfTest.java  |     6 +-
 .../SpringCacheManagerContextInjectionTest.java |     2 +-
 .../ignite/cache/spring/spring-caching.xml      |     2 +-
 .../store/jdbc/CachePojoStoreXmlSelfTest.java   |     4 +-
 .../ignite/internal/GridFactorySelfTest.java    |   154 +-
 .../GridSpringBeanSerializationSelfTest.java    |     2 +-
 .../internal/IgniteDynamicCacheConfigTest.java  |     4 +-
 .../GridSpringResourceInjectionSelfTest.java    |     4 +-
 .../GridTransformSpringInjectionSelfTest.java   |     2 +-
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |     6 +-
 .../org/apache/ignite/spring-injection-test.xml |     2 +-
 .../spring/injection/spring-resource.tmpl.xml   |     2 +-
 .../org/apache/ignite/spring/sprint-exclude.xml |     2 -
 .../GridSpringTransactionManagerSelfTest.java   |     6 +-
 ...gTransactionManagerContextInjectionTest.java |     2 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |     6 +-
 .../scanners/UriDeploymentScannerManager.java   |    12 +-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |     6 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |     4 +-
 .../config/VisorConfigurationCommand.scala      |     2 +-
 .../visor/commands/node/VisorNodeCommand.scala  |     6 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    10 +-
 .../ignite/visor/VisorRuntimeBaseSpec.scala     |     4 +-
 .../commands/alert/VisorAlertCommandSpec.scala  |     4 +-
 .../cache/VisorCacheClearCommandSpec.scala      |     4 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |     4 +-
 .../cache/VisorCacheResetCommandSpec.scala      |     4 +-
 .../config/VisorConfigurationCommandSpec.scala  |     4 +-
 .../disco/VisorDiscoveryCommandSpec.scala       |     4 +-
 .../events/VisorEventsCommandSpec.scala         |     4 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |     4 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |     4 +-
 modules/web-console/backend/app/agent.js        |    14 +-
 modules/web-console/backend/app/browser.js      |     8 +-
 modules/web-console/frontend/app/app.js         |    11 +-
 .../form-field-datepicker.pug                   |    12 +-
 .../app/components/input-dialog/index.js        |    24 +
 .../input-dialog/input-dialog.controller.js     |    35 +
 .../input-dialog/input-dialog.service.js        |    88 +
 .../input-dialog/input-dialog.tpl.pug           |    39 +
 .../list-of-registered-users/index.js           |     2 +
 .../list-of-registered-users.column-defs.js     |    48 +-
 .../list-of-registered-users.controller.js      |   193 +-
 .../list-of-registered-users.scss               |    28 +
 .../list-of-registered-users.tpl.pug            |    50 +-
 .../ui-grid-header/ui-grid-header.scss          |     6 +
 .../ui-grid-header/ui-grid-header.tpl.pug       |     4 +-
 .../ui-grid-settings/ui-grid-settings.scss      |    45 +
 .../frontend/app/modules/agent/agent.module.js  |    10 +-
 .../frontend/app/modules/sql/sql.controller.js  |   109 +-
 .../frontend/app/modules/sql/sql.module.js      |    12 +-
 .../frontend/app/modules/states/errors.state.js |     4 +-
 .../frontend/app/primitives/badge/index.scss    |    36 +
 .../frontend/app/primitives/index.js            |    19 +
 .../frontend/app/primitives/tabs/index.scss     |    73 +
 .../frontend/app/services/Clone.service.js      |    66 -
 .../frontend/controllers/caches-controller.js   |    10 +-
 .../frontend/controllers/clusters-controller.js |     6 +-
 .../frontend/controllers/domains-controller.js  |    12 +-
 .../frontend/controllers/igfs-controller.js     |    10 +-
 .../frontend/public/stylesheets/style.scss      |    13 +-
 modules/web-console/frontend/views/403.pug      |    22 -
 modules/web-console/frontend/views/403.tpl.pug  |    22 +
 modules/web-console/frontend/views/404.pug      |    22 -
 modules/web-console/frontend/views/404.tpl.pug  |    22 +
 .../views/configuration/summary.tpl.pug         |     4 +-
 .../web-console/frontend/views/sql/sql.tpl.pug  |    49 +-
 .../frontend/views/templates/clone.tpl.pug      |    39 -
 .../frontend/views/templates/message.tpl.pug    |     4 +-
 .../ignite/console/demo/AgentClusterDemo.java   |     4 +-
 .../cache/websession/WebSessionFilter.java      |    12 +-
 .../servlet/ServletContextListenerStartup.java  |    12 +-
 .../ignite/startup/servlet/ServletStartup.java  |     8 +-
 .../internal/websession/WebSessionSelfTest.java |    21 +-
 .../config/benchmark-atomic.properties          |    18 +-
 .../config/benchmark-bin-identity.properties    |    10 +-
 .../config/benchmark-cache-load.properties      |    10 +-
 .../config/benchmark-client-mode.properties     |    10 +-
 .../config/benchmark-compute.properties         |    18 +-
 .../config/benchmark-failover.properties        |    18 +-
 .../yardstick/config/benchmark-full.properties  |    18 +-
 .../config/benchmark-multicast.properties       |    10 +-
 .../config/benchmark-put-indexed-val.properties |    18 +-
 .../benchmark-query-put-separated.properties    |    10 +-
 .../yardstick/config/benchmark-query.properties |    18 +-
 .../config/benchmark-remote-sample.properties   |    18 +-
 .../config/benchmark-remote.properties          |    18 +-
 .../config/benchmark-sample.properties          |    18 +-
 .../config/benchmark-sql-dml.properties         |    18 +-
 .../yardstick/config/benchmark-store.properties |    10 +-
 .../yardstick/config/benchmark-tx.properties    |    18 +-
 modules/yardstick/config/benchmark.properties   |    18 +-
 .../test-max-int-values-offheap.properties      |    23 +-
 .../test-max-int-values-onheap.properties       |    23 +-
 .../config/test-max-int-values-swap.properties  |    23 +-
 .../ignite/yardstick/IgniteBenchmarkUtils.java  |     2 +-
 .../cache/IgniteGetAndPutBenchmark.java         |     2 +-
 .../cache/IgniteGetAndPutTxBenchmark.java       |     2 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |    10 +-
 parent/pom.xml                                  |     6 +-
 scripts/git-remoteless-branches.sh              |    19 +
 1940 files changed, 53350 insertions(+), 22881 deletions(-)
----------------------------------------------------------------------