You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2017/04/06 13:31:55 UTC

[48/50] [abbrv] ignite git commit: Merge remote-tracking branch 'remotes/origin/master' into ignite-2893

Merge remote-tracking branch 'remotes/origin/master' into ignite-2893

# Conflicts:
#	modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicLongImpl.java


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

Branch: refs/heads/ignite-2893
Commit: b2c87cb36d92ce22a5a4071f1bb99219eda7af8c
Parents: 151c6aa a6d518d
Author: sboikov <sb...@gridgain.com>
Authored: Thu Apr 6 14:25:10 2017 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Apr 6 14:25:10 2017 +0300

----------------------------------------------------------------------
 .gitignore                                      |    2 +-
 DEVNOTES.txt                                    |    5 +-
 NOTICE                                          |    2 +-
 RELEASE_NOTES.txt                               |   20 +
 assembly/LICENSE_FABRIC                         |   35 +-
 assembly/LICENSE_HADOOP                         |   17 +-
 assembly/NOTICE_FABRIC                          |    2 +-
 assembly/NOTICE_HADOOP                          |    2 +-
 assembly/dependencies-fabric-lgpl.xml           |    1 +
 assembly/dependencies-fabric.xml                |    1 +
 assembly/dependencies-hadoop.xml                |    3 +
 assembly/release-base.xml                       |    5 -
 assembly/release-fabric-base.xml                |   17 +
 assembly/release-sources.xml                    |    3 +-
 config/example-kube.xml                         |   53 +
 config/hadoop/default-config.xml                |   29 -
 doap_Ignite.rdf                                 |    1 -
 examples/config/filesystem/example-igfs.xml     |   27 -
 examples/config/spark/example-shared-rdd.xml    |   83 +
 examples/pom-standalone-lgpl.xml                |   12 +
 examples/pom-standalone.xml                     |   12 +
 examples/pom.xml                                |   41 +-
 examples/schema-import/bin/h2-server.bat        |    2 +-
 examples/schema-import/bin/h2-server.sh         |    4 +-
 .../schema-import/bin/schema-import.properties  |    2 +-
 .../computegrid/ComputeAsyncExample.java        |    8 +-
 .../ComputeFibonacciContinuationExample.java    |   13 +-
 .../examples/datagrid/CacheAsyncApiExample.java |   17 +-
 .../datastructures/IgniteLockExample.java       |    4 +-
 .../datastructures/IgniteSemaphoreExample.java  |    4 +-
 .../examples/ScalarContinuationExample.scala    |   10 +-
 .../examples/spark/ScalarSharedRDDExample.scala |   89 +
 .../ignite/examples/spark/SharedRDDExample.java |  127 +
 .../ignite/examples/spark/package-info.java     |   22 +
 .../IgniteExamplesJ8SelfTestSuite.java          |    1 +
 .../tests/examples/ScalarExamplesSelfTest.scala |    6 +
 .../examples/SharedRDDExampleSelfTest.java      |   36 +
 .../IgniteExamplesSparkSelfTestSuite.java       |   46 +
 .../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       |   10 +-
 .../gridify/GridifySingleSplitLoadTest.java     |    6 +-
 .../org/test/gridify/ExternalAopTarget.java     |   16 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |    6 +-
 .../src/main/resources/META-INF/licenses.txt.vm |    7 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |   74 +-
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   62 +-
 .../s3/S3CheckpointManagerSelfTest.java         |    6 +-
 .../TcpDiscoveryS3IpFinderAbstractSelfTest.java |   84 +
 ...3IpFinderAwsCredentialsProviderSelfTest.java |   46 +
 ...scoveryS3IpFinderAwsCredentialsSelfTest.java |   45 +
 .../s3/TcpDiscoveryS3IpFinderSelfTest.java      |   79 -
 .../ignite/testsuites/IgniteS3TestSuite.java    |   26 +-
 .../jmh/cache/JmhCacheAbstractBenchmark.java    |    6 +-
 .../stream/camel/IgniteCamelStreamerTest.java   |    4 +-
 .../cassandra/persistence/PojoKeyField.java     |    2 +-
 .../ignite/tests/utils/TestTransaction.java     |   11 +
 modules/clients/pom.xml                         |    7 +
 .../src/test/config/jdbc-config-cache-store.xml |  124 +
 modules/clients/src/test/config/jdbc-config.xml |    2 +-
 .../internal/TaskEventSubjectIdSelfTest.java    |    4 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |    4 +-
 .../client/ClientDefaultCacheSelfTest.java      |    4 +-
 .../internal/client/ClientStartNodeTask.java    |   24 +-
 .../internal/client/ClientStopNodeTask.java     |    2 +-
 .../ClientTcpSslAuthenticationSelfTest.java     |    4 +-
 ...skExecutionAfterTopologyRestartSelfTest.java |    4 +-
 .../internal/client/ClientTestRestServer.java   |    6 +-
 .../ClientAbstractMultiNodeSelfTest.java        |   25 +-
 .../integration/ClientAbstractSelfTest.java     |    4 +-
 .../integration/ClientPreferDirectSelfTest.java |    4 +-
 .../client/router/ClientFailedInitSelfTest.java |    4 +-
 .../client/router/RouterFactorySelfTest.java    |    4 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   68 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |    6 +-
 ...cBinaryMarshallerMergeStatementSelfTest.java |    6 +-
 .../jdbc2/JdbcComplexQuerySelfTest.java         |    4 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |   66 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |    4 +-
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java  |    4 +-
 .../jdbc2/JdbcInsertStatementSelfTest.java      |   51 +
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java |    4 +-
 .../jdbc2/JdbcMergeStatementSelfTest.java       |   51 +
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |    6 +-
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java  |    4 +-
 .../jdbc2/JdbcPreparedStatementSelfTest.java    |    4 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |    4 +-
 .../internal/jdbc2/JdbcSpringSelfTest.java      |  125 +
 .../internal/jdbc2/JdbcStatementSelfTest.java   |    4 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java   |  187 ++
 .../jdbc2/JdbcUpdateStatementSelfTest.java      |   50 +
 .../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        |   17 +-
 .../jdbc/AbstractJdbcPojoQuerySelfTest.java     |  169 ++
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java   |    4 +-
 .../ignite/jdbc/JdbcConnectionSelfTest.java     |    6 +-
 .../ignite/jdbc/JdbcEmptyCacheSelfTest.java     |    4 +-
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java    |    4 +-
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |    8 +-
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |    4 +-
 .../jdbc/JdbcPojoLegacyQuerySelfTest.java       |   44 +
 .../ignite/jdbc/JdbcPojoQuerySelfTest.java      |   56 +
 .../jdbc/JdbcPreparedStatementSelfTest.java     |    4 +-
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |    4 +-
 .../ignite/jdbc/JdbcStatementSelfTest.java      |    4 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    9 +-
 .../src/test/resources/spring-server-node.xml   |   73 +-
 .../test/resources/spring-server-ssl-node.xml   |   71 +-
 .../cloud/TcpDiscoveryCloudIpFinder.java        |   51 +-
 .../ignite/codegen/MessageCodeGenerator.java    |    2 +-
 modules/core/src/main/java/META-INF/NOTICE      |    2 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   16 +-
 .../java/org/apache/ignite/IgniteBinary.java    |   35 +-
 .../java/org/apache/ignite/IgniteCache.java     |  611 +++-
 .../java/org/apache/ignite/IgniteCluster.java   |  126 +
 .../java/org/apache/ignite/IgniteCompute.java   |  300 +-
 .../java/org/apache/ignite/IgniteEvents.java    |  128 +-
 .../org/apache/ignite/IgniteFileSystem.java     |   92 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |   39 +-
 .../java/org/apache/ignite/IgniteMessaging.java |   38 +-
 .../java/org/apache/ignite/IgniteServices.java  |  221 +-
 .../apache/ignite/IgniteSystemProperties.java   |   60 +
 .../main/java/org/apache/ignite/Ignition.java   |   43 +-
 .../org/apache/ignite/IgnitionListener.java     |    2 +-
 .../ignite/binary/BinaryBasicIdMapper.java      |    5 +-
 .../ignite/binary/BinaryBasicNameMapper.java    |    5 +-
 .../ignite/binary/BinaryObjectBuilder.java      |   10 -
 .../apache/ignite/binary/BinaryRawReader.java   |   13 +
 .../apache/ignite/binary/BinaryRawWriter.java   |   13 +
 .../org/apache/ignite/binary/BinaryReader.java  |   15 +
 .../ignite/binary/BinaryTypeConfiguration.java  |   30 +-
 .../org/apache/ignite/binary/BinaryWriter.java  |   15 +
 .../ignite/cache/CacheKeyConfiguration.java     |   10 +-
 .../org/apache/ignite/cache/CacheManager.java   |    2 +-
 .../ignite/cache/CacheTypeFieldMetadata.java    |  149 -
 .../apache/ignite/cache/CacheTypeMetadata.java  |  379 ---
 .../org/apache/ignite/cache/QueryEntity.java    |   62 +-
 .../org/apache/ignite/cache/QueryIndex.java     |   25 +-
 .../affinity/fair/FairAffinityFunction.java     |   54 +-
 .../rendezvous/RendezvousAffinityFunction.java  |   27 +-
 .../cache/eviction/AbstractEvictionPolicy.java  |  212 ++
 .../ignite/cache/eviction/EvictionPolicy.java   |    2 -
 .../cache/eviction/fifo/FifoEvictionPolicy.java |  202 +-
 .../eviction/fifo/FifoEvictionPolicyMBean.java  |    2 +
 .../igfs/IgfsPerBlockLruEvictionPolicy.java     |  131 +-
 .../cache/eviction/lru/LruEvictionPolicy.java   |  201 +-
 .../eviction/random/RandomEvictionPolicy.java   |  124 -
 .../random/RandomEvictionPolicyMBean.java       |   42 -
 .../eviction/sorted/SortedEvictionPolicy.java   |  207 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |    4 +-
 .../org/apache/ignite/cache/query/SqlQuery.java |   31 +-
 .../apache/ignite/cache/query/TextQuery.java    |    4 +-
 .../store/jdbc/CacheAbstractJdbcStore.java      |   90 +-
 .../store/jdbc/CacheJdbcBlobStoreFactory.java   |    2 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |   18 +-
 .../store/jdbc/JdbcTypesDefaultTransformer.java |   19 +
 .../cache/store/jdbc/JdbcTypesTransformer.java  |   17 +
 .../apache/ignite/compute/gridify/Gridify.java  |   10 +
 .../ignite/compute/gridify/GridifySetToSet.java |   10 +
 .../compute/gridify/GridifySetToValue.java      |   10 +
 .../configuration/AtomicConfiguration.java      |   15 +-
 .../configuration/BinaryConfiguration.java      |   30 +-
 .../configuration/CacheConfiguration.java       |  208 +-
 .../configuration/CollectionConfiguration.java  |   36 +-
 .../configuration/ConnectorConfiguration.java   |  100 +-
 .../configuration/FileSystemConfiguration.java  |  226 +-
 .../configuration/HadoopConfiguration.java      |   31 +-
 .../configuration/IgniteConfiguration.java      |  157 +-
 .../configuration/NearCacheConfiguration.java   |   50 +
 .../configuration/TransactionConfiguration.java |   45 +-
 .../igfs/IgfsGroupDataBlocksKeyMapper.java      |    5 +-
 .../igfs/IgfsIpcEndpointConfiguration.java      |   30 +-
 .../local/LocalIgfsSecondaryFileSystem.java     |    6 +-
 .../apache/ignite/internal/GridComponent.java   |   51 +-
 .../apache/ignite/internal/GridDiagnostic.java  |   16 +-
 .../internal/GridEventConsumeHandler.java       |    5 +
 .../ignite/internal/GridJobCancelRequest.java   |    2 +-
 .../ignite/internal/GridJobExecuteRequest.java  |    2 +-
 .../ignite/internal/GridJobExecuteResponse.java |    2 +-
 .../ignite/internal/GridJobSiblingImpl.java     |    4 +-
 .../ignite/internal/GridJobSiblingsRequest.java |    2 +-
 .../internal/GridJobSiblingsResponse.java       |    2 +-
 .../ignite/internal/GridKernalContext.java      |   36 +-
 .../ignite/internal/GridKernalContextImpl.java  |   64 +-
 .../ignite/internal/GridKernalGatewayImpl.java  |   47 +-
 .../apache/ignite/internal/GridLoggerProxy.java |   25 +-
 .../internal/GridMessageListenHandler.java      |    5 +
 .../internal/GridPerformanceSuggestions.java    |   92 -
 .../ignite/internal/GridPluginComponent.java    |   21 +-
 .../ignite/internal/GridTaskCancelRequest.java  |    2 +-
 .../ignite/internal/GridTaskSessionRequest.java |    2 +-
 .../org/apache/ignite/internal/GridTopic.java   |   10 +-
 .../ignite/internal/IgniteComputeImpl.java      |  549 +++-
 .../ignite/internal/IgniteEventsImpl.java       |   79 +
 .../apache/ignite/internal/IgniteKernal.java    |  262 +-
 .../ignite/internal/IgniteMessagingImpl.java    |   67 +-
 .../internal/IgniteNeedReconnectException.java  |   40 +
 .../ignite/internal/IgniteNodeAttributes.java   |   10 +-
 .../ignite/internal/IgniteServicesImpl.java     |  108 +
 .../ignite/internal/IgniteTransactionsEx.java   |    8 +-
 .../ignite/internal/IgniteVersionUtils.java     |    2 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |  303 +-
 .../ignite/internal/MappingStoreTask.java       |   59 +
 .../internal/MarshallerContextAdapter.java      |  211 --
 .../ignite/internal/MarshallerContextImpl.java  |  699 +++--
 .../internal/MarshallerMappingFileStore.java    |  174 ++
 .../ignite/internal/MarshallerPlatformIds.java  |   33 +
 .../internal/StripedExecutorMXBeanAdapter.java  |   90 +
 .../binary/BinaryCachingMetadataHandler.java    |    6 +
 .../internal/binary/BinaryClassDescriptor.java  |  136 +-
 .../ignite/internal/binary/BinaryContext.java   |   53 +-
 .../internal/binary/BinaryEnumObjectImpl.java   |    6 +-
 .../internal/binary/BinaryFieldAccessor.java    |   79 +-
 .../internal/binary/BinaryFieldMetadata.java    |  127 +
 .../internal/binary/BinaryMarshaller.java       |    1 -
 .../ignite/internal/binary/BinaryMetadata.java  |   49 +-
 .../binary/BinaryMetadataCollector.java         |   28 +-
 .../internal/binary/BinaryMetadataHandler.java  |   18 +-
 .../binary/BinaryNoopMetadataHandler.java       |    5 +
 .../internal/binary/BinaryObjectExImpl.java     |    4 -
 .../internal/binary/BinaryObjectImpl.java       |   52 +-
 .../binary/BinaryObjectOffheapImpl.java         |   11 +-
 .../internal/binary/BinaryReaderExImpl.java     |  346 ++-
 .../binary/BinarySerializedFieldComparator.java |    3 +
 .../ignite/internal/binary/BinaryTreeMap.java   |    6 +-
 .../ignite/internal/binary/BinaryUtils.java     |  170 +-
 .../ignite/internal/binary/BinaryWriteMode.java |    6 +
 .../internal/binary/BinaryWriterExImpl.java     |  127 +-
 .../internal/binary/GridBinaryMarshaller.java   |    8 +-
 .../binary/builder/BinaryBuilderReader.java     |   37 +
 .../binary/builder/BinaryObjectBuilderImpl.java |   34 +-
 .../client/GridClientConfiguration.java         |  100 +-
 .../client/GridClientDataConfiguration.java     |   15 +-
 .../client/GridClientPartitionAffinity.java     |   15 +-
 .../balancer/GridClientBalancerAdapter.java     |    5 +-
 .../GridClientConnectionManagerAdapter.java     |    2 +-
 .../connection/GridClientNioTcpConnection.java  |    2 +-
 .../GridClientOptimizedMarshaller.java          |   16 +-
 .../router/GridTcpRouterConfiguration.java      |   50 +-
 .../impl/GridRouterCommandLineStartup.java      |    4 +-
 .../client/router/impl/GridTcpRouterImpl.java   |    4 +-
 .../client/util/GridClientConsistentHash.java   |   14 +-
 .../internal/cluster/ClusterGroupAdapter.java   |   12 +-
 .../cluster/ClusterNodeLocalMapImpl.java        |    3 +-
 .../cluster/IgniteClusterAsyncImpl.java         |   28 +-
 .../internal/cluster/IgniteClusterImpl.java     |   26 +-
 .../internal/direct/DirectMessageWriter.java    |    4 +-
 .../stream/v1/DirectByteBufferStreamImplV1.java |    8 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java |    9 +-
 .../internal/igfs/common/IgfsMarshaller.java    |    4 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |  145 +-
 .../internal/jdbc2/JdbcPreparedStatement.java   |   34 +-
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |    2 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java  |    2 +-
 .../internal/jdbc2/JdbcSqlFieldsQuery.java      |   58 +-
 .../ignite/internal/jdbc2/JdbcStatement.java    |   22 +-
 .../jdbc2/JdbcStreamedPreparedStatement.java    |   59 +
 .../apache/ignite/internal/jdbc2/JdbcUtils.java |    4 +-
 .../internal/managers/GridManagerAdapter.java   |   29 +-
 .../checkpoint/GridCheckpointManager.java       |    4 +-
 .../checkpoint/GridCheckpointRequest.java       |    2 +-
 .../managers/communication/GridIoManager.java   |  271 +-
 .../managers/communication/GridIoMessage.java   |    2 +-
 .../communication/GridIoMessageFactory.java     |   61 +-
 .../managers/communication/GridIoPolicy.java    |   15 +-
 .../communication/GridIoUserMessage.java        |    2 +-
 .../communication/IgniteIoTestMessage.java      |    2 +-
 .../deployment/GridDeploymentCommunication.java |    6 +-
 .../deployment/GridDeploymentInfoBean.java      |    2 +-
 .../deployment/GridDeploymentRequest.java       |    2 +-
 .../deployment/GridDeploymentResponse.java      |    2 +-
 .../internal/managers/discovery/DiscoCache.java |  310 ++
 .../discovery/DiscoveryCustomMessage.java       |   48 +
 .../discovery/GridDiscoveryManager.java         |  866 ++----
 .../eventstorage/DiscoveryEventListener.java    |   33 +
 .../eventstorage/GridEventStorageManager.java   |  210 +-
 .../eventstorage/GridEventStorageMessage.java   |    2 +-
 .../failover/GridFailoverContextImpl.java       |   11 -
 .../managers/failover/GridFailoverManager.java  |    3 -
 .../internal/mxbean/IgniteStandardMXBean.java   |   12 +-
 .../processors/GridProcessorAdapter.java        |   21 +-
 .../affinity/AffinityTopologyVersion.java       |    2 +-
 .../affinity/GridAffinityAssignmentCache.java   |   13 +-
 .../affinity/GridAffinityProcessor.java         |    2 +-
 .../cache/CacheAffinitySharedManager.java       |   41 +-
 .../cache/CacheEntryInfoCollection.java         |    2 +-
 .../cache/CacheEntryPredicateAdapter.java       |    2 +-
 .../cache/CacheEntryPredicateContainsValue.java |    2 +-
 .../cache/CacheEntrySerializablePredicate.java  |    2 +-
 .../cache/CacheEvictableEntryImpl.java          |    4 +-
 .../processors/cache/CacheEvictionEntry.java    |    2 +-
 .../cache/CacheInvokeDirectResult.java          |    2 +-
 .../processors/cache/CacheMetricsImpl.java      |   10 +-
 .../cache/CacheObjectByteArrayImpl.java         |    2 +-
 .../processors/cache/CacheObjectContext.java    |    3 +-
 .../processors/cache/CacheObjectImpl.java       |    2 +-
 .../cache/CachePartitionExchangeWorkerTask.java |   29 +
 .../internal/processors/cache/CacheType.java    |    8 +-
 .../cache/DynamicCacheChangeBatch.java          |   14 +
 .../processors/cache/EntryGetResult.java        |   95 +
 .../processors/cache/EntryGetWithTtlResult.java |   58 +
 .../processors/cache/GridCacheAdapter.java      |  504 ++--
 .../cache/GridCacheAffinityManager.java         |   84 +-
 .../processors/cache/GridCacheAtomicFuture.java |    8 +-
 .../cache/GridCacheClearAllRunnable.java        |    4 +-
 .../processors/cache/GridCacheContext.java      |  154 +-
 .../cache/GridCacheDeploymentManager.java       |   12 +-
 .../processors/cache/GridCacheEntryEx.java      |   42 +-
 .../processors/cache/GridCacheEntryInfo.java    |    2 +-
 .../processors/cache/GridCacheEventManager.java |    4 +-
 .../cache/GridCacheEvictionManager.java         |   75 +-
 .../cache/GridCacheEvictionRequest.java         |    2 +-
 .../cache/GridCacheEvictionResponse.java        |    2 +-
 .../processors/cache/GridCacheGateway.java      |   51 +-
 .../processors/cache/GridCacheIoManager.java    |  114 +-
 .../cache/GridCacheManagerAdapter.java          |    2 +-
 .../processors/cache/GridCacheMapEntry.java     |  169 +-
 .../processors/cache/GridCacheMessage.java      |   17 +-
 .../processors/cache/GridCacheMvccManager.java  |   50 +-
 .../GridCachePartitionExchangeManager.java      |  326 ++-
 .../processors/cache/GridCacheProcessor.java    |  459 ++-
 .../processors/cache/GridCacheProxyImpl.java    |    6 +-
 .../processors/cache/GridCacheReturn.java       |    8 +-
 .../cache/GridCacheSharedContext.java           |   17 +-
 .../cache/GridCacheSharedTtlCleanupManager.java |    2 +-
 .../processors/cache/GridCacheSwapManager.java  |    6 +-
 .../processors/cache/GridCacheTtlManager.java   |    8 +-
 .../processors/cache/GridCacheUtils.java        |   52 +-
 .../cache/GridDeferredAckMessageSender.java     |   17 +-
 .../processors/cache/IgniteCacheProxy.java      |  592 +++-
 .../processors/cache/IgniteInternalCache.java   |    5 +-
 .../processors/cache/KeyCacheObjectImpl.java    |   76 +-
 .../processors/cache/QueryCursorImpl.java       |    6 +-
 .../processors/cache/ReaderArguments.java       |   74 +
 .../cache/affinity/GridCacheAffinityImpl.java   |   18 +-
 .../cache/binary/BinaryMetadataHolder.java      |   73 +
 .../cache/binary/BinaryMetadataTransport.java   |  641 ++++
 .../binary/BinaryMetadataUpdatedListener.java   |   29 +
 .../binary/CacheObjectBinaryProcessor.java      |   12 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |  508 +---
 .../binary/ClientMetadataRequestFuture.java     |  161 +
 .../cache/binary/MetadataRequestMessage.java    |  122 +
 .../cache/binary/MetadataResponseMessage.java   |  195 ++
 .../binary/MetadataUpdateAcceptedMessage.java   |   96 +
 .../binary/MetadataUpdateProposedMessage.java   |  224 ++
 .../cache/binary/MetadataUpdateResult.java      |   96 +
 .../CacheDataStructuresManager.java             |    2 +-
 .../distributed/GridCacheCommittedTxInfo.java   |  117 -
 .../distributed/GridCacheTtlUpdateRequest.java  |    2 +-
 .../distributed/GridCacheTxRecoveryRequest.java |    2 +-
 .../GridCacheTxRecoveryResponse.java            |    2 +-
 .../distributed/GridDistributedBaseMessage.java |    2 +-
 .../GridDistributedCacheAdapter.java            |   11 +-
 .../distributed/GridDistributedCacheEntry.java  |    3 -
 .../distributed/GridDistributedLockRequest.java |   28 +-
 .../GridDistributedLockResponse.java            |    3 +-
 .../GridDistributedTxFinishRequest.java         |  219 +-
 .../GridDistributedTxFinishResponse.java        |   77 +-
 .../distributed/GridDistributedTxMapping.java   |   45 +-
 .../GridDistributedTxPrepareRequest.java        |  207 +-
 .../GridDistributedTxPrepareResponse.java       |   78 +-
 .../GridDistributedTxRemoteAdapter.java         |   59 +-
 .../GridDistributedUnlockRequest.java           |   20 +-
 .../dht/GridClientPartitionTopology.java        |   83 +-
 .../dht/GridDhtAffinityAssignmentRequest.java   |    2 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  |  103 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |   26 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   60 +-
 .../distributed/dht/GridDhtCacheEntry.java      |    2 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |  107 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |   99 +-
 .../distributed/dht/GridDhtLocalPartition.java  |  136 +-
 .../distributed/dht/GridDhtLockFuture.java      |   35 +-
 .../distributed/dht/GridDhtLockRequest.java     |   18 +-
 .../distributed/dht/GridDhtLockResponse.java    |    2 +-
 .../dht/GridDhtPartitionTopology.java           |   16 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  134 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   78 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   55 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |  253 +-
 .../dht/GridDhtTxFinishResponse.java            |   72 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |  161 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   39 +-
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java  |    2 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |  243 +-
 .../dht/GridDhtTxPrepareRequest.java            |  140 +-
 .../dht/GridDhtTxPrepareResponse.java           |  119 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |    2 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |   20 +-
 .../dht/GridPartitionedGetFuture.java           |   34 +-
 .../dht/GridPartitionedSingleGetFuture.java     |   70 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |  297 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |  394 ++-
 .../dht/atomic/GridDhtAtomicCache.java          |  926 +++---
 .../GridDhtAtomicDeferredUpdateResponse.java    |   70 +-
 .../dht/atomic/GridDhtAtomicNearResponse.java   |  314 ++
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |   97 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |  284 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   85 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  337 +--
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |  111 +-
 ...idNearAtomicAbstractSingleUpdateRequest.java |  481 +--
 .../GridNearAtomicAbstractUpdateFuture.java     |  468 ++-
 .../GridNearAtomicAbstractUpdateRequest.java    |  480 ++-
 .../GridNearAtomicCheckUpdateRequest.java       |  175 ++
 .../atomic/GridNearAtomicFullUpdateRequest.java |  489 +---
 ...GridNearAtomicSingleUpdateFilterRequest.java |   26 +-
 .../GridNearAtomicSingleUpdateFuture.java       |  614 ++--
 ...GridNearAtomicSingleUpdateInvokeRequest.java |   40 +-
 .../GridNearAtomicSingleUpdateRequest.java      |   68 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |  963 +++---
 .../atomic/GridNearAtomicUpdateResponse.java    |  361 +--
 .../dht/atomic/NearCacheUpdates.java            |  335 +++
 .../distributed/dht/atomic/UpdateErrors.java    |  222 ++
 .../dht/colocated/GridDhtColocatedCache.java    |   43 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   39 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |    8 +-
 .../dht/preloader/GridDhtForceKeysRequest.java  |    2 +-
 .../dht/preloader/GridDhtForceKeysResponse.java |    2 +-
 .../GridDhtPartitionDemandMessage.java          |    2 +-
 .../dht/preloader/GridDhtPartitionDemander.java |  518 +---
 .../preloader/GridDhtPartitionExchangeId.java   |    2 +-
 .../dht/preloader/GridDhtPartitionFullMap.java  |   45 +-
 .../dht/preloader/GridDhtPartitionMap.java      |  210 +-
 .../dht/preloader/GridDhtPartitionMap2.java     |  330 ---
 .../dht/preloader/GridDhtPartitionSupplier.java |   12 +-
 .../GridDhtPartitionSupplyMessage.java          |    2 +-
 .../GridDhtPartitionSupplyMessageV2.java        |    2 +-
 .../GridDhtPartitionsAbstractMessage.java       |    4 -
 .../GridDhtPartitionsExchangeFuture.java        |  102 +-
 .../preloader/GridDhtPartitionsFullMessage.java |    8 +-
 .../GridDhtPartitionsSingleMessage.java         |   12 +-
 .../GridDhtPartitionsSingleRequest.java         |    2 +-
 .../dht/preloader/GridDhtPreloader.java         |   61 +-
 .../distributed/near/CacheVersionedValue.java   |    2 +-
 .../distributed/near/GridNearAtomicCache.java   |   30 +-
 .../distributed/near/GridNearCacheEntry.java    |    6 +-
 .../distributed/near/GridNearGetFuture.java     |   40 +-
 .../distributed/near/GridNearGetRequest.java    |   78 +-
 .../distributed/near/GridNearGetResponse.java   |    2 +-
 .../distributed/near/GridNearLockFuture.java    |   33 +-
 .../distributed/near/GridNearLockRequest.java   |  231 +-
 .../distributed/near/GridNearLockResponse.java  |   14 +-
 ...arOptimisticSerializableTxPrepareFuture.java |   76 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   54 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |   13 +
 .../GridNearPessimisticTxPrepareFuture.java     |   67 +-
 .../near/GridNearSingleGetRequest.java          |   68 +-
 .../near/GridNearSingleGetResponse.java         |    2 +-
 .../near/GridNearTransactionalCache.java        |   14 +-
 .../near/GridNearTxFinishFuture.java            |  191 +-
 .../near/GridNearTxFinishRequest.java           |  176 +-
 .../near/GridNearTxFinishResponse.java          |   38 +-
 .../cache/distributed/near/GridNearTxLocal.java | 2731 ++++++++++++++++-
 .../near/GridNearTxPrepareFutureAdapter.java    |   22 +-
 .../near/GridNearTxPrepareRequest.java          |  256 +-
 .../near/GridNearTxPrepareResponse.java         |   88 +-
 .../distributed/near/GridNearTxRemote.java      |    4 +-
 .../distributed/near/GridNearUnlockRequest.java |   22 +-
 .../distributed/near/IgniteTxMappingsImpl.java  |    4 +-
 .../near/IgniteTxMappingsSingleImpl.java        |    6 +-
 .../processors/cache/local/GridLocalCache.java  |    1 +
 .../local/atomic/GridLocalAtomicCache.java      |   21 +-
 .../processors/cache/query/CacheQuery.java      |    1 -
 .../query/GridCacheDistributedQueryManager.java |    7 +-
 .../cache/query/GridCacheLocalQueryFuture.java  |    3 +-
 .../cache/query/GridCacheQueryAdapter.java      |   12 +-
 .../cache/query/GridCacheQueryManager.java      |  247 +-
 .../cache/query/GridCacheQueryRequest.java      |    2 +-
 .../cache/query/GridCacheQueryResponse.java     |    2 +-
 .../cache/query/GridCacheSqlQuery.java          |  131 +-
 .../CacheContinuousQueryBatchAck.java           |    6 +-
 .../continuous/CacheContinuousQueryEntry.java   |    2 +-
 .../continuous/CacheContinuousQueryHandler.java |  109 +-
 .../continuous/CacheContinuousQueryManager.java |   89 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |    4 +-
 .../store/GridCacheStoreManagerAdapter.java     |  179 +-
 .../cache/store/GridCacheWriteBehindStore.java  |   16 +-
 .../cache/transactions/IgniteInternalTx.java    |   80 +-
 .../transactions/IgniteTransactionsImpl.java    |   12 +-
 .../cache/transactions/IgniteTxAdapter.java     |  169 +-
 .../cache/transactions/IgniteTxEntry.java       |   52 +-
 .../cache/transactions/IgniteTxHandler.java     |  169 +-
 .../IgniteTxImplicitSingleStateImpl.java        |    4 +-
 .../cache/transactions/IgniteTxKey.java         |    2 +-
 .../transactions/IgniteTxLocalAdapter.java      | 2753 ++----------------
 .../cache/transactions/IgniteTxLocalEx.java     |  142 +-
 .../cache/transactions/IgniteTxManager.java     |  302 +-
 .../cache/transactions/IgniteTxRemoteEx.java    |   11 +
 .../IgniteTxRemoteStateAdapter.java             |    2 +-
 .../cache/transactions/IgniteTxState.java       |    2 +-
 .../cache/transactions/IgniteTxStateImpl.java   |    5 +-
 .../transactions/TransactionProxyImpl.java      |   52 +-
 .../cache/transactions/TxDeadlockDetection.java |    2 +-
 .../cache/transactions/TxEntryValueHolder.java  |    8 +-
 .../processors/cache/transactions/TxLock.java   |    2 +-
 .../cache/transactions/TxLockList.java          |    2 +-
 .../cache/transactions/TxLocksRequest.java      |    2 +-
 .../cache/transactions/TxLocksResponse.java     |    2 +-
 .../version/GridCacheRawVersionedEntry.java     |    2 +-
 .../cache/version/GridCacheVersion.java         |    4 +-
 .../cache/version/GridCacheVersionEx.java       |    2 +-
 .../cache/version/GridCacheVersionManager.java  |    2 +-
 .../cacheobject/IgniteCacheObjectProcessor.java |    5 +-
 .../IgniteCacheObjectProcessorImpl.java         |   20 +-
 .../clock/GridClockDeltaSnapshotMessage.java    |    2 +-
 .../processors/clock/GridClockDeltaVersion.java |    2 +-
 .../processors/clock/GridClockServer.java       |    6 +-
 .../clock/GridClockSyncProcessor.java           |    6 +-
 .../processors/closure/AffinityTask.java        |    6 -
 .../closure/GridClosureProcessor.java           |  441 +--
 .../processors/cluster/ClusterProcessor.java    |   55 +-
 .../processors/cluster/GridUpdateNotifier.java  |   16 +-
 .../continuous/GridContinuousHandler.java       |    5 +
 .../continuous/GridContinuousMessage.java       |    2 +-
 .../continuous/GridContinuousProcessor.java     |  157 +-
 .../datastreamer/DataStreamProcessor.java       |    8 +-
 .../datastreamer/DataStreamerEntry.java         |    2 +-
 .../datastreamer/DataStreamerImpl.java          |    8 +-
 .../datastreamer/DataStreamerRequest.java       |    2 +-
 .../datastreamer/DataStreamerResponse.java      |    2 +-
 .../datastructures/DataStructuresProcessor.java |   37 +-
 .../datastructures/GridCacheAtomicLongImpl.java |    2 +
 .../GridCacheAtomicReferenceImpl.java           |    6 +-
 .../GridCacheAtomicSequenceImpl.java            |    4 +-
 .../GridCacheAtomicStampedImpl.java             |    6 +-
 .../GridCacheCountDownLatchImpl.java            |    6 +-
 .../datastructures/GridCacheLockImpl.java       |   28 +-
 .../datastructures/GridCacheSemaphoreImpl.java  |   18 +-
 .../datastructures/GridCacheSetImpl.java        |    2 +-
 .../datastructures/GridSetQueryPredicate.java   |    2 +-
 .../GridTransactionalCacheQueueImpl.java        |   10 +-
 .../processors/hadoop/HadoopClasspathUtils.java |    4 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java |    5 +-
 .../internal/processors/hadoop/HadoopJobId.java |    2 +-
 .../processors/hadoop/HadoopTaskContext.java    |   10 +
 .../shuffle/HadoopDirectShuffleMessage.java     |    2 +-
 .../hadoop/shuffle/HadoopShuffleAck.java        |    2 +-
 .../shuffle/HadoopShuffleFinishRequest.java     |    2 +-
 .../shuffle/HadoopShuffleFinishResponse.java    |    2 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |    2 +-
 .../processors/igfs/IgfsAckMessage.java         |    2 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java |   45 +-
 .../internal/processors/igfs/IgfsBlockKey.java  |    3 +-
 .../processors/igfs/IgfsBlocksMessage.java      |    2 +-
 .../internal/processors/igfs/IgfsContext.java   |    8 +-
 .../processors/igfs/IgfsDataManager.java        |   74 +-
 .../processors/igfs/IgfsDeleteMessage.java      |    2 +-
 .../processors/igfs/IgfsFileAffinityRange.java  |    2 +-
 .../internal/processors/igfs/IgfsFileImpl.java  |    5 +-
 .../igfs/IgfsFragmentizerManager.java           |    4 +-
 .../igfs/IgfsFragmentizerRequest.java           |    2 +-
 .../igfs/IgfsFragmentizerResponse.java          |    2 +-
 .../internal/processors/igfs/IgfsImpl.java      |  108 +-
 .../processors/igfs/IgfsIpcHandler.java         |    2 +-
 .../processors/igfs/IgfsMetaManager.java        |  100 +-
 .../processors/igfs/IgfsNoopProcessor.java      |    2 +-
 .../internal/processors/igfs/IgfsProcessor.java |  135 +-
 .../internal/processors/igfs/IgfsServer.java    |    6 +-
 .../processors/igfs/IgfsServerManager.java      |    2 +-
 .../processors/igfs/IgfsSyncMessage.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     |    6 +-
 .../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        |    8 +-
 .../internal/processors/job/GridJobWorker.java  |    8 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |    3 +-
 .../marshaller/ClientRequestFuture.java         |  183 ++
 .../GridMarshallerMappingProcessor.java         |  362 +++
 .../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 ++
 .../internal/processors/odbc/IgniteTypes.java   |   69 +
 .../processors/odbc/OdbcMessageParser.java      |   13 +-
 .../internal/processors/odbc/OdbcProcessor.java |    6 +-
 .../processors/odbc/OdbcRequestHandler.java     |    2 +
 .../internal/processors/odbc/OdbcTypes.java     |  131 +
 .../internal/processors/odbc/OdbcUtils.java     |   85 +
 .../processors/odbc/escape/OdbcEscapeUtils.java |   52 +-
 .../platform/PlatformAbstractBootstrap.java     |    3 +-
 .../platform/PlatformAbstractTarget.java        |   32 +-
 .../platform/PlatformAsyncResult.java           |   41 +
 .../platform/PlatformAsyncTarget.java           |   44 -
 .../platform/PlatformConfigurationEx.java       |    3 +-
 .../platform/PlatformContextImpl.java           |  102 +-
 .../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           |   23 +-
 .../platform/PlatformTargetProxyImpl.java       |   67 +-
 .../binary/PlatformBinaryProcessor.java         |   40 +-
 .../platform/cache/PlatformCache.java           |  241 +-
 .../cache/PlatformCacheEntryProcessorImpl.java  |    6 +-
 .../callback/PlatformCallbackGateway.java       |  119 +
 .../platform/callback/PlatformCallbackOp.java   |   21 +
 .../platform/compute/PlatformAbstractJob.java   |    2 +-
 .../platform/compute/PlatformCompute.java       |   14 +-
 .../dotnet/PlatformDotNetCacheStore.java        |   12 +-
 .../dotnet/PlatformDotNetConfigurationEx.java   |   21 +-
 ...formDotNetEntityFrameworkCacheExtension.java |    8 +-
 .../platform/events/PlatformEvents.java         |   70 +-
 .../memory/PlatformOutputStreamImpl.java        |    8 +-
 .../platform/messaging/PlatformMessaging.java   |   35 +-
 .../plugin/PlatformPluginProcessor.java         |   46 +
 .../cache/PlatformCachePluginConfiguration.java |   58 +
 .../cache/PlatformCachePluginProvider.java      |  123 +
 .../platform/services/PlatformServices.java     |   95 +-
 .../transactions/PlatformTransactions.java      |   18 +-
 .../utils/PlatformConfigurationUtils.java       |  289 +-
 .../platform/utils/PlatformUtils.java           |   58 +-
 .../processors/plugin/CachePluginManager.java   |    8 +-
 .../plugin/IgnitePluginProcessor.java           |   84 +-
 .../internal/processors/pool/PoolProcessor.java |   20 +-
 .../processors/port/GridPortProcessor.java      |    2 +-
 .../query/GridQueryIndexDescriptor.java         |    4 +-
 .../processors/query/GridQueryIndexType.java    |   32 -
 .../processors/query/GridQueryIndexing.java     |   89 +-
 .../processors/query/GridQueryProcessor.java    | 2364 ++-------------
 .../processors/query/GridQueryProperty.java     |   21 +-
 .../query/GridQueryTypeDescriptor.java          |    7 +
 .../processors/query/GridRunningQueryInfo.java  |  132 +
 .../query/QueryIndexDescriptorImpl.java         |  102 +
 .../processors/query/QueryTypeCandidate.java    |   66 +
 .../query/QueryTypeDescriptorImpl.java          |  320 ++
 .../processors/query/QueryTypeIdKey.java        |   94 +
 .../processors/query/QueryTypeNameKey.java      |   68 +
 .../internal/processors/query/QueryUtils.java   |  677 +++++
 .../messages/GridQueryCancelRequest.java        |    2 +-
 .../twostep/messages/GridQueryFailResponse.java |    2 +-
 .../messages/GridQueryNextPageRequest.java      |   31 +-
 .../messages/GridQueryNextPageResponse.java     |   31 +-
 .../h2/twostep/messages/GridQueryRequest.java   |  368 ---
 .../query/property/QueryBinaryProperty.java     |  267 ++
 .../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         |    3 +-
 .../processors/rest/GridRestProcessor.java      |    8 +-
 .../handlers/cache/GridCacheCommandHandler.java |   29 +-
 .../redis/GridRedisRestCommandHandler.java      |   36 +
 .../string/GridRedisSetCommandHandler.java      |   45 +-
 .../handlers/task/GridTaskCommandHandler.java   |    4 +-
 .../handlers/task/GridTaskResultRequest.java    |    2 +-
 .../handlers/task/GridTaskResultResponse.java   |    2 +-
 .../version/GridVersionCommandHandler.java      |    2 +-
 .../rest/protocols/tcp/GridTcpRestProtocol.java |    2 +-
 .../service/GridServiceProcessor.java           |  324 +--
 .../processors/service/GridServiceProxy.java    |   10 +
 .../session/GridTaskSessionProcessor.java       |    2 +-
 .../processors/task/GridTaskProcessor.java      |   13 +-
 .../task/GridTaskThreadContextKey.java          |    7 +-
 .../processors/task/GridTaskWorker.java         |   29 +-
 .../timeout/GridTimeoutProcessor.java           |    6 +-
 .../suggestions/GridPerformanceSuggestions.java |  105 +
 .../JvmConfigurationSuggestions.java            |  104 +
 .../suggestions/OsConfigurationSuggestions.java |  127 +
 .../internal/suggestions/package-info.java      |   21 +
 .../ignite/internal/util/GridBusyLock.java      |    2 +-
 .../ignite/internal/util/GridByteArrayList.java |    2 +-
 .../ignite/internal/util/GridLongList.java      |    2 +-
 .../internal/util/GridMessageCollection.java    |    2 +-
 .../internal/util/GridStripedSpinBusyLock.java  |    2 +-
 .../ignite/internal/util/HostAndPortRange.java  |    2 +-
 .../ignite/internal/util/IgniteUtils.java       |  144 +-
 .../util/StripedCompositeReadWriteLock.java     |   50 +-
 .../ignite/internal/util/StripedExecutor.java   |  103 +-
 .../internal/util/UUIDCollectionMessage.java    |    2 +-
 .../util/future/GridCompoundFuture.java         |   11 +-
 .../internal/util/ipc/IpcToNioAdapter.java      |    7 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   22 +-
 .../nio/GridAbstractCommunicationClient.java    |   37 +-
 .../util/nio/GridCommunicationClient.java       |    5 -
 .../nio/GridConnectionBytesVerifyFilter.java    |    7 +-
 .../internal/util/nio/GridDirectParser.java     |   12 +-
 .../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/VisorMultiNodeTask.java      |    2 +-
 .../ignite/internal/visor/cache/VisorCache.java |   84 +-
 .../cache/VisorCacheAggregatedMetrics.java      |    2 +-
 .../visor/cache/VisorCacheClearTask.java        |   41 +-
 .../visor/cache/VisorCacheConfiguration.java    |   22 +-
 .../internal/visor/cache/VisorCacheMetrics.java |   26 +
 .../cache/VisorCacheMetricsCollectorTask.java   |   18 +-
 .../visor/cache/VisorCacheMetricsV2.java        |   66 -
 .../cache/VisorCacheQueryConfiguration.java     |   11 +
 .../cache/VisorCacheQueryConfigurationV2.java   |   47 -
 .../cache/VisorCacheStoreConfiguration.java     |   12 +
 .../cache/VisorCacheStoreConfigurationV2.java   |   48 -
 .../cache/VisorCacheTypeFieldMetadata.java      |   14 +-
 .../visor/cache/VisorCacheTypeMetadata.java     |   97 +-
 .../internal/visor/cache/VisorCacheV2.java      |   73 -
 .../internal/visor/cache/VisorCacheV3.java      |   52 -
 .../internal/visor/cache/VisorCacheV4.java      |  124 -
 .../visor/compute/VisorGatewayTask.java         |   28 +-
 .../visor/event/VisorGridDiscoveryEvent.java    |   18 +-
 .../visor/event/VisorGridDiscoveryEventV2.java  |   80 -
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |   26 +-
 .../visor/igfs/VisorIgfsFormatTask.java         |    2 +-
 .../visor/node/VisorBasicConfiguration.java     |   12 +-
 .../visor/node/VisorIgfsConfiguration.java      |    7 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   58 +-
 .../node/VisorNodeDataCollectorJobResult.java   |   16 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |    2 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |   10 +-
 .../visor/query/VisorCancelQueriesTask.java     |   72 +
 .../query/VisorCollectRunningQueriesTask.java   |   96 +
 .../internal/visor/query/VisorQueryArg.java     |   39 +-
 .../internal/visor/query/VisorQueryArgV2.java   |   49 -
 .../internal/visor/query/VisorQueryJob.java     |   12 +-
 .../internal/visor/query/VisorRunningQuery.java |  132 +
 .../internal/visor/util/VisorEventMapper.java   |    4 +-
 .../internal/visor/util/VisorTaskUtils.java     |   23 +-
 .../apache/ignite/lang/IgniteAsyncSupport.java  |   52 +-
 .../ignite/lang/IgniteAsyncSupported.java       |    4 +-
 .../ignite/lang/IgniteProductVersion.java       |    2 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java |   25 +-
 .../ignite/marshaller/MarshallerContext.java    |   23 +-
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    1 -
 .../optimized/OptimizedClassDescriptor.java     |    2 +-
 .../optimized/OptimizedMarshaller.java          |   15 +-
 .../optimized/OptimizedMarshallerUtils.java     |   16 +-
 .../apache/ignite/mxbean/IgniteMBeanAware.java  |   28 +
 .../apache/ignite/mxbean/IgnitionMXBean.java    |   14 +-
 .../ignite/mxbean/StripedExecutorMXBean.java    |   90 +
 .../dotnet/PlatformDotNetAffinityFunction.java  |   10 +-
 .../PlatformDotNetBinaryConfiguration.java      |   31 +-
 .../PlatformDotNetBinaryTypeConfiguration.java  |   35 +-
 .../dotnet/PlatformDotNetConfiguration.java     |   10 +-
 .../extensions/communication/Message.java       |    5 +-
 .../communication/MessageFactory.java           |    2 +-
 .../extensions/communication/MessageWriter.java |    5 +-
 ...PlatformCachePluginConfigurationClosure.java |   31 +
 ...mCachePluginConfigurationClosureFactory.java |   37 +
 .../PlatformPluginConfigurationClosure.java     |   30 +
 ...atformPluginConfigurationClosureFactory.java |   37 +
 .../ignite/services/ServiceConfiguration.java   |   35 +-
 .../java/org/apache/ignite/spi/IgniteSpi.java   |    6 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   72 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |    6 +
 .../ignite/spi/IgniteSpiMBeanAdapter.java       |   78 +
 .../org/apache/ignite/spi/IgniteSpiThread.java  |    6 +-
 .../ignite/spi/IgniteSpiThreadFactory.java      |   10 +-
 .../checkpoint/cache/CacheCheckpointSpi.java    |   42 +-
 .../spi/checkpoint/jdbc/JdbcCheckpointSpi.java  |  221 +-
 .../spi/checkpoint/noop/NoopCheckpointSpi.java  |    9 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |   64 +-
 .../sharedfs/SharedFsTimeoutTask.java           |    6 +-
 .../ignite/spi/collision/CollisionSpi.java      |   11 +-
 .../fifoqueue/FifoQueueCollisionSpi.java        |  136 +-
 .../fifoqueue/FifoQueueCollisionSpiMBean.java   |    2 +-
 .../jobstealing/JobStealingCollisionSpi.java    |  283 +-
 .../JobStealingCollisionSpiMBean.java           |    6 +-
 .../jobstealing/JobStealingRequest.java         |    2 +-
 .../spi/collision/noop/NoopCollisionSpi.java    |    9 +-
 .../PriorityQueueCollisionSpi.java              |  280 +-
 .../PriorityQueueCollisionSpiMBean.java         |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |  756 ++++-
 .../tcp/TcpCommunicationSpiMBean.java           |    1 -
 .../deployment/local/LocalDeploymentSpi.java    |   26 +-
 .../ignite/spi/discovery/DiscoveryDataBag.java  |  299 ++
 .../spi/discovery/DiscoverySpiDataExchange.java |   15 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |  353 ++-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  303 +-
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |   12 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  537 +++-
 .../tcp/internal/DiscoveryDataPacket.java       |  345 +++
 .../tcp/internal/TcpDiscoveryNode.java          |    6 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |    8 +-
 .../ipfinder/TcpDiscoveryIpFinderAdapter.java   |    5 +-
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |   17 +-
 .../TcpDiscoveryMulticastIpFinder.java          |   47 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |   12 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |   14 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |   21 +
 .../messages/TcpDiscoveryClientAckResponse.java |    4 -
 .../TcpDiscoveryJoinRequestMessage.java         |   18 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |   10 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |   78 +-
 .../memory/MemoryEventStorageSpi.java           |  100 +-
 .../ignite/spi/failover/FailoverContext.java    |   10 -
 .../spi/failover/always/AlwaysFailoverSpi.java  |   55 +-
 .../jobstealing/JobStealingFailoverSpi.java     |   70 +-
 .../spi/failover/never/NeverFailoverSpi.java    |   32 +-
 .../spi/indexing/noop/NoopIndexingSpi.java      |    9 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |   45 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |   46 +-
 .../WeightedRandomLoadBalancingSpi.java         |   63 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |  120 +-
 .../spi/swapspace/noop/NoopSwapSpaceSpi.java    |    9 +-
 .../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  |   92 +-
 .../ignite/thread/IgniteThreadFactory.java      |   18 +-
 .../ignite/thread/IgniteThreadPoolExecutor.java |   12 +-
 .../apache/ignite/transactions/Transaction.java |   22 +
 .../resources/META-INF/classnames.properties    |  107 +-
 .../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 +-
 modules/core/src/test/config/log4j-test.xml     |    6 +
 .../test/config/store/jdbc/ignite-jdbc-type.xml |  279 ++
 .../config/store/jdbc/ignite-type-metadata.xml  |  276 --
 .../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     |   22 +-
 .../store/StoreResourceInjectionSelfTest.java   |    4 +-
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   25 +-
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   92 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |    4 +-
 .../ignite/cache/store/jdbc/model/Gender.java   |   41 +
 .../ignite/cache/store/jdbc/model/Person.java   |   31 +-
 .../ignite/custom/DummyEventFilterFactory.java  |   47 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |   66 +-
 .../igfs/IgfsFragmentizerAbstractSelfTest.java  |   23 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |    5 +-
 .../internal/ClusterGroupAbstractTest.java      |   77 +-
 .../internal/ClusterGroupHostsSelfTest.java     |   10 +-
 .../ignite/internal/ClusterMetricsSelfTest.java |    4 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |    4 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |   13 +-
 .../ignite/internal/GridAffinityMappedTest.java |   11 +-
 .../internal/GridAffinityNoCacheSelfTest.java   |    2 +-
 .../internal/GridAffinityP2PSelfTest.java       |   11 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   10 +-
 .../GridAlwaysFailoverSpiFailSelfTest.java      |    4 +-
 .../internal/GridCacheRecreateLockTest.java     |   78 +
 .../internal/GridCancelOnGridStopSelfTest.java  |    2 +-
 .../internal/GridCancelUnusedJobSelfTest.java   |    6 +-
 .../GridCancelledJobsMetricsSelfTest.java       |   15 +-
 .../GridCollisionJobsContextSelfTest.java       |   10 +-
 .../internal/GridCommunicationSelfTest.java     |    2 +-
 ...omputationBinarylizableClosuresSelfTest.java |    4 +-
 .../GridContinuousJobAnnotationSelfTest.java    |    4 +-
 .../internal/GridContinuousTaskSelfTest.java    |  104 +-
 .../ignite/internal/GridDeploymentSelfTest.java |   16 +-
 .../internal/GridDiscoveryEventSelfTest.java    |    4 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    6 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |   16 +-
 ...ventStorageRuntimeConfigurationSelfTest.java |    4 +-
 .../internal/GridFactoryVmShutdownTest.java     |    2 +-
 ...ridFailFastNodeFailureDetectionSelfTest.java |    6 +-
 .../GridFailedInputParametersSelfTest.java      |    2 +-
 .../GridFailoverCustomTopologySelfTest.java     |   11 +-
 .../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        |   97 +-
 .../internal/GridJobStealingSelfTest.java       |    4 +-
 .../GridJobStealingZeroActiveJobsSelfTest.java  |    6 +-
 .../internal/GridLifecycleAwareSelfTest.java    |    4 +-
 .../internal/GridLifecycleBeanSelfTest.java     |   16 +-
 .../GridLocalEventListenerSelfTest.java         |    6 +-
 .../internal/GridMultipleJobsSelfTest.java      |   14 +-
 .../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 +-
 .../ignite/internal/GridReduceSelfTest.java     |    9 +-
 .../internal/GridReleaseTypeSelfTest.java       |    4 +-
 .../internal/GridRuntimeExceptionSelfTest.java  |    8 +-
 .../internal/GridSpiExceptionSelfTest.java      |    8 +-
 .../ignite/internal/GridStartStopSelfTest.java  |    6 +-
 .../internal/GridStopWithWaitSelfTest.java      |   12 +-
 .../GridTaskCancelSingleNodeSelfTest.java       |    7 +-
 .../internal/GridTaskExecutionSelfTest.java     |   58 +-
 ...xecutionWithoutPeerClassLoadingSelfTest.java |   31 +
 .../GridTaskFailoverAffinityRunTest.java        |   13 +-
 .../GridTaskFutureImplStopGridSelfTest.java     |    8 +-
 .../GridTaskInstanceExecutionSelfTest.java      |    9 +-
 .../internal/GridTaskJobRejectSelfTest.java     |   11 +-
 .../internal/GridTaskListenerSelfTest.java      |    2 +-
 .../internal/GridTaskMapAsyncSelfTest.java      |    6 +-
 .../internal/GridTaskResultCacheSelfTest.java   |    4 +-
 .../internal/GridTaskTimeoutSelfTest.java       |    8 +-
 .../IgniteClientReconnectAbstractTest.java      |    4 +-
 .../IgniteClientReconnectApiExceptionTest.java  |   20 +-
 .../IgniteClientReconnectCacheTest.java         |   20 +-
 ...niteClientReconnectFailoverAbstractTest.java |    8 +-
 .../IgniteClientReconnectFailoverTest.java      |    4 +-
 .../IgniteClientReconnectStreamerTest.java      |    4 +-
 .../ignite/internal/IgniteClientRejoinTest.java |  378 +++
 .../IgniteComputeEmptyClusterGroupTest.java     |   30 +-
 .../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        |  123 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |   13 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java |  131 +-
 ...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 +-
 .../binary/TestCachingMetadataHandler.java      |    5 +
 ...ByteBufferStreamImplV2ByteOrderSelfTest.java |    2 +-
 ...GridManagerLocalMessageListenerSelfTest.java |    8 +-
 .../managers/GridNoopManagerSelfTest.java       |    2 +-
 .../GridCheckpointManagerAbstractSelfTest.java  |   33 +-
 .../checkpoint/GridCheckpointTaskSelfTest.java  |    4 +-
 ...idCommunicationManagerListenersSelfTest.java |    6 +-
 .../GridCommunicationSendMessageSelfTest.java   |   87 +-
 .../communication/GridIoManagerSelfTest.java    |   34 +-
 .../IgniteCommunicationBalanceTest.java         |    4 +-
 .../communication/IgniteIoTestMessagesTest.java |    4 +-
 .../IgniteVariousConnectionNumberTest.java      |    6 +-
 .../GridDeploymentManagerStopSelfTest.java      |    2 +-
 .../GridDeploymentMessageCountSelfTest.java     |    6 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   64 +-
 .../GridDiscoveryManagerAttributesSelfTest.java |   14 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |  214 --
 .../IgniteTopologyPrintFormatSelfTest.java      |    8 +-
 .../events/GridEventStorageManagerSelfTest.java |    4 +-
 .../swapspace/GridSwapSpaceManagerSelfTest.java |    4 +-
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java |    4 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |    4 +-
 .../BinaryObjectOffHeapUnswapTemporaryTest.java |    5 +-
 .../cache/CacheAffinityCallSelfTest.java        |   14 +-
 .../CacheAtomicSingleMessageCountSelfTest.java  |    4 +-
 .../cache/CacheClientStoreSelfTest.java         |    6 +-
 .../cache/CacheConcurrentReadThroughTest.java   |  180 ++
 .../cache/CacheDeferredDeleteQueueTest.java     |  134 +
 ...cheDhtLocalPartitionAfterRemoveSelfTest.java |    4 +-
 .../cache/CacheEntryProcessorCopySelfTest.java  |    4 +-
 .../cache/CacheEnumOperationsAbstractTest.java  |    4 +-
 ...CacheExchangeMessageDuplicatedStateTest.java |   18 +-
 .../cache/CacheFutureExceptionSelfTest.java     |   12 +-
 .../cache/CacheGetEntryAbstractTest.java        |   20 +-
 ...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     |   11 +-
 .../processors/cache/CachePutIfAbsentTest.java  |    4 +-
 .../cache/CacheReadThroughRestartSelfTest.java  |    6 +-
 .../cache/CacheRebalancingSelfTest.java         |   20 +-
 .../CacheSerializableTransactionsTest.java      |  183 +-
 .../CacheStartupInDeploymentModesTest.java      |   11 +-
 .../cache/CacheStopAndDestroySelfTest.java      |   12 +-
 .../CacheStoreUsageMultinodeAbstractTest.java   |   10 +-
 .../cache/CacheSwapUnswapGetTest.java           |    4 +-
 .../CacheSwapUnswapGetTestSmallQueueSize.java   |    4 +-
 .../processors/cache/CacheTxFastFinishTest.java |    6 +-
 .../CacheTxNotAllowReadFromBackupTest.java      |    4 +-
 .../processors/cache/CrossCacheLockTest.java    |    6 +-
 .../cache/CrossCacheTxRandomOperationsTest.java |    6 +-
 .../EntryVersionConsistencyReadThroughTest.java |    4 +-
 ...idAbstractCacheInterceptorRebalanceTest.java |    4 +-
 ...ridCacheAbstractByteArrayValuesSelfTest.java |    4 +-
 .../GridCacheAbstractFailoverSelfTest.java      |   22 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java |  105 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  918 +++++-
 .../GridCacheAbstractLocalStoreSelfTest.java    |   24 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   52 +-
 .../GridCacheAbstractRemoveFailureTest.java     |    6 +-
 .../cache/GridCacheAbstractSelfTest.java        |   10 +-
 .../cache/GridCacheAbstractTxReadTest.java      |    8 +-
 ...acheAbstractUsersAffinityMapperSelfTest.java |    4 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |    4 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |    6 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |   13 +-
 ...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     |   28 +-
 .../GridCacheConditionalDeploymentSelfTest.java |    8 +-
 ...idCacheConfigurationConsistencySelfTest.java |   10 +-
 ...ridCacheConfigurationValidationSelfTest.java |   46 +-
 .../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   |   39 +-
 .../cache/GridCacheIteratorPerformanceTest.java |    4 +-
 .../cache/GridCacheKeyCheckSelfTest.java        |    4 +-
 .../processors/cache/GridCacheLeakTest.java     |    4 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   37 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |    4 +-
 .../GridCacheMarshallerTxAbstractTest.java      |    4 +-
 .../GridCacheMarshallingNodeJoinSelfTest.java   |    4 +-
 .../cache/GridCacheMemoryModeSelfTest.java      |    4 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |    6 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    4 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |    4 +-
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |    4 +-
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    4 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |   48 +-
 .../processors/cache/GridCacheMvccSelfTest.java |  208 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |    4 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    4 +-
 .../cache/GridCacheOffHeapCleanupTest.java      |    4 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |    2 +-
 .../processors/cache/GridCacheOffHeapTest.java  |  274 --
 .../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  |   26 +-
 .../GridCacheQueryIndexingDisabledSelfTest.java |    4 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |    4 +-
 .../GridCacheReferenceCleanupSelfTest.java      |   19 +-
 .../cache/GridCacheReloadSelfTest.java          |    4 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |    6 +-
 .../GridCacheReturnValueTransferSelfTest.java   |    4 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    4 +-
 .../processors/cache/GridCacheStopSelfTest.java |    8 +-
 ...ridCacheStoreManagerDeserializationTest.java |    7 +-
 .../cache/GridCacheStorePutxSelfTest.java       |    4 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |    4 +-
 .../cache/GridCacheSwapCleanupTest.java         |    4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |    4 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |    4 +-
 ...ridCacheSwapSpaceSpiConsistencySelfTest.java |   10 +-
 ...acheTcpClientDiscoveryMultiThreadedTest.java |    4 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   33 +-
 .../processors/cache/GridCacheTestStore.java    |    2 -
 .../GridCacheTtlManagerEvictionSelfTest.java    |    4 +-
 .../GridCacheTtlManagerNotificationTest.java    |    4 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |    4 +-
 .../cache/GridCacheUtilsSelfTest.java           |    6 +-
 .../GridCacheValueBytesPreloadingSelfTest.java  |   10 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |    4 +-
 .../GridCacheVariableTopologySelfTest.java      |    4 +-
 .../cache/GridCacheVersionMultinodeTest.java    |    4 +-
 .../GridCacheVersionTopologyChangeTest.java     |    4 +-
 ...calCacheStoreManagerDeserializationTest.java |    2 +-
 .../cache/GridLocalIgniteSerializationTest.java |   10 +-
 ...ProjectionForCachesOnDaemonNodeSelfTest.java |   12 +-
 .../IgniteCacheAbstractStopBusySelfTest.java    |   13 +-
 .../cache/IgniteCacheAbstractTest.java          |   10 +-
 ...IgniteCacheBinaryEntryProcessorSelfTest.java |    6 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |    8 +-
 .../IgniteCacheConfigVariationsFullApiTest.java |  985 ++++++-
 ...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 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |   20 +-
 ...gniteCacheInvokeReadThroughAbstractTest.java |    4 +-
 ...gniteCacheLoadRebalanceEvictionSelfTest.java |    4 +-
 .../IgniteCacheManyAsyncOperationsTest.java     |   12 +-
 .../cache/IgniteCacheNearLockValueSelfTest.java |    6 +-
 .../IgniteCacheP2pUnmarshallingErrorTest.java   |    8 +-
 ...gniteCacheP2pUnmarshallingNearErrorTest.java |    4 +-
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java |    6 +-
 .../IgniteCachePartitionMapUpdateTest.java      |    4 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |   51 +-
 .../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   |    5 +-
 .../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 |  273 ++
 ...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 |   16 +-
 ...niteTopologyValidatorGridSplitCacheTest.java |  334 +++
 .../processors/cache/IgniteTxAbstractTest.java  |    7 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |    4 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |   10 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |   13 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    4 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |    4 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |    4 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |    8 +-
 .../MarshallerCacheJobRunNodeRestartTest.java   |    4 +-
 .../cache/OffHeapTieredTransactionSelfTest.java |    4 +-
 ...heapCacheMetricsForClusterGroupSelfTest.java |    4 +-
 .../cache/OffheapCacheOnClientsTest.java        |    4 +-
 ...sExchangeOnDiscoveryHistoryOverflowTest.java |  190 ++
 .../cache/WithKeepBinaryCacheFullApiTest.java   |  228 +-
 .../binary/BinaryMetadataUpdatesFlowTest.java   |  592 ++++
 .../CacheKeepBinaryWithInterceptorTest.java     |   21 +-
 .../GridBinaryCacheEntryMemorySizeSelfTest.java |   21 +-
 ...ryDuplicateIndexObjectsAbstractSelfTest.java |  161 -
 ...yAtomicEntryProcessorDeploymentSelfTest.java |    4 +-
 ...naryObjectMetadataExchangeMultinodeTest.java |  463 +++
 ...acheBinaryObjectUserClassloaderSelfTest.java |   10 +-
 ...naryObjectsAbstractDataStreamerSelfTest.java |    4 +-
 ...aryObjectsAbstractMultiThreadedSelfTest.java |    4 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |  115 +-
 .../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 +-
 ...ateIndexObjectPartitionedAtomicSelfTest.java |   38 -
 ...xObjectPartitionedTransactionalSelfTest.java |   41 -
 .../dht/GridCacheMemoryModeBinarySelfTest.java  |    4 +-
 ...dCacheOffHeapTieredAtomicBinarySelfTest.java |    4 +-
 .../GridCacheOffHeapTieredBinarySelfTest.java   |    4 +-
 ...fHeapTieredEvictionAtomicBinarySelfTest.java |    4 +-
 ...acheOffHeapTieredEvictionBinarySelfTest.java |    4 +-
 ...IgniteCacheAbstractExecutionContextTest.java |   10 +-
 ...niteCacheContinuousExecutionContextTest.java |    4 +-
 ...IgniteCacheIsolatedExecutionContextTest.java |    4 +-
 ...niteCacheP2PDisableExecutionContextTest.java |    4 +-
 .../IgniteCachePrivateExecutionContextTest.java |    4 +-
 .../IgniteCacheSharedExecutionContextTest.java  |    4 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |   69 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    6 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   60 +-
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   59 +
 .../GridCacheQueueApiSelfAbstractTest.java      |   58 +
 .../GridCacheQueueCleanupSelfTest.java          |    4 +-
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   12 +-
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |    6 +-
 .../GridCacheSequenceApiSelfAbstractTest.java   |    4 +-
 .../GridCacheSetAbstractSelfTest.java           |   53 +
 .../IgniteAtomicLongApiAbstractSelfTest.java    |   31 +-
 .../IgniteAtomicsAbstractTest.java              |    4 +-
 .../IgniteClientDataStructuresAbstractTest.java |    6 +-
 .../IgniteCollectionAbstractTest.java           |    4 +-
 .../IgniteCountDownLatchAbstractSelfTest.java   |   50 +-
 .../IgniteDataStructureUniqueNameTest.java      |    4 +-
 .../IgniteDataStructureWithJobTest.java         |    4 +-
 .../IgniteLockAbstractSelfTest.java             |   85 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   61 +-
 ...SemaphoreFailoverSafeReleasePermitsTest.java |    4 +-
 ...achePartitionedAtomicSequenceTxSelfTest.java |    4 +-
 ...idCachePartitionedNodeRestartTxSelfTest.java |    4 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |    4 +-
 .../CacheAbstractRestartSelfTest.java           |    6 +-
 .../distributed/CacheAffinityEarlyTest.java     |    4 +-
 ...acheAsyncOperationsFailoverAbstractTest.java |   20 +-
 .../distributed/CacheAsyncOperationsTest.java   |   38 +-
 .../CacheGetFutureHangsSelfTest.java            |   10 +-
 .../CacheGetInsideLockChangingTopologyTest.java |    4 +-
 ...ffinityAssignmentNodeJoinValidationTest.java |    4 +-
 .../CacheLateAffinityAssignmentTest.java        |   61 +-
 ...CacheLoadingConcurrentGridStartSelfTest.java |   12 +-
 .../CacheLockReleaseNodeLeaveTest.java          |   68 +-
 .../CachePutAllFailoverAbstractTest.java        |   16 +-
 .../CacheTryLockMultithreadedTest.java          |    4 +-
 ...tractDistributedByteArrayValuesSelfTest.java |    4 +-
 .../GridCacheAbstractJobExecutionTest.java      |   23 +-
 .../GridCacheAbstractNodeRestartSelfTest.java   |    4 +-
 ...tractPartitionedByteArrayValuesSelfTest.java |    4 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java   |    4 +-
 .../GridCacheBasicOpAbstractTest.java           |   42 +-
 .../GridCacheClientModesAbstractSelfTest.java   |   24 +-
 ...ientModesTcpClientDiscoveryAbstractTest.java |    4 +-
 ...acheEntrySetIterationPreloadingSelfTest.java |    4 +-
 .../distributed/GridCacheEventAbstractTest.java |   84 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |    4 +-
 .../distributed/GridCacheLockAbstractTest.java  |    4 +-
 .../distributed/GridCacheMixedModeSelfTest.java |   12 +-
 .../GridCacheMultiNodeAbstractTest.java         |   29 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |    4 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    8 +-
 .../GridCacheNodeFailureAbstractTest.java       |    4 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |   12 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |    4 +-
 .../GridCachePreloadEventsAbstractSelfTest.java |    4 +-
 .../GridCachePreloadLifecycleAbstractTest.java  |    4 +-
 ...GridCachePreloadRestartAbstractSelfTest.java |    4 +-
 .../GridCacheTransformEventSelfTest.java        |    4 +-
 ...yMetadataUpdateChangingTopologySelfTest.java |   24 +-
 ...niteBinaryMetadataUpdateNodeRestartTest.java |    4 +-
 .../distributed/IgniteCache150ClientsTest.java  |    6 +-
 ...micMessageRecoveryPairedConnectionsTest.java |    4 +-
 ...niteCacheClientNodeChangingTopologyTest.java |   42 +-
 .../IgniteCacheClientNodeConcurrentStart.java   |    6 +-
 ...teCacheClientNodePartitionsExchangeTest.java |    8 +-
 .../IgniteCacheClientReconnectTest.java         |    4 +-
 ...acheConnectionRecovery10ConnectionsTest.java |    4 +-
 .../IgniteCacheConnectionRecoveryTest.java      |   14 +-
 .../IgniteCacheCreatePutMultiNodeSelfTest.java  |    4 +-
 .../distributed/IgniteCacheCreatePutTest.java   |    4 +-
 .../distributed/IgniteCacheGetRestartTest.java  |    6 +-
 .../distributed/IgniteCacheManyClientsTest.java |    4 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java |    6 +-
 ...eCacheMessageRecoveryIdleConnectionTest.java |   10 +-
 .../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           |    9 +-
 ...teSynchronizationModesMultithreadedTest.java |   12 +-
 ...iteTxConsistencyRestartAbstractSelfTest.java |   10 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |   14 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |   18 +-
 .../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 |   21 +-
 .../GridCacheDhtPreloadDisabledSelfTest.java    |    6 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |    4 +-
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   10 +-
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |    4 +-
 .../dht/GridCacheDhtPreloadPerformanceTest.java |    4 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |    4 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |   20 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |    8 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |    4 +-
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    4 +-
 .../dht/GridCacheGlobalLoadTest.java            |   25 +-
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |    4 +-
 ...ePartitionedNearDisabledMetricsSelfTest.java |    8 +-
 ...idCachePartitionedPreloadEventsSelfTest.java |    4 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |    6 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |    4 +-
 ...ridCachePartitionedUnloadEventsSelfTest.java |    4 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java     |   22 +-
 .../dht/GridNearCacheTxNodeFailureSelfTest.java |    4 +-
 ...gniteAtomicLongChangingTopologySelfTest.java |    4 +-
 .../IgniteCacheCommitDelayTxRecoveryTest.java   |    4 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |    4 +-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |   12 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java    |    8 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |    4 +-
 ...artitionedBackupNodeFailureRecoveryTest.java |    4 +-
 ...woBackupsPrimaryNodeFailureRecoveryTest.java |    4 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |   17 +-
 .../IgniteCachePutRetryAbstractSelfTest.java    |   67 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |    6 +-
 .../dht/IgniteCacheTxRecoveryRollbackTest.java  |  501 ++++
 .../dht/IgniteCrossCacheTxSelfTest.java         |    4 +-
 .../AtomicPutAllChangingTopologyTest.java       |    2 +-
 .../atomic/GridCacheAtomicFailoverSelfTest.java |    4 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   10 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |    4 +-
 ...AtomicPrimaryWriteOrderFailoverSelfTest.java |    4 +-
 .../atomic/IgniteCacheAtomicProtocolTest.java   |  865 ++++++
 ...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 +-
 ...erNoStripedPoolMultiNodeFullApiSelfTest.java |   35 -
 .../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 |   25 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |    4 +-
 .../GridCacheNearPartitionedClearSelfTest.java  |    4 +-
 .../GridCacheNearReaderPreloadSelfTest.java     |    6 +-
 .../near/GridCacheNearReadersSelfTest.java      |   21 +-
 .../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  |   13 +-
 .../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/GridNearCacheStoreUpdateTest.java      |  466 +++
 .../GridNearOffheapCacheStoreUpdateTest.java    |   35 +
 .../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       |   82 +-
 ...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     |    8 +-
 .../GridCacheReplicatedJobExecutionTest.java    |    4 +-
 .../GridCacheReplicatedMarshallerTxTest.java    |    4 +-
 .../GridCacheReplicatedMetricsSelfTest.java     |    4 +-
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    4 +-
 .../GridCacheReplicatedNodeFailureSelfTest.java |    4 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java |    3 +-
 .../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     |   15 +-
 ...eplicatedPreloadStartStopEventsSelfTest.java |    4 +-
 .../cache/eviction/EvictionAbstractTest.java    |    8 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |    4 +-
 ...heConcurrentEvictionConsistencySelfTest.java |    4 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |    4 +-
 .../GridCacheDistributedEvictionsSelfTest.java  |    4 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   25 +-
 .../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    |   50 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |  104 +-
 .../expiry/IgniteCacheTtlCleanupSelfTest.java   |    4 +-
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java |   21 +
 .../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    |    8 +-
 .../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 +-
 .../IgniteCacheQueryCacheDestroySelfTest.java   |  142 +
 .../cache/query/IndexingSpiQuerySelfTest.java   |   71 +-
 .../cache/query/IndexingSpiQueryTxSelfTest.java |    8 +-
 .../IndexingSpiQueryWithH2IndexingSelfTest.java |   36 +
 .../continuous/CacheContinuousBatchAckTest.java |   12 +-
 ...heContinuousBatchForceServerModeAckTest.java |    8 +-
 ...eContinuousQueryAsyncFilterListenerTest.java |    6 +-
 ...CacheContinuousQueryCounterAbstractTest.java |    8 +-
 ...acheContinuousQueryExecuteInPrimaryTest.java |    4 +-
 ...ContinuousQueryFailoverAbstractSelfTest.java |   41 +-
 .../CacheContinuousQueryLostPartitionTest.java  |    6 +-
 ...ontinuousQueryOperationFromCallbackTest.java |    4 +-
 .../CacheContinuousQueryOperationP2PTest.java   |    4 +-
 .../CacheContinuousQueryOrderingEventTest.java  |    4 +-
 ...acheContinuousQueryRandomOperationsTest.java |    4 +-
 .../CacheContinuousQueryVariationsTest.java     |   11 +-
 ...eEntryProcessorExternalizableFailedTest.java |    4 +-
 .../CacheEntryProcessorNonSerializableTest.java |    4 +-
 ...CacheKeepBinaryIterationSwapEnabledTest.java |    4 +-
 .../CacheKeepBinaryIterationTest.java           |    4 +-
 .../ClientReconnectContinuousQueryTest.java     |  201 ++
 .../ContinuousQueryPeerClassLoadingTest.java    |  142 +
 ...yRemoteFilterMissingInClassPathSelfTest.java |    4 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |   12 +-
 .../GridCacheContinuousQueryConcurrentTest.java |   11 +-
 ...eContinuousQueryMultiNodesFilteringTest.java |   10 +-
 ...dCacheContinuousQueryNodesFilteringTest.java |    2 +-
 ...eContinuousQueryReplicatedTxOneNodeTest.java |    4 +-
 ...niteCacheContinuousQueryBackupQueueTest.java |    4 +-
 ...CacheContinuousQueryClientReconnectTest.java |    4 +-
 .../IgniteCacheContinuousQueryClientTest.java   |    4 +-
 ...eCacheContinuousQueryImmutableEntryTest.java |    6 +-
 ...teCacheContinuousQueryNoUnsubscribeTest.java |    4 +-
 ...IgniteCacheContinuousQueryReconnectTest.java |   16 +-
 ...BehindStorePartitionedMultiNodeSelfTest.java |    4 +-
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java |    4 +-
 ...CacheClientWriteBehindStoreAbstractTest.java |   12 +-
 .../TxDeadlockDetectionNoHangsTest.java         |    6 +-
 .../transactions/TxDeadlockDetectionTest.java   |    6 +-
 ...timisticDeadlockDetectionCrossCacheTest.java |    4 +-
 .../TxOptimisticDeadlockDetectionTest.java      |   36 +-
 ...simisticDeadlockDetectionCrossCacheTest.java |    4 +-
 .../TxPessimisticDeadlockDetectionTest.java     |    6 +-
 ...edEntryPartitionedAtomicOffHeapSelfTest.java |    4 +-
 ...PartitionedTransactionalOffHeapSelfTest.java |    4 +-
 ...nedEntryReplicatedAtomicOffHeapSelfTest.java |    4 +-
 ...yReplicatedTransactionalOffHeapSelfTest.java |    4 +-
 .../clock/GridTimeSyncProcessorSelfTest.java    |    4 +-
 .../closure/GridClosureProcessorRemoteTest.java |    2 +-
 .../closure/GridClosureProcessorSelfTest.java   |   78 +-
 .../closure/GridClosureSerializationTest.java   |    4 +-
 .../cluster/GridAddressResolverSelfTest.java    |    6 +-
 ...ComputeJobExecutionErrorToLogManualTest.java |   18 +-
 ...gniteComputeConfigVariationsFullApiTest.java |  533 +++-
 .../compute/PublicThreadpoolStarvationTest.java |    4 +-
 .../continuous/GridEventConsumeSelfTest.java    |  200 +-
 .../continuous/GridMessageListenSelfTest.java   |    4 +-
 .../IgniteNoCustomEventsOnNodeStart.java        |    4 +-
 .../DataStreamProcessorSelfTest.java            |   10 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |   12 +-
 .../DataStreamerMultiThreadedSelfTest.java      |    4 +-
 .../DataStreamerMultinodeCreateCacheTest.java   |    4 +-
 .../datastreamer/DataStreamerTimeoutTest.java   |   10 +-
 .../DataStreamerUpdateAfterLoadTest.java        |    4 +-
 .../IgniteDataStreamerPerformanceTest.java      |    4 +-
 ...faultIgfsSecondaryFileSystemTestAdapter.java |    2 +-
 .../igfs/IgfsAbstractBaseSelfTest.java          |   25 +-
 .../processors/igfs/IgfsAbstractSelfTest.java   |   36 +-
 .../igfs/IgfsBackupFailoverSelfTest.java        |   20 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |   23 +-
 ...sCachePerBlockLruEvictionPolicySelfTest.java |   24 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |   23 +-
 .../processors/igfs/IgfsCommonAbstractTest.java |    8 +-
 .../igfs/IgfsDataManagerSelfTest.java           |   37 +-
 .../processors/igfs/IgfsFileInfoSelfTest.java   |    4 +-
 .../processors/igfs/IgfsMaxSizeSelfTest.java    |   12 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |   15 +-
 .../processors/igfs/IgfsMetricsSelfTest.java    |   22 +-
 .../internal/processors/igfs/IgfsMock.java      |   43 +-
 .../igfs/IgfsModeResolverSelfTest.java          |   10 +-
 .../processors/igfs/IgfsModesSelfTest.java      |   55 +-
 .../processors/igfs/IgfsOneClientNodeTest.java  |   17 +-
 .../processors/igfs/IgfsProcessorSelfTest.java  |   37 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   |  324 +--
 ...gfsSecondaryFileSystemInjectionSelfTest.java |    8 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |   21 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |   31 +-
 .../processors/igfs/IgfsStartCacheTest.java     |   30 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |   52 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |   96 +-
 .../igfs/benchmark/IgfsBenchmark.java           |    4 +-
 .../IgfsAbstractRecordResolverSelfTest.java     |   12 +-
 ...niteMessagingConfigVariationFullApiTest.java |  108 +-
 .../odbc/OdbcEscapeSequenceSelfTest.java        |  131 +
 .../odbc/OdbcProcessorValidationSelfTest.java   |    2 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    1 -
 .../service/ClosureServiceClientsNodesTest.java |   10 +-
 .../service/GridServiceClientNodeTest.java      |    4 +-
 .../GridServiceContinuousQueryRedeployTest.java |  167 ++
 ...rviceDeploymentExceptionPropagationTest.java |    2 +-
 .../GridServiceProcessorAbstractSelfTest.java   |  295 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |   18 +-
 .../GridServiceProcessorStopSelfTest.java       |   84 +-
 ...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  |    6 +-
 .../ServicePredicateAccessCacheTest.java        |    4 +-
 .../internal/util/IgniteUtilsSelfTest.java      |   71 +-
 .../internal/util/StripedExecutorTest.java      |  168 ++
 .../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 |    8 +-
 .../nio/impl/GridNioFilterChainSelfTest.java    |   12 +-
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |    7 +-
 .../lang/GridMetadataAwareAdapterSelfTest.java  |    4 +-
 .../loadtest/GridSingleExecutionTest.java       |   10 +-
 .../loadtests/GridCacheMultiNodeLoadTest.java   |    4 +-
 .../loadtests/colocation/GridTestMain.java      |    7 +-
 .../communication/GridIoManagerBenchmark.java   |    4 +-
 .../communication/GridIoManagerBenchmark0.java  |   18 +-
 .../GridTcpCommunicationBenchmark.java          |    2 +-
 .../communication/GridTestMessage.java          |    2 +-
 .../GridCachePartitionedAtomicLongLoadTest.java |    4 +-
 .../multisplit/GridMultiSplitsLoadTest.java     |   11 +-
 .../GridMultiSplitsRedeployLoadTest.java        |    2 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   16 +-
 .../GridSingleSplitsRedeployLoadTest.java       |    2 +-
 .../direct/session/GridSessionLoadTest.java     |    2 +-
 .../direct/stealing/GridStealingLoadTest.java   |    4 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |   12 +-
 ...GridJobExecutionLoadTestClientSemaphore.java |    9 +-
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |   10 +-
 .../ignite/loadtests/job/GridJobLoadTest.java   |    6 +-
 .../loadtests/job/GridJobLoadTestSubmitter.java |    7 +-
 .../mergesort/GridMergeSortLoadTask.java        |    7 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |    2 +-
 ...namicProxySerializationMultiJvmSelfTest.java |    4 +-
 .../marshaller/GridMarshallerAbstractTest.java  |   15 +-
 .../GridMarshallerPerformanceTest.java          |    4 +
 .../marshaller/MarshallerContextSelfTest.java   |  220 +-
 .../marshaller/MarshallerContextTestImpl.java   |   33 +-
 .../OptimizedMarshallerEnumSelfTest.java        |   25 +-
 .../OptimizedMarshallerNodeFailoverTest.java    |    4 +-
 ...GridMessagingNoPeerClassLoadingSelfTest.java |    4 +-
 .../ignite/messaging/GridMessagingSelfTest.java |  191 +-
 .../messaging/IgniteMessagingSendAsyncTest.java |  495 ++++
 .../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     |   18 +-
 .../ignite/p2p/GridP2PTimeoutSelfTest.java      |    4 +-
 .../ignite/p2p/GridP2PUndeploySelfTest.java     |    6 +-
 .../platform/PlatformComputeEchoTask.java       |   18 +
 .../platform/PlatformEventsWriteEventTask.java  |    9 -
 .../ignite/platform/PlatformExceptionTask.java  |   78 +
 .../PlatformJavaObjectFactoryProxySelfTest.java |    2 +-
 .../ignite/platform/PlatformStopIgniteTask.java |   21 +-
 .../platform/plugin/PlatformTestPlugin.java     |   27 +
 .../plugin/PlatformTestPluginConfiguration.java |   63 +
 ...rmTestPluginConfigurationClosureFactory.java |   61 +
 .../plugin/PlatformTestPluginException.java     |   34 +
 .../plugin/PlatformTestPluginExtension.java     |   51 +
 .../plugin/PlatformTestPluginProvider.java      |   97 +
 .../plugin/PlatformTestPluginTarget.java        |  231 ++
 .../cache/PlatformGetCachePluginsTask.java      |   85 +
 .../PlatformTestCachePluginConfiguration.java   |   60 +
 ...formTestCachePluginConfigurationClosure.java |   48 +
 ...tCachePluginConfigurationClosureFactory.java |   37 +
 .../cache/PlatformTestCachePluginProvider.java  |   73 +
 .../services/ServiceThreadPoolSelfTest.java     |  133 +
 ...SessionCancelSiblingsFromFutureSelfTest.java |    6 +-
 ...ridSessionCancelSiblingsFromJobSelfTest.java |    6 +-
 ...idSessionCancelSiblingsFromTaskSelfTest.java |    6 +-
 .../GridSessionCheckpointAbstractSelfTest.java  |    2 +-
 .../GridSessionCollisionSpiSelfTest.java        |    2 +-
 ...idSessionFutureWaitJobAttributeSelfTest.java |   13 +-
 ...dSessionFutureWaitTaskAttributeSelfTest.java |    6 +-
 .../session/GridSessionJobFailoverSelfTest.java |    4 +-
 ...GridSessionJobWaitTaskAttributeSelfTest.java |    6 +-
 .../ignite/session/GridSessionLoadSelfTest.java |    4 +-
 .../GridSessionSetFutureAttributeSelfTest.java  |    6 +-
 ...nSetFutureAttributeWaitListenerSelfTest.java |    6 +-
 ...GridSessionSetJobAttributeOrderSelfTest.java |    8 +-
 .../GridSessionSetJobAttributeSelfTest.java     |    6 +-
 ...sionSetJobAttributeWaitListenerSelfTest.java |   13 +-
 .../GridSessionSetTaskAttributeSelfTest.java    |   13 +-
 ...GridSessionTaskWaitJobAttributeSelfTest.java |   13 +-
 .../GridSessionWaitAttributeSelfTest.java       |   17 +-
 .../spi/GridSpiStartStopAbstractTest.java       |    2 +-
 .../spi/GridTcpSpiForwardingSelfTest.java       |   10 +-
 .../CacheCheckpointSpiSecondCacheSelfTest.java  |    4 +-
 .../GridAbstractCommunicationSelfTest.java      |    4 +-
 .../communication/GridCacheMessageSelfTest.java |   26 +-
 .../spi/communication/GridTestMessage.java      |    4 +-
 .../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 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |  323 ++
 .../TcpCommunicationSpiFaultyClientTest.java    |  266 ++
 .../local/GridLocalDeploymentSpiSelfTest.java   |    6 +-
 .../discovery/AbstractDiscoverySelfTest.java    |    9 +-
 ...gniteClientReconnectMassiveShutdownTest.java |    4 +-
 ...pClientDiscoveryMarshallerCheckSelfTest.java |    6 +-
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |    4 +-
 .../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 |  147 +-
 .../tcp/TcpDiscoverySnapshotHistoryTest.java    |    4 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |    2 +-
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |   74 +-
 .../tcp/TcpDiscoverySpiStartStopSelfTest.java   |   11 +-
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java    |    4 +-
 .../TcpDiscoverySslSecuredUnsecuredTest.java    |  185 ++
 .../discovery/tcp/TcpDiscoverySslSelfTest.java  |    4 +-
 .../tcp/TestReconnectPluginProvider.java        |  111 +
 .../discovery/tcp/TestReconnectProcessor.java   |   93 +
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java      |    2 +-
 .../spi/failover/GridFailoverTestContext.java   |    7 +-
 .../GridInternalTasksLoadBalancingSelfTest.java |    6 +-
 .../GridSwapSpaceSpiAbstractSelfTest.java       |    3 +-
 .../GridSwapSpaceSpiConsistencySelfTest.java    |   12 +-
 .../file/GridFileSwapSpaceSpiSelfTest.java      |    2 +-
 .../inmemory/GridTestSwapSpaceSpi.java          |    2 +-
 .../noop/GridNoopSwapSpaceSpiSelfTest.java      |    4 +-
 .../startup/GridRandomCommandLineLoader.java    |    2 +-
 .../ignite/startup/GridVmNodesStarter.java      |    4 +-
 .../stream/socket/SocketStreamerSelfTest.java   |    4 +-
 .../testframework/GridSpiTestContext.java       |   10 +-
 .../ignite/testframework/GridTestNode.java      |    3 +-
 .../ignite/testframework/GridTestUtils.java     |   67 +-
 .../ignite/testframework/IgniteTestSuite.java   |    2 +-
 .../configvariations/ConfigFactory.java         |    8 +-
 .../ConfigVariationsFactory.java                |    6 +-
 .../testframework/junits/GridAbstractTest.java  |  281 +-
 .../junits/GridTestKernalContext.java           |    1 +
 ...IgniteCacheConfigVariationsAbstractTest.java |   12 +-
 .../IgniteConfigVariationsAbstractTest.java     |   12 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |   11 +
 .../junits/common/GridAbstractExamplesTest.java |    2 +-
 .../junits/common/GridCommonAbstractTest.java   |  122 +-
 .../common/GridRollingRestartAbstractTest.java  |    6 +-
 .../multijvm/IgniteCacheProcessProxy.java       |  172 ++
 .../multijvm/IgniteClusterProcessProxy.java     |   13 +
 .../multijvm/IgniteEventsProcessProxy.java      |   31 +
 .../junits/multijvm/IgniteNodeRunner.java       |   55 +-
 .../junits/multijvm/IgniteProcessProxy.java     |  112 +-
 .../junits/spi/GridSpiAbstractConfigTest.java   |    2 +-
 .../junits/spi/GridSpiAbstractTest.java         |   13 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    4 +-
 .../testsuites/IgniteBinaryBasicTestSuite.java  |    5 +
 .../IgniteBinaryObjectsTestSuite.java           |    6 +
 .../IgniteCacheDataStructuresSelfTestSuite.java |    2 -
 .../IgniteCacheFullApiSelfTestSuite.java        |    8 +-
 .../IgniteCacheRestartTestSuite2.java           |    3 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    4 +
 .../testsuites/IgniteCacheTestSuite2.java       |    7 +
 .../testsuites/IgniteCacheTestSuite5.java       |    6 +
 .../IgniteCacheTxRecoverySelfTestSuite.java     |    3 +
 .../IgniteClientReconnectTestSuite.java         |    2 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    6 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    9 +-
 ...essagingConfigVariationFullApiTestSuite.java |    4 +-
 .../IgniteSpiCommunicationSelfTestSuite.java    |    5 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    7 +-
 .../IgniteTopologyValidatorTestSuit.java        |    1 +
 .../ignite/thread/IgniteThreadPoolSizeTest.java |    8 -
 .../util/AttributeNodeFilterSelfTest.java       |    4 +-
 .../ignite/util/GridMessageCollectionTest.java  |    5 +-
 .../apache/ignite/util/GridRandomSelfTest.java  |   17 -
 .../util/GridTopologyHeapSizeSelfTest.java      |    4 +-
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   10 +-
 .../org.apache.ignite.plugin.PluginProvider     |    1 +
 modules/docker/1.9.0/Dockerfile                 |   46 +
 modules/docker/1.9.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |    4 +-
 .../CacheNoValueClassOnServerTestClient.java    |    3 +-
 .../CacheConfigurationP2PTestClient.java        |    3 +-
 modules/flink/pom.xml                           |    2 +-
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java  |   37 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |   56 +-
 .../h2/GridBinaryH2IndexingGeoSelfTest.java     |    4 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |  409 ++-
 .../h2/GridH2IndexingSegmentedGeoSelfTest.java  |   37 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |    2 +
 modules/hadoop/pom.xml                          |    7 +
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |   10 +-
 .../io/BytesWritablePartiallyRawComparator.java |   51 +
 .../hadoop/io/TextPartiallyRawComparator.java   |   68 +-
 .../IgniteHadoopWeightedMapReducePlanner.java   |   26 +-
 .../hadoop/igfs/HadoopIgfsEndpoint.java         |    4 +-
 .../processors/hadoop/impl/HadoopUtils.java     |   66 +
 .../HadoopBasicFileSystemFactoryDelegate.java   |    2 +-
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |  230 +-
 .../hadoop/impl/igfs/HadoopIgfsUtils.java       |    6 +
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java     |   99 +-
 .../hadoop/impl/v1/HadoopV1MapTask.java         |   89 +-
 .../hadoop/impl/v1/HadoopV1ReduceTask.java      |   69 +-
 .../hadoop/impl/v2/HadoopV2Context.java         |   19 +-
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |   10 +-
 .../hadoop/impl/v2/HadoopV2MapTask.java         |   18 +-
 .../hadoop/impl/v2/HadoopV2ReduceTask.java      |   14 +
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |   19 +-
 .../hadoop/shuffle/HadoopShuffle.java           |    7 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |   14 +-
 .../shuffle/direct/HadoopDirectDataInput.java   |    2 +-
 .../HadoopEmbeddedTaskExecutor.java             |    2 +-
 .../taskexecutor/HadoopExecutorService.java     |   16 +-
 .../hadoop/taskexecutor/HadoopRunnableTask.java |   12 +-
 .../external/HadoopExternalTaskExecutor.java    |    2 +-
 .../child/HadoopChildProcessRunner.java         |   10 +-
 .../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       |   14 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |   28 +-
 .../hadoop/impl/HadoopErrorSimulator.java       |   12 +-
 .../hadoop/impl/HadoopGroupingTest.java         |    4 +-
 .../hadoop/impl/HadoopJobTrackerSelfTest.java   |    4 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |   10 +-
 .../impl/HadoopNoHadoopMapReduceTest.java       |    4 +-
 .../hadoop/impl/HadoopSortingExternalTest.java  |    8 +-
 .../hadoop/impl/HadoopSortingTest.java          |    4 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |    6 +-
 .../hadoop/impl/HadoopTeraSortTest.java         |    4 +-
 .../hadoop/impl/HadoopValidationSelfTest.java   |    4 +-
 .../HadoopClientProtocolEmbeddedSelfTest.java   |    4 +-
 ...opClientProtocolMultipleServersSelfTest.java |    6 +-
 .../client/HadoopClientProtocolSelfTest.java    |    2 +-
 .../impl/igfs/Hadoop1DualAbstractTest.java      |    6 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   10 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |   77 +-
 ...Igfs20FileSystemLoopbackPrimarySelfTest.java |    4 +-
 ...oopIgfs20FileSystemShmemPrimarySelfTest.java |    4 +-
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |   14 +-
 ...oopSecondaryFileSystemConfigurationTest.java |   91 +-
 .../hadoop/impl/igfs/IgfsEventsTestSuite.java   |    2 +-
 .../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   |   66 +-
 ...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 +-
 .../cache/query/GridCacheTwoStepQuery.java      |   35 +-
 .../query/h2/DmlStatementsProcessor.java        |  368 ++-
 .../query/h2/GridH2ResultSetIterator.java       |    3 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  603 +++-
 .../query/h2/dml/UpdatePlanBuilder.java         |  111 +-
 .../query/h2/opt/DistributedJoinMode.java       |   51 +
 .../query/h2/opt/GridH2CollocationModel.java    |   82 +-
 .../query/h2/opt/GridH2IndexBase.java           |  356 ++-
 .../query/h2/opt/GridH2QueryContext.java        |   84 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |    5 -
 .../query/h2/opt/GridH2ScanIndex.java           |  273 ++
 .../processors/query/h2/opt/GridH2Table.java    |  277 +-
 .../query/h2/opt/GridH2TreeIndex.java           |  160 +-
 .../query/h2/opt/GridLuceneIndex.java           |    4 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |   56 +-
 .../processors/query/h2/sql/GridSqlAlias.java   |   13 +-
 .../processors/query/h2/sql/GridSqlArray.java   |    8 +-
 .../processors/query/h2/sql/GridSqlAst.java     |   61 +
 .../processors/query/h2/sql/GridSqlColumn.java  |   85 +-
 .../processors/query/h2/sql/GridSqlConst.java   |    6 +-
 .../processors/query/h2/sql/GridSqlElement.java |   43 +-
 .../query/h2/sql/GridSqlFunction.java           |   18 +-
 .../processors/query/h2/sql/GridSqlJoin.java    |   35 +-
 .../processors/query/h2/sql/GridSqlKeyword.java |    3 +-
 .../query/h2/sql/GridSqlOperation.java          |    6 +-
 .../query/h2/sql/GridSqlOperationType.java      |   25 +-
 .../query/h2/sql/GridSqlParameter.java          |    4 +-
 .../query/h2/sql/GridSqlPlaceholder.java        |    2 +-
 .../processors/query/h2/sql/GridSqlQuery.java   |   91 +-
 .../query/h2/sql/GridSqlQueryParser.java        |  267 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      | 1686 +++++++++--
 .../processors/query/h2/sql/GridSqlSelect.java  |  121 +-
 .../query/h2/sql/GridSqlSortColumn.java         |   41 +
 .../query/h2/sql/GridSqlStatement.java          |   11 +-
 .../query/h2/sql/GridSqlSubquery.java           |   31 +-
 .../processors/query/h2/sql/GridSqlTable.java   |   19 +-
 .../processors/query/h2/sql/GridSqlType.java    |    6 +-
 .../processors/query/h2/sql/GridSqlUnion.java   |   66 +-
 .../processors/query/h2/sql/GridSqlValue.java   |   25 -
 .../query/h2/twostep/GridMapQueryExecutor.java  |  346 ++-
 .../query/h2/twostep/GridMergeIndex.java        |  647 +++-
 .../query/h2/twostep/GridMergeIndexSorted.java  |  380 +++
 .../h2/twostep/GridMergeIndexUnsorted.java      |  101 +-
 .../query/h2/twostep/GridMergeTable.java        |   70 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  332 ++-
 .../query/h2/twostep/GridResultPage.java        |   34 +-
 .../query/h2/twostep/msg/GridH2Array.java       |    2 +-
 .../query/h2/twostep/msg/GridH2Boolean.java     |    2 +-
 .../query/h2/twostep/msg/GridH2Byte.java        |    2 +-
 .../query/h2/twostep/msg/GridH2Bytes.java       |    2 +-
 .../query/h2/twostep/msg/GridH2CacheObject.java |    2 +-
 .../query/h2/twostep/msg/GridH2Date.java        |    2 +-
 .../query/h2/twostep/msg/GridH2Decimal.java     |    2 +-
 .../query/h2/twostep/msg/GridH2Double.java      |    2 +-
 .../query/h2/twostep/msg/GridH2Float.java       |    2 +-
 .../query/h2/twostep/msg/GridH2Geometry.java    |    4 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |   62 +-
 .../twostep/msg/GridH2IndexRangeResponse.java   |   64 +-
 .../query/h2/twostep/msg/GridH2Integer.java     |    2 +-
 .../query/h2/twostep/msg/GridH2JavaObject.java  |    2 +-
 .../query/h2/twostep/msg/GridH2Long.java        |    2 +-
 .../query/h2/twostep/msg/GridH2Null.java        |    2 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   21 +-
 .../query/h2/twostep/msg/GridH2RowMessage.java  |    2 +-
 .../query/h2/twostep/msg/GridH2RowRange.java    |    2 +-
 .../h2/twostep/msg/GridH2RowRangeBounds.java    |    2 +-
 .../query/h2/twostep/msg/GridH2Short.java       |    2 +-
 .../query/h2/twostep/msg/GridH2String.java      |    2 +-
 .../query/h2/twostep/msg/GridH2Time.java        |    2 +-
 .../query/h2/twostep/msg/GridH2Timestamp.java   |    2 +-
 .../query/h2/twostep/msg/GridH2Uuid.java        |    2 +-
 .../twostep/msg/GridH2ValueMessageFactory.java  |    2 +-
 .../cache/BinarySerializationQuerySelfTest.java |   32 +-
 ...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 |    8 +-
 ...CacheScanPartitionQueryFallbackSelfTest.java |    8 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   |  214 +-
 .../ClientReconnectAfterClusterRestartTest.java |   10 +-
 ...ryDuplicateIndexObjectsAbstractSelfTest.java |  159 +
 .../cache/GridCacheCrossCacheQuerySelfTest.java |    6 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    4 +-
 .../cache/GridCacheOffHeapSelfTest.java         |    4 +-
 .../GridCacheOffheapIndexEntryEvictTest.java    |    4 +-
 .../cache/GridCacheOffheapIndexGetSelfTest.java |    4 +-
 .../GridCacheQueryIndexDisabledSelfTest.java    |   24 +-
 .../GridCacheQuerySerializationSelfTest.java    |    4 +-
 .../cache/GridCacheQuerySimpleBenchmark.java    |    4 +-
 .../processors/cache/GridCacheSwapSelfTest.java |    4 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java |    4 +-
 .../IgniteBinaryObjectFieldsQuerySelfTest.java  |    6 +-
 .../IgniteBinaryObjectQueryArgumentsTest.java   |    4 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |   27 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |   14 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |  410 ++-
 .../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      |   40 +-
 ...PartitionedAndReplicatedCollocationTest.java |    4 +-
 ...teCacheJoinPartitionedAndReplicatedTest.java |    4 +-
 ...IgniteCacheJoinQueryWithAffinityKeyTest.java |    4 +-
 .../cache/IgniteCacheLargeResultSelfTest.java   |    4 +-
 ...eLockPartitionOnAffinityRunAbstractTest.java |    5 +-
 ...PartitionOnAffinityRunAtomicCacheOpTest.java |   15 +-
 ...niteCacheLockPartitionOnAffinityRunTest.java |   57 +-
 ...titionOnAffinityRunWithCollisionSpiTest.java |   16 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |   25 +-
 .../cache/IgniteCacheNoClassQuerySelfTest.java  |    4 +-
 .../IgniteCacheObjectKeyIndexingSelfTest.java   |  124 +
 .../cache/IgniteCacheOffheapEvictQueryTest.java |    8 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java  |    4 +-
 ...CacheOffheapTieredMultithreadedSelfTest.java |    4 +-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |    8 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |    4 +-
 ...IgniteCachePrimitiveFieldsQuerySelfTest.java |    4 +-
 .../cache/IgniteCacheQueriesLoadTest1.java      |    4 +-
 .../IgniteCacheQueryH2IndexingLeakTest.java     |    4 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java     |   28 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |    4 +-
 ...gniteCacheSqlQueryMultiThreadedSelfTest.java |    4 +-
 .../IgniteCacheStarvationOnRebalanceTest.java   |    4 +-
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |   64 +-
 ...ClientReconnectCacheQueriesFailoverTest.java |    4 +-
 .../cache/IgniteClientReconnectQueriesTest.java |    4 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |    4 +-
 .../cache/IncorrectQueryEntityTest.java         |   78 +
 .../cache/QueryEntityCaseMismatchTest.java      |  107 +
 .../cache/SqlFieldsQuerySelfTest.java           |    4 +-
 ...ateIndexObjectPartitionedAtomicSelfTest.java |   38 +
 ...xObjectPartitionedTransactionalSelfTest.java |   41 +
 ...lientQueryReplicatedNodeRestartSelfTest.java |   10 +-
 ...niteCacheDistributedQueryCancelSelfTest.java |   10 +-
 ...butedQueryStopOnCancelOrTimeoutSelfTest.java |    6 +-
 ...artitionedFieldsQueryP2PEnabledSelfTest.java |    4 +-
 ...achePartitionedQueryP2PDisabledSelfTest.java |    4 +-
 .../IgniteCachePartitionedQuerySelfTest.java    |   85 +
 ...cheQueryAbstractDistributedJoinSelfTest.java |    6 +-
 .../near/IgniteCacheQueryNodeFailTest.java      |    4 +-
 .../IgniteCacheQueryNodeRestartSelfTest.java    |    4 +-
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |    8 +-
 ...ReplicatedFieldsQueryP2PEnabledSelfTest.java |    4 +-
 ...CacheReplicatedQueryP2PDisabledSelfTest.java |    4 +-
 ...eCacheLocalQueryCancelOrTimeoutSelfTest.java |    4 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java     |    4 +-
 .../query/IgniteQueryDedicatedPoolTest.java     |  223 ++
 .../IgniteSqlEntryCacheModeAgnosticTest.java    |  140 +
 .../query/IgniteSqlSchemaIndexingTest.java      |   15 +-
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  289 ++
 .../query/IgniteSqlSplitterSelfTest.java        |  421 ++-
 .../query/h2/GridH2IndexRebuildTest.java        |  261 --
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   87 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |   54 -
 .../h2/sql/AbstractH2CompareQueryTest.java      |   25 +-
 .../query/h2/sql/GridQueryParsingTest.java      |  105 +-
 .../query/h2/sql/H2CompareBigQueryTest.java     |   58 +-
 .../FetchingQueryCursorStressTest.java          |  277 ++
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    4 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |    4 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   16 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |    2 +
 .../IgniteCacheQuerySelfTestSuite3.java         |    4 +
 .../processors/query/h2/sql/bigQuery.sql        |   36 +-
 .../apache/ignite/stream/jms11/JmsStreamer.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 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |    6 +-
 .../ignite/stream/kafka/TestKafkaBroker.java    |    2 +-
 .../connect/IgniteSourceConnectorTest.java      |    2 +-
 modules/kubernetes/DEVNOTES.txt                 |   63 +
 modules/kubernetes/README.txt                   |   33 +
 modules/kubernetes/config/Dockerfile            |   62 +
 modules/kubernetes/config/example-kube.xml      |   44 +
 .../kubernetes/config/ignite-deployment.yaml    |   41 +
 modules/kubernetes/config/ignite-service.yaml   |   29 +
 modules/kubernetes/config/run.sh                |   50 +
 modules/kubernetes/licenses/apache-2.0.txt      |  202 ++
 modules/kubernetes/pom.xml                      |   93 +
 .../TcpDiscoveryKubernetesIpFinder.java         |  317 ++
 .../tcp/ipfinder/kubernetes/package-info.java   |   22 +
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java |   93 +
 .../tcp/ipfinder/kubernetes/package-info.java   |   22 +
 .../testsuites/IgniteKubernetesTestSuite.java   |   41 +
 .../log4j/GridLog4jCorrectFileNameTest.java     |    6 +-
 .../log4j2/GridLog4j2CorrectFileNameTest.java   |    6 +-
 .../log4j2/GridLog4j2InitializedTest.java       |    2 +-
 .../logger/log4j2/Log4j2LoggerSelfTest.java     |    6 +-
 .../log4j2/Log4j2LoggerVerboseModeSelfTest.java |    6 +-
 .../stream/mqtt/IgniteMqttStreamerTest.java     |    4 +-
 .../IgniteAbstractOsgiContextActivator.java     |    2 +-
 .../BundleDelegatingClassLoader.java            |    4 +-
 .../classloaders/ContainerSweepClassLoader.java |    4 +-
 .../activators/BasicIgniteTestActivator.java    |    2 +-
 modules/platforms/cpp/binary/Makefile.am        |    5 +-
 .../platforms/cpp/binary/include/Makefile.am    |    7 +
 .../cpp/binary/include/ignite/binary/binary.h   |   15 +-
 .../binary/binary_array_identity_resolver.h     |   64 +
 .../include/ignite/binary/binary_containers.h   |    2 +-
 .../ignite/binary/binary_identity_resolver.h    |   61 +
 .../include/ignite/binary/binary_object.h       |  151 +
 .../include/ignite/binary/binary_raw_reader.h   |   19 +
 .../include/ignite/binary/binary_raw_writer.h   |   19 +-
 .../include/ignite/binary/binary_reader.h       |   21 +
 .../binary/include/ignite/binary/binary_type.h  |   24 +-
 .../include/ignite/binary/binary_writer.h       |   21 +-
 .../include/ignite/impl/binary/binary_common.h  |   12 +
 .../ignite/impl/binary/binary_field_meta.h      |  110 +
 .../ignite/impl/binary/binary_id_resolver.h     |   96 +-
 .../ignite/impl/binary/binary_object_header.h   |  270 ++
 .../ignite/impl/binary/binary_object_impl.h     |  252 ++
 .../ignite/impl/binary/binary_reader_impl.h     |  165 +-
 .../include/ignite/impl/binary/binary_schema.h  |   12 +-
 .../ignite/impl/binary/binary_type_handler.h    |   47 +-
 .../ignite/impl/binary/binary_type_impl.h       |  149 +
 .../ignite/impl/binary/binary_type_manager.h    |   48 +-
 .../ignite/impl/binary/binary_type_snapshot.h   |   98 +-
 .../ignite/impl/binary/binary_type_updater.h    |   19 +-
 .../include/ignite/impl/binary/binary_utils.h   |  264 +-
 .../ignite/impl/binary/binary_writer_impl.h     |   72 +-
 .../ignite/impl/interop/interop_output_stream.h |   10 +-
 .../cpp/binary/project/vs/binary.vcxproj        |   12 +-
 .../binary/project/vs/binary.vcxproj.filters    |   36 +-
 .../binary/binary_array_identity_resolver.cpp   |   42 +
 .../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_type.cpp       |    4 +-
 .../cpp/binary/src/binary/binary_writer.cpp     |   10 +
 .../src/impl/binary/binary_field_meta.cpp       |   42 +
 .../src/impl/binary/binary_object_header.cpp    |   63 +
 .../src/impl/binary/binary_object_impl.cpp      |  224 ++
 .../src/impl/binary/binary_reader_impl.cpp      |  177 +-
 .../src/impl/binary/binary_type_handler.cpp     |   45 +-
 .../src/impl/binary/binary_type_manager.cpp     |  191 +-
 .../src/impl/binary/binary_type_snapshot.cpp    |   50 +-
 .../src/impl/binary/binary_type_updater.cpp     |   32 -
 .../cpp/binary/src/impl/binary/binary_utils.cpp |  173 +-
 .../src/impl/binary/binary_writer_impl.cpp      |  109 +-
 .../src/impl/interop/interop_output_stream.cpp  |    5 +
 modules/platforms/cpp/common/Makefile.am        |    9 +-
 .../platforms/cpp/common/include/Makefile.am    |    2 +
 .../common/include/ignite/common/concurrent.h   |   59 +-
 .../include/ignite/common/platform_utils.h      |   79 +
 .../cpp/common/include/ignite/common/utils.h    |  323 +-
 .../cpp/common/include/ignite/ignite_error.h    |    2 +-
 .../cpp/common/include/ignite/reference.h       |   14 +-
 .../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      |   75 +
 .../cpp/common/os/linux/src/common/utils.cpp    |  136 -
 .../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 |   80 +
 .../cpp/common/os/win/src/common/utils.cpp      |  142 -
 .../cpp/common/project/vs/common.vcxproj        |    9 +-
 .../common/project/vs/common.vcxproj.filters    |   30 +-
 .../platforms/cpp/common/project/vs/targetver.h |   25 -
 .../platforms/cpp/common/src/common/utils.cpp   |  184 ++
 .../platforms/cpp/common/src/ignite_error.cpp   |   68 +-
 modules/platforms/cpp/common/src/time.cpp       |   83 +
 modules/platforms/cpp/core-test/Makefile.am     |   12 +-
 .../cpp/core-test/config/cache-identity.xml     |  154 +
 .../cpp/core-test/config/cache-query.xml        |   66 +-
 .../cpp/core-test/config/cache-store.xml        |   71 +
 .../cpp/core-test/config/cache-test.xml         |    2 +-
 .../core-test/include/ignite/binary_test_defs.h |  136 +-
 .../include/ignite/binary_test_utils.h          |   53 +
 .../cpp/core-test/include/ignite/complex_type.h |  135 +
 .../cpp/core-test/include/ignite/test_type.h    |  189 ++
 .../cpp/core-test/include/ignite/test_utils.h   |   74 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |   15 +
 .../project/vs/core-test.vcxproj.filters        |   50 +-
 .../src/binary_identity_resolver_test.cpp       |  607 ++++
 .../cpp/core-test/src/binary_object_test.cpp    |  390 +++
 .../src/binary_reader_writer_raw_test.cpp       |  743 +----
 .../core-test/src/binary_reader_writer_test.cpp |  919 +-----
 .../cpp/core-test/src/binary_session_test.cpp   |   24 +-
 .../cpp/core-test/src/cache_invoke_test.cpp     |  527 ++++
 .../cpp/core-test/src/cache_query_test.cpp      |  437 +--
 .../cpp/core-test/src/cache_store_test.cpp      |  151 +
 .../platforms/cpp/core-test/src/cache_test.cpp  |  289 +-
 .../cpp/core-test/src/cluster_test.cpp          |   82 +
 .../cpp/core-test/src/continuous_query_test.cpp |  233 +-
 .../cpp/core-test/src/date_time_test.cpp        |  287 ++
 .../cpp/core-test/src/handle_registry_test.cpp  |    2 +-
 .../cpp/core-test/src/ignite_error_test.cpp     |    2 +-
 .../cpp/core-test/src/ignition_test.cpp         |   33 +-
 .../cpp/core-test/src/interop_memory_test.cpp   |    5 +-
 .../cpp/core-test/src/interop_test.cpp          |   42 +-
 .../cpp/core-test/src/reference_test.cpp        |   14 +-
 .../platforms/cpp/core-test/src/test_utils.cpp  |   86 +
 .../cpp/core-test/src/transactions_test.cpp     |   25 +-
 modules/platforms/cpp/core/Makefile.am          |    2 +
 modules/platforms/cpp/core/include/Makefile.am  |   64 +-
 .../cpp/core/include/ignite/cache/cache.h       |  454 ++-
 .../cpp/core/include/ignite/cache/cache_entry.h |   15 +
 .../ignite/cache/cache_entry_processor.h        |   81 +
 .../cache/event/cache_entry_event_filter.h      |  109 +
 .../include/ignite/cache/mutable_cache_entry.h  |  176 ++
 .../cache/query/continuous/continuous_query.h   |   37 +-
 .../include/ignite/cache/query/query_argument.h |  134 -
 .../include/ignite/cache/query/query_cursor.h   |   30 +-
 .../core/include/ignite/cache/query/query_sql.h |   16 +-
 .../ignite/cache/query/query_sql_fields.h       |   16 +-
 .../platforms/cpp/core/include/ignite/ignite.h  |   36 +-
 .../cpp/core/include/ignite/ignite_binding.h    |  146 +
 .../include/ignite/ignite_binding_context.h     |   88 +
 .../core/include/ignite/ignite_configuration.h  |    2 -
 .../cpp/core/include/ignite/ignition.h          |   14 +-
 .../impl/binary/binary_type_updater_impl.h      |    6 +-
 .../cpp/core/include/ignite/impl/bindings.h     |   95 +
 .../impl/cache/cache_entry_processor_holder.h   |  267 ++
 .../core/include/ignite/impl/cache/cache_impl.h |  167 +-
 .../cache/event/cache_entry_event_filter_base.h |   66 +
 .../event/cache_entry_event_filter_holder.h     |  185 ++
 .../continuous/continuous_query_handle_impl.h   |   10 -
 .../query/continuous/continuous_query_impl.h    |   60 +-
 .../ignite/impl/cache/query/query_argument.h    |  137 +
 .../ignite/impl/cache/query/query_impl.h        |    7 +
 .../ignite/impl/cluster/cluster_group_impl.h    |   77 +
 .../cpp/core/include/ignite/impl/helpers.h      |   57 +
 .../include/ignite/impl/ignite_binding_impl.h   |  130 +
 .../include/ignite/impl/ignite_environment.h    |   76 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |   67 +-
 .../ignite/impl/interop/interop_target.h        |   64 +-
 .../core/include/ignite/impl/module_manager.h   |  131 +
 .../cpp/core/include/ignite/impl/operations.h   |  198 +-
 .../platforms/cpp/core/project/vs/core.vcxproj  |   17 +-
 .../cpp/core/project/vs/core.vcxproj.filters    |   57 +-
 modules/platforms/cpp/core/src/ignite.cpp       |   12 +-
 modules/platforms/cpp/core/src/ignition.cpp     |  373 +--
 .../impl/binary/binary_type_updater_impl.cpp    |  101 +-
 .../cpp/core/src/impl/cache/cache_impl.cpp      |  204 +-
 .../continuous/continuous_query_handle_impl.cpp |    7 +-
 .../core/src/impl/cache/query/query_impl.cpp    |   47 +-
 .../src/impl/cluster/cluster_group_impl.cpp     |   64 +
 .../cpp/core/src/impl/ignite_binding_impl.cpp   |   88 +
 .../cpp/core/src/impl/ignite_environment.cpp    |  192 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |   36 +-
 .../core/src/impl/interop/interop_target.cpp    |   83 +-
 .../src/impl/transactions/transactions_impl.cpp |   14 +-
 .../cpp/jni/include/ignite/jni/exports.h        |    4 +-
 .../platforms/cpp/jni/include/ignite/jni/java.h |   10 +-
 .../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 +-
 .../platforms/cpp/jni/project/vs/jni.vcxproj    |    1 -
 .../cpp/jni/project/vs/jni.vcxproj.filters      |    3 -
 modules/platforms/cpp/jni/project/vs/module.def |    4 +-
 .../platforms/cpp/jni/project/vs/targetver.h    |   25 -
 modules/platforms/cpp/jni/src/exports.cpp       |   12 +-
 modules/platforms/cpp/jni/src/java.cpp          |   86 +-
 modules/platforms/cpp/odbc-test/Makefile.am     |    1 +
 .../cpp/odbc-test/config/queries-default.xml    |    2 +-
 .../odbc-test/include/sql_test_suite_fixture.h  |   16 +
 .../platforms/cpp/odbc-test/include/test_type.h |   33 +-
 .../cpp/odbc-test/include/test_utils.h          |   51 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    2 +
 .../project/vs/odbc-test.vcxproj.filters        |    6 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |   38 +-
 .../src/application_data_buffer_test.cpp        |  244 +-
 .../platforms/cpp/odbc-test/src/cursor_test.cpp |    6 +-
 .../cpp/odbc-test/src/queries_test.cpp          |  142 +-
 .../src/sql_aggregate_functions_test.cpp        |    5 +-
 .../src/sql_date_time_functions_test.cpp        |   31 +-
 .../src/sql_esc_convert_function_test.cpp       |  158 +
 .../src/sql_numeric_functions_test.cpp          |    1 +
 .../cpp/odbc-test/src/sql_outer_join_test.cpp   |    1 +
 .../odbc-test/src/sql_string_functions_test.cpp |    1 +
 .../odbc-test/src/sql_test_suite_fixture.cpp    |   97 +-
 .../cpp/odbc-test/src/sql_types_test.cpp        |  123 +-
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |   67 +-
 .../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          |   14 +-
 .../platforms/cpp/odbc/install/install_x86.cmd  |    8 +-
 .../odbc/src/app/application_data_buffer.cpp    |  250 +-
 .../platforms/cpp/odbc/src/app/parameter.cpp    |   11 +-
 modules/platforms/cpp/odbc/src/column.cpp       |   19 +
 .../cpp/odbc/src/config/connection_info.cpp     |  260 +-
 modules/platforms/cpp/odbc/src/type_traits.cpp  |   13 +-
 modules/platforms/cpp/odbc/src/utility.cpp      |   17 +-
 .../Apache.Ignite.AspNet.Tests/App.config       |    6 +-
 .../ExpiryCacheHolderTest.cs                    |   12 +-
 .../IgniteOutputCacheProviderTest.cs            |    2 +-
 .../IgniteSessionStateStoreProviderTest.cs      |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.AspNet.nuspec                 |    2 +-
 .../Apache.Ignite.AspNet/Impl/ConfigUtil.cs     |    4 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../SchemaTest.cs                               |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Tests.csproj             |   25 +-
 .../Binary/BinaryBuilderSelfTest.cs             |  256 +-
 .../BinaryBuilderSelfTestDynamicRegistration.cs |   40 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |    2 +-
 .../Binary/BinaryDynamicRegistrationTest.cs     |  483 +++
 .../Binary/BinaryEqualityComparerTest.cs        |  282 ++
 .../Binary/BinaryReaderWriterTest.cs            |    8 +
 .../Binary/BinarySelfTest.cs                    |  205 +-
 .../Binary/BinarySelfTestFullFooter.cs          |    5 +-
 .../Binary/BinaryStructureTest.cs               |  122 +
 .../Binary/IO/BinaryStreamsTest.cs              |   19 +
 .../Binary/JavaBinaryInteropTest.cs             |  182 ++
 .../Serializable/AdvancedSerializationTest.cs   |  228 ++
 .../BasicSerializableObjectsTest.cs             |  124 +
 .../Binary/Serializable/CallbacksTest.cs        |  369 +++
 .../Binary/Serializable/DelegatesTest.cs        |  161 +
 .../Binary/Serializable/ObjectReferenceTests.cs |  131 +
 .../Binary/Serializable/PrimitivesTest.cs       |  754 +++++
 .../Binary/Serializable/SqlDmlTest.cs           |  277 ++
 .../BinaryConfigurationTest.cs                  |   43 +
 .../Cache/Affinity/AffinityFieldTest.cs         |    2 +-
 .../Cache/Affinity/AffinityFunctionTest.cs      |   25 +-
 .../Cache/Affinity/AffinityTest.cs              |    2 +-
 .../Cache/CacheAbstractTest.cs                  |   97 +-
 .../Cache/CacheAbstractTransactionalTest.cs     |  339 +++
 .../Cache/CacheConfigurationTest.cs             |   22 +-
 .../Cache/CacheDynamicStartTest.cs              |    2 +-
 .../Cache/CacheMetricsTest.cs                   |    2 +-
 .../Cache/CacheNearTest.cs                      |    4 +-
 .../Cache/CacheTestAsyncWrapper.cs              |   12 +-
 .../Cache/Query/CacheDmlQueriesTest.cs          |  293 ++
 .../Cache/Query/CacheLinqTest.cs                |  261 +-
 .../Query/CacheQueriesCodeConfigurationTest.cs  |    7 +
 .../Cache/Query/CacheQueriesTest.cs             |   17 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |   33 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |    2 +-
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |    9 +-
 .../Cache/Store/CacheStoreAdapterTest.cs        |   14 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   26 +-
 .../Cache/Store/CacheStoreTest.cs               |  372 ++-
 .../Cache/Store/CacheTestParallelLoadStore.cs   |   16 +-
 .../Cache/Store/CacheTestStore.cs               |   27 +-
 .../Cache/Store/NamedNodeCacheStoreTest.cs      |   34 +
 .../Compute/AbstractTaskTest.cs                 |   28 +-
 .../Compute/ComputeApiTest.cs                   |  115 +-
 .../Compute/IgniteExceptionTaskSelfTest.cs      |   40 +-
 .../Compute/MixedClusterTest.cs                 |   33 +-
 .../Compute/ResourceTaskTest.cs                 |   13 +-
 .../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/cache-query-continuous.xml           |  118 +-
 .../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/DeploymentTest.cs  |   26 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |    1 -
 .../Examples/ExamplesTest.cs                    |   24 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   68 +-
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |   33 +-
 .../IgniteConfigurationSectionTest.cs           |    9 +-
 .../IgniteConfigurationSerializerTest.cs        |  136 +-
 .../IgniteConfigurationTest.cs                  |   49 +-
 .../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                        |  348 +++
 .../Plugin/TestIgnitePlugin.cs                  |   39 +
 .../Plugin/TestIgnitePluginConfiguration.cs     |   53 +
 .../Plugin/TestIgnitePluginException.cs         |   64 +
 .../Plugin/TestIgnitePluginProvider.cs          |  153 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |    2 +-
 .../SerializationTest.cs                        |  240 --
 .../Services/ServiceProxyTest.cs                |   40 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   11 +
 .../dotnet/Apache.Ignite.Core.Tests/app.config  |    4 +-
 .../Apache.Ignite.Core.Tests/custom_app.config  |    2 +-
 .../Apache.Ignite.Core.Schema.nuspec            |    2 +-
 .../Apache.Ignite.Core.csproj                   |   42 +-
 .../Apache.Ignite.Core.nuspec                   |    2 +-
 .../Binary/BinaryArrayEqualityComparer.cs       |  160 +
 .../Binary/BinaryConfiguration.cs               |   24 +
 .../Binary/BinaryTypeConfiguration.cs           |   14 +
 .../Binary/IBinaryObjectBuilder.cs              |   10 -
 .../Cache/Affinity/AffinityFunctionBase.cs      |  139 +
 .../Cache/Affinity/Fair/FairAffinityFunction.cs |    1 -
 .../Rendezvous/RendezvousAffinityFunction.cs    |    1 -
 .../Cache/Configuration/CacheConfiguration.cs   |   56 +-
 .../Cache/Configuration/QueryEntity.cs          |   43 +-
 .../Cache/Configuration/QueryField.cs           |    6 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |   32 +-
 .../Cache/ICacheEntryProcessorResult.cs         |   12 +-
 .../Cache/Query/Continuous/ContinuousQuery.cs   |   59 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs |    4 +-
 .../Cache/Query/SqlFieldsQuery.cs               |    6 +-
 .../Store/CacheParallelLoadStoreAdapter.cs      |   38 +-
 .../Cache/Store/CacheStoreAdapter.cs            |   30 +-
 .../Cache/Store/ICacheStore.cs                  |   39 +-
 .../Cache/Store/ICacheStoreSession.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 +-
 .../Datastream/IDataStreamer.cs                 |    2 +-
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |    2 +-
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |   10 +-
 .../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   |  172 +-
 .../IgniteConfigurationSection.xsd              |   75 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   34 +-
 .../Impl/Binary/BinarizableSerializer.cs        |    5 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |   28 +-
 .../Binary/BinaryEqualityComparerSerializer.cs  |   99 +
 .../Impl/Binary/BinaryFieldEqualityComparer.cs  |  138 +
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |   66 +-
 .../Impl/Binary/BinaryObject.cs                 |   59 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |  104 +-
 .../Impl/Binary/BinaryObjectHeader.cs           |   34 +-
 .../Impl/Binary/BinaryObjectSchemaHolder.cs     |   22 +
 .../Impl/Binary/BinaryObjectSchemaSerializer.cs |    2 +
 .../Impl/Binary/BinaryProcessor.cs              |   41 +-
 .../Impl/Binary/BinaryReader.cs                 |  174 +-
 .../Impl/Binary/BinaryReflectiveActions.cs      |    2 +-
 .../BinaryReflectiveSerializerInternal.cs       |   84 +-
 .../Binary/BinarySurrogateTypeDescriptor.cs     |   19 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |  106 +-
 .../Impl/Binary/BinarySystemTypeSerializer.cs   |    2 +-
 .../Impl/Binary/BinaryUtils.cs                  |  119 +-
 .../Impl/Binary/BinaryWriter.cs                 |  239 +-
 .../Impl/Binary/DateTimeHolder.cs               |   68 -
 .../Impl/Binary/DateTimeSerializer.cs           |   48 -
 .../Binary/DeserializationCallbackProcessor.cs  |  102 +
 .../Impl/Binary/IBinaryEqualityComparer.cs      |   63 +
 .../Impl/Binary/IBinarySerializerInternal.cs    |    4 +-
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |   13 +
 .../Impl/Binary/Io/BinaryHeapStream.cs          |   12 +
 .../Impl/Binary/Io/BinaryStreamAdapter.cs       |  119 -
 .../Impl/Binary/Io/BinaryStreamBase.cs          |   13 +
 .../Impl/Binary/Io/IBinaryStream.cs             |   14 +-
 .../Impl/Binary/Io/IBinaryStreamProcessor.cs    |   33 +
 .../Impl/Binary/Marshaller.cs                   |  303 +-
 .../Impl/Binary/Metadata/BinaryField.cs         |   72 +
 .../Impl/Binary/Metadata/BinaryType.cs          |   38 +-
 .../Binary/Metadata/BinaryTypeHashsetHandler.cs |   10 +-
 .../Impl/Binary/Metadata/BinaryTypeHolder.cs    |    9 +-
 .../Impl/Binary/Metadata/IBinaryTypeHandler.cs  |    4 +-
 .../Impl/Binary/ReflectionUtils.cs              |   50 +
 .../Impl/Binary/SerializableObjectHolder.cs     |   80 -
 .../Impl/Binary/SerializableSerializer.cs       |  656 ++++-
 .../Impl/Binary/TypeResolver.cs                 |    7 +
 .../Impl/Binary/UserSerializerProxy.cs          |    5 +-
 .../Impl/Cache/Affinity/AffinityFunctionBase.cs |  140 -
 .../Affinity/AffinityFunctionSerializer.cs      |    3 -
 .../Impl/Cache/CacheEntryProcessorResult.cs     |   27 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  135 +-
 .../Impl/Cache/Store/CacheStore.cs              |  233 +-
 .../Impl/Cache/Store/CacheStoreInternal.cs      |  285 ++
 .../Impl/Cache/Store/ICacheStoreInternal.cs     |   43 +
 .../Impl/Collections/MultiValueDictionary.cs    |    2 +-
 .../Common/CopyOnWriteConcurrentDictionary.cs   |   35 +
 .../Impl/Common/DelegateConverter.cs            |   90 +-
 .../Impl/Common/DelegateTypeDescriptor.cs       |    3 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |    3 +-
 .../Impl/Common/IFutureConverter.cs             |    4 +-
 .../Impl/Common/IFutureInternal.cs              |    3 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |  281 +-
 .../Impl/Common/IgniteHome.cs                   |   21 +-
 .../Impl/Common/LoadedAssembliesResolver.cs     |    2 +-
 .../Impl/Common/SerializableTypeDescriptor.cs   |  222 ++
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |   98 +-
 .../Apache.Ignite.Core/Impl/Handle/Handle.cs    |    2 +-
 .../Impl/Handle/HandleRegistry.cs               |    2 +-
 .../Apache.Ignite.Core/Impl/Handle/IHandle.cs   |    2 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   37 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |    6 +
 .../Impl/Memory/IPlatformMemory.cs              |    5 +-
 .../Impl/Memory/PlatformMemory.cs               |    3 +-
 .../Impl/Memory/PlatformMemoryManager.cs        |    4 +-
 .../Impl/Memory/PlatformMemoryPool.cs           |    3 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |   23 +-
 .../Impl/Memory/PlatformRawMemory.cs            |   96 -
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |  116 +-
 .../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 +
 .../Impl/Services/ServiceProxySerializer.cs     |    4 +-
 .../Transactions/CacheTransactionManager.cs     |  174 ++
 .../Impl/Transactions/Transaction.cs            |    8 +
 .../Impl/Transactions/TransactionImpl.cs        |   13 +
 .../Impl/Transactions/TransactionsImpl.cs       |   10 +
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |    6 +
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |    9 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |  102 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   12 +
 .../Interop/IPlatformTarget.cs                  |  103 +
 .../NuGet/LINQPad/ComputeExample.linq           |    1 -
 .../NuGet/LINQPad/PutGetExample.linq            |    5 +-
 .../NuGet/LINQPad/QueryExample.linq             |    5 +-
 .../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 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../App.config                                  |    4 +-
 .../EntityFrameworkCacheInitializationTest.cs   |    2 +-
 .../EntityFrameworkCacheTest.cs                 |    2 +-
 .../Apache.Ignite.EntityFramework.nuspec        |    2 +-
 .../IgniteDbConfiguration.cs                    |    4 +-
 .../Impl/DbCache.cs                             |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Linq.csproj                   |    1 -
 .../Apache.Ignite.Linq.nuspec                   |    2 +-
 .../dotnet/Apache.Ignite.Linq/CompiledQuery.cs  |  112 +-
 .../dotnet/Apache.Ignite.Linq/CompiledQuery2.cs |  257 --
 .../Impl/CacheFieldsQueryProvider.cs            |   10 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |  141 +-
 .../Impl/CacheQueryModelVisitor.cs              |    3 +
 .../Apache.Ignite.Linq/Impl/CacheQueryParser.cs |   25 +-
 .../Apache.Ignite.Linq/Impl/MethodVisitor.cs    |   72 +-
 .../NuGet/LINQPad/QueryExample.linq             |    5 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../dotnet/Apache.Ignite.Linq/QueryOptions.cs   |    2 +-
 .../Apache.Ignite.Log4Net.nuspec                |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.NLog.nuspec                   |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    2 +-
 .../Apache.Ignite.Examples.csproj               |    2 +
 .../examples/Apache.Ignite.Examples/App.config  |   20 +-
 .../Datagrid/LinqExample.cs                     |    2 +-
 .../Datagrid/MultiTieredCacheExample.cs         |    4 +-
 .../Datagrid/PutGetExample.cs                   |   13 +-
 .../Datagrid/QueryDmlExample.cs                 |  162 ++
 .../Datagrid/StoreExample.cs                    |    1 +
 .../Datagrid/TransactionExample.cs              |   75 +-
 .../Misc/ClientReconnectExample.cs              |   40 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.ExamplesDll/Binary/Address.cs |    2 -
 .../Compute/CharacterCountClosure.cs            |    1 -
 .../Datagrid/ContinuousQueryFilter.cs           |    2 -
 .../Datagrid/EmployeeStore.cs                   |   27 +-
 .../Datagrid/EmployeeStorePredicate.cs          |    2 -
 .../Messaging/RemoteOrderedListener.cs          |    1 -
 .../Messaging/RemoteUnorderedListener.cs        |    1 -
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Services/MapService.cs                      |    1 -
 modules/scalar-2.10/pom.xml                     |    2 +-
 modules/scalar/pom.xml                          |    2 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |   24 +-
 .../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 +-
 modules/schema-import/README.txt                |    4 +-
 modules/spark-2.10/pom.xml                      |   54 +
 modules/spark/pom.xml                           |  183 +-
 .../org/apache/ignite/spark/IgniteContext.scala |   24 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |    6 +
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |   24 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |   31 +-
 .../org/apache/ignite/spark/IgniteRDDSpec.scala |   14 +-
 modules/spring/pom.xml                          |    6 +
 .../org/apache/ignite/IgniteSpringBean.java     |    2 +-
 .../apache/ignite/cache/spring/SpringCache.java |    4 +-
 .../ignite/cache/spring/SpringCacheManager.java |   42 +-
 .../util/spring/IgniteSpringHelperImpl.java     |    8 +-
 .../spring/SpringTransactionManager.java        |   50 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |   10 +-
 .../src/test/config/jdbc-pojo-store-obj.xml     |   10 +-
 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/SpringCacheTest.java    |  177 ++
 .../ignite/cache/spring/spring-caching.xml      |    2 +-
 .../store/jdbc/CachePojoStoreXmlSelfTest.java   |    4 +-
 .../ignite/internal/GridFactorySelfTest.java    |  156 +-
 .../GridSpringBeanSerializationSelfTest.java    |    2 +-
 .../internal/IgniteDynamicCacheConfigTest.java  |    8 +-
 .../GridSpringResourceInjectionSelfTest.java    |    4 +-
 .../GridTransformSpringInjectionSelfTest.java   |    2 +-
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |    6 +-
 .../org/apache/ignite/spring-injection-test.xml |    2 +-
 .../IgniteExcludeInConfigurationTest.java       |   14 +-
 .../spring/injection/spring-resource.tmpl.xml   |    2 +-
 .../org/apache/ignite/spring/sprint-exclude.xml |   21 +-
 .../testsuites/IgniteSpringTestSuite.java       |    3 +
 .../GridSpringTransactionManagerSelfTest.java   |    8 +-
 ...gTransactionManagerContextInjectionTest.java |    2 +-
 ...gniteProjectionStartStopRestartSelfTest.java |    6 +-
 .../ant/beautifier/GridJavadocAntTask.java      |    1 +
 .../ignite/tools/classgen/ClassesGenerator.java |    6 +-
 .../twitter/IgniteTwitterStreamerTest.java      |    4 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |   84 +-
 .../scanners/UriDeploymentScannerManager.java   |   12 +-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |    6 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |    4 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |    3 +-
 .../commands/cache/VisorCacheCommand.scala      |   21 +-
 .../commands/cache/VisorCacheScanCommand.scala  |    2 +-
 .../config/VisorConfigurationCommand.scala      |    2 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    2 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    6 +-
 .../scala/org/apache/ignite/visor/visor.scala   |  125 +-
 .../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 +-
 .../cswap/VisorCacheSwapCommandSpec.scala       |    4 +-
 .../disco/VisorDiscoveryCommandSpec.scala       |    4 +-
 .../events/VisorEventsCommandSpec.scala         |    4 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    4 +-
 .../commands/mem/VisorMemoryCommandSpec.scala   |   33 +
 .../commands/tasks/VisorTasksCommandSpec.scala  |   26 +-
 modules/web-console/backend/app/agent.js        |  106 +-
 modules/web-console/backend/app/browser.js      |   62 +-
 modules/web-console/backend/app/mongo.js        |   49 +-
 modules/web-console/backend/app/routes.js       |    5 +-
 modules/web-console/backend/app/settings.js     |    8 +-
 modules/web-console/backend/index.js            |   10 -
 .../web-console/backend/routes/activities.js    |   45 +
 modules/web-console/backend/routes/admin.js     |    2 +-
 modules/web-console/backend/routes/agent.js     |   10 +-
 modules/web-console/backend/routes/profile.js   |    4 +-
 modules/web-console/backend/routes/public.js    |    1 -
 .../web-console/backend/services/activities.js  |  116 +
 .../web-console/backend/services/sessions.js    |    6 +-
 modules/web-console/backend/services/users.js   |   20 +-
 .../backend/test/unit/ActivitiesService.test.js |  131 +
 modules/web-console/frontend/.eslintrc          |    1 +
 modules/web-console/frontend/.gitignore         |    1 +
 modules/web-console/frontend/app/app.config.js  |   25 +-
 modules/web-console/frontend/app/app.js         |   41 +-
 .../activities-user-dialog.controller.js        |   27 +
 .../activities-user-dialog.tpl.pug              |   36 +
 .../components/activities-user-dialog/index.js  |   35 +
 .../form-field-datepicker.pug                   |   59 +
 .../form-field-datepicker.scss                  |   20 +
 .../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           |   30 +
 .../list-of-registered-users.categories.js      |   30 +
 .../list-of-registered-users.column-defs.js     |   80 +
 .../list-of-registered-users.controller.js      |  335 +++
 .../list-of-registered-users.scss               |   28 +
 .../list-of-registered-users.tpl.pug            |   72 +
 .../ui-grid-header/ui-grid-header.scss          |   91 +
 .../ui-grid-header/ui-grid-header.tpl.pug       |   29 +
 .../ui-grid-settings/ui-grid-settings.pug       |   33 +
 .../ui-grid-settings/ui-grid-settings.scss      |  144 +
 .../app/core/activities/Activities.data.js      |   34 +
 .../frontend/app/core/admin/Admin.data.js       |   77 +
 modules/web-console/frontend/app/core/index.js  |   25 +
 modules/web-console/frontend/app/data/i18n.js   |   39 +
 .../app/directives/centered/centered.css        |   37 -
 .../directives/centered/centered.directive.js   |    2 +-
 .../app/directives/centered/centered.scss       |   37 +
 .../information/information.directive.js        |    4 +-
 .../app/directives/information/information.jade |   20 -
 .../app/directives/information/information.pug  |   20 +
 .../ui-ace-docker/ui-ace-docker.directive.js    |    4 +-
 .../directives/ui-ace-docker/ui-ace-docker.jade |   31 -
 .../directives/ui-ace-docker/ui-ace-docker.pug  |   31 +
 .../ui-ace-java/ui-ace-java.directive.js        |    4 +-
 .../app/directives/ui-ace-java/ui-ace-java.jade |   22 -
 .../app/directives/ui-ace-java/ui-ace-java.pug  |   22 +
 .../ui-ace-pojos/ui-ace-pojos.directive.js      |    4 +-
 .../directives/ui-ace-pojos/ui-ace-pojos.jade   |   40 -
 .../directives/ui-ace-pojos/ui-ace-pojos.pug    |   40 +
 .../ui-ace-pom/ui-ace-pom.controller.js         |    4 +-
 .../ui-ace-pom/ui-ace-pom.directive.js          |    4 +-
 .../app/directives/ui-ace-pom/ui-ace-pom.jade   |   17 -
 .../app/directives/ui-ace-pom/ui-ace-pom.pug    |   17 +
 .../ui-ace-sharp/ui-ace-sharp.directive.js      |    4 +-
 .../directives/ui-ace-sharp/ui-ace-sharp.jade   |   22 -
 .../directives/ui-ace-sharp/ui-ace-sharp.pug    |   22 +
 .../ui-ace-spring/ui-ace-spring.directive.js    |    4 +-
 .../directives/ui-ace-spring/ui-ace-spring.jade |   17 -
 .../directives/ui-ace-spring/ui-ace-spring.pug  |   17 +
 .../ui-grid-settings/ui-grid-settings.jade      |   33 -
 .../ui-grid-settings/ui-grid-settings.scss      |   38 -
 .../app/filters/uiGridSubcategories.filter.js   |   24 +
 .../frontend/app/helpers/jade/form.jade         |   28 -
 .../frontend/app/helpers/jade/form.pug          |   28 +
 .../helpers/jade/form/form-field-checkbox.jade  |   38 -
 .../helpers/jade/form/form-field-checkbox.pug   |   50 +
 .../helpers/jade/form/form-field-datalist.jade  |   51 -
 .../helpers/jade/form/form-field-datalist.pug   |   51 +
 .../app/helpers/jade/form/form-field-down.jade  |   18 -
 .../app/helpers/jade/form/form-field-down.pug   |   18 +
 .../helpers/jade/form/form-field-dropdown.jade  |   51 -
 .../helpers/jade/form/form-field-dropdown.pug   |   50 +
 .../helpers/jade/form/form-field-feedback.jade  |   32 -
 .../helpers/jade/form/form-field-feedback.pug   |   32 +
 .../app/helpers/jade/form/form-field-label.jade |   23 -
 .../app/helpers/jade/form/form-field-label.pug  |   23 +
 .../helpers/jade/form/form-field-number.jade    |   53 -
 .../app/helpers/jade/form/form-field-number.pug |   52 +
 .../helpers/jade/form/form-field-password.jade  |   47 -
 .../helpers/jade/form/form-field-password.pug   |   47 +
 .../app/helpers/jade/form/form-field-text.jade  |   64 -
 .../app/helpers/jade/form/form-field-text.pug   |   63 +
 .../app/helpers/jade/form/form-field-up.jade    |   18 -
 .../app/helpers/jade/form/form-field-up.pug     |   18 +
 .../app/helpers/jade/form/form-group.jade       |   23 -
 .../app/helpers/jade/form/form-group.pug        |   23 +
 .../frontend/app/helpers/jade/mixins.jade       |  609 ----
 .../frontend/app/helpers/jade/mixins.pug        |  610 ++++
 .../frontend/app/modules/Demo/Demo.module.js    |  166 --
 .../frontend/app/modules/agent/agent.module.js  |   29 +-
 .../app/modules/branding/branding.provider.js   |    2 +-
 .../modules/branding/header-logo.directive.js   |    4 +-
 .../app/modules/branding/header-logo.jade       |   18 -
 .../app/modules/branding/header-logo.pug        |   18 +
 .../branding/powered-by-apache.directive.js     |    4 +-
 .../app/modules/branding/powered-by-apache.jade |   18 -
 .../app/modules/branding/powered-by-apache.pug  |   18 +
 .../modules/configuration/Version.service.js    |   35 +-
 .../configuration/configuration.module.js       |    6 +-
 .../generator/ConfigurationGenerator.js         |    9 +-
 .../configuration/generator/Maven.service.js    |   10 +-
 .../frontend/app/modules/demo/Demo.module.js    |  173 ++
 .../app/modules/dialog/dialog.factory.js        |    2 +-
 .../frontend/app/modules/dialog/dialog.jade     |   26 -
 .../frontend/app/modules/dialog/dialog.tpl.pug  |   26 +
 .../getting-started/GettingStarted.provider.js  |    3 +-
 .../frontend/app/modules/loading/loading.css    |   73 -
 .../app/modules/loading/loading.directive.js    |    8 +-
 .../frontend/app/modules/loading/loading.jade   |   23 -
 .../frontend/app/modules/loading/loading.pug    |   23 +
 .../frontend/app/modules/loading/loading.scss   |   73 +
 .../frontend/app/modules/nodes/Nodes.service.js |    4 +-
 .../app/modules/nodes/nodes-dialog.jade         |   35 -
 .../app/modules/nodes/nodes-dialog.tpl.pug      |   35 +
 .../app/modules/sql/notebook.controller.js      |    4 +-
 .../frontend/app/modules/sql/sql.controller.js  |  129 +-
 .../frontend/app/modules/sql/sql.module.js      |   21 +-
 .../frontend/app/modules/states/admin.state.js  |    6 +-
 .../app/modules/states/configuration.state.js   |   23 +-
 .../states/configuration/caches/affinity.jade   |   82 -
 .../states/configuration/caches/affinity.pug    |   82 +
 .../configuration/caches/client-near-cache.jade |   50 -
 .../configuration/caches/client-near-cache.pug  |   50 +
 .../configuration/caches/concurrency.jade       |   65 -
 .../states/configuration/caches/concurrency.pug |   65 +
 .../states/configuration/caches/general.jade    |   69 -
 .../states/configuration/caches/general.pug     |   69 +
 .../states/configuration/caches/memory.jade     |  109 -
 .../states/configuration/caches/memory.pug      |  108 +
 .../configuration/caches/near-cache-client.jade |   51 -
 .../configuration/caches/near-cache-client.pug  |   51 +
 .../configuration/caches/near-cache-server.jade |   52 -
 .../configuration/caches/near-cache-server.pug  |   52 +
 .../configuration/caches/node-filter.jade       |   59 -
 .../states/configuration/caches/node-filter.pug |   59 +
 .../states/configuration/caches/query.jade      |  114 -
 .../states/configuration/caches/query.pug       |  114 +
 .../states/configuration/caches/rebalance.jade  |   66 -
 .../states/configuration/caches/rebalance.pug   |   66 +
 .../states/configuration/caches/statistics.jade |   39 -
 .../states/configuration/caches/statistics.pug  |   39 +
 .../states/configuration/caches/store.jade      |  250 --
 .../states/configuration/caches/store.pug       |  250 ++
 .../states/configuration/clusters/atomic.jade   |   54 -
 .../states/configuration/clusters/atomic.pug    |   54 +
 .../configuration/clusters/attributes.jade      |   57 -
 .../configuration/clusters/attributes.pug       |   57 +
 .../states/configuration/clusters/binary.jade   |   77 -
 .../states/configuration/clusters/binary.pug    |   77 +
 .../configuration/clusters/cache-key-cfg.jade   |   50 -
 .../configuration/clusters/cache-key-cfg.pug    |   50 +
 .../configuration/clusters/checkpoint.jade      |   86 -
 .../configuration/clusters/checkpoint.pug       |   86 +
 .../configuration/clusters/checkpoint/fs.jade   |   66 -
 .../configuration/clusters/checkpoint/fs.pug    |   66 +
 .../configuration/clusters/checkpoint/jdbc.jade |   48 -
 .../configuration/clusters/checkpoint/jdbc.pug  |   48 +
 .../configuration/clusters/checkpoint/s3.jade   |  178 --
 .../configuration/clusters/checkpoint/s3.pug    |  178 ++
 .../configuration/clusters/collision.jade       |   63 -
 .../states/configuration/clusters/collision.pug |   63 +
 .../clusters/collision/custom.jade              |   24 -
 .../configuration/clusters/collision/custom.pug |   24 +
 .../clusters/collision/fifo-queue.jade          |   27 -
 .../clusters/collision/fifo-queue.pug           |   27 +
 .../clusters/collision/job-stealing.jade        |   63 -
 .../clusters/collision/job-stealing.pug         |   63 +
 .../clusters/collision/priority-queue.jade      |   42 -
 .../clusters/collision/priority-queue.pug       |   42 +
 .../configuration/clusters/communication.jade   |  100 -
 .../configuration/clusters/communication.pug    |  100 +
 .../configuration/clusters/connector.jade       |  104 -
 .../states/configuration/clusters/connector.pug |  104 +
 .../configuration/clusters/deployment.jade      |  237 --
 .../configuration/clusters/deployment.pug       |  237 ++
 .../configuration/clusters/discovery.jade       |   88 -
 .../states/configuration/clusters/discovery.pug |   88 +
 .../states/configuration/clusters/events.jade   |   68 -
 .../states/configuration/clusters/events.pug    |   68 +
 .../states/configuration/clusters/failover.jade |   73 -
 .../states/configuration/clusters/failover.pug  |   73 +
 .../states/configuration/clusters/general.jade  |   76 -
 .../states/configuration/clusters/general.pug   |   76 +
 .../clusters/general/discovery/cloud.jade       |  134 -
 .../clusters/general/discovery/cloud.pug        |  134 +
 .../clusters/general/discovery/google.jade      |   38 -
 .../clusters/general/discovery/google.pug       |   38 +
 .../clusters/general/discovery/jdbc.jade        |   31 -
 .../clusters/general/discovery/jdbc.pug         |   31 +
 .../clusters/general/discovery/multicast.jade   |   99 -
 .../clusters/general/discovery/multicast.pug    |   99 +
 .../clusters/general/discovery/s3.jade          |   27 -
 .../clusters/general/discovery/s3.pug           |   27 +
 .../clusters/general/discovery/shared.jade      |   23 -
 .../clusters/general/discovery/shared.pug       |   23 +
 .../clusters/general/discovery/vm.jade          |   79 -
 .../clusters/general/discovery/vm.pug           |   79 +
 .../clusters/general/discovery/zookeeper.jade   |   85 -
 .../clusters/general/discovery/zookeeper.pug    |   85 +
 .../bounded-exponential-backoff.jade            |   27 -
 .../retrypolicy/bounded-exponential-backoff.pug |   27 +
 .../discovery/zookeeper/retrypolicy/custom.jade |   24 -
 .../discovery/zookeeper/retrypolicy/custom.pug  |   24 +
 .../retrypolicy/exponential-backoff.jade        |   27 -
 .../retrypolicy/exponential-backoff.pug         |   27 +
 .../zookeeper/retrypolicy/forever.jade          |   22 -
 .../discovery/zookeeper/retrypolicy/forever.pug |   22 +
 .../zookeeper/retrypolicy/n-times.jade          |   25 -
 .../discovery/zookeeper/retrypolicy/n-times.pug |   25 +
 .../zookeeper/retrypolicy/one-time.jade         |   23 -
 .../zookeeper/retrypolicy/one-time.pug          |   23 +
 .../zookeeper/retrypolicy/until-elapsed.jade    |   25 -
 .../zookeeper/retrypolicy/until-elapsed.pug     |   25 +
 .../states/configuration/clusters/igfs.jade     |   38 -
 .../states/configuration/clusters/igfs.pug      |   38 +
 .../configuration/clusters/load-balancing.jade  |  107 -
 .../configuration/clusters/load-balancing.pug   |  107 +
 .../states/configuration/clusters/logger.jade   |   66 -
 .../states/configuration/clusters/logger.pug    |   66 +
 .../configuration/clusters/logger/custom.jade   |   25 -
 .../configuration/clusters/logger/custom.pug    |   25 +
 .../configuration/clusters/logger/log4j.jade    |   50 -
 .../configuration/clusters/logger/log4j.pug     |   50 +
 .../configuration/clusters/logger/log4j2.jade   |   39 -
 .../configuration/clusters/logger/log4j2.pug    |   39 +
 .../configuration/clusters/marshaller.jade      |   76 -
 .../configuration/clusters/marshaller.pug       |   76 +
 .../states/configuration/clusters/metrics.jade  |   51 -
 .../states/configuration/clusters/metrics.pug   |   51 +
 .../states/configuration/clusters/odbc.jade     |   48 -
 .../states/configuration/clusters/odbc.pug      |   48 +
 .../states/configuration/clusters/ssl.jade      |  110 -
 .../states/configuration/clusters/ssl.pug       |  110 +
 .../states/configuration/clusters/swap.jade     |   72 -
 .../states/configuration/clusters/swap.pug      |   72 +
 .../states/configuration/clusters/thread.jade   |   48 -
 .../states/configuration/clusters/thread.pug    |   48 +
 .../states/configuration/clusters/time.jade     |   47 -
 .../states/configuration/clusters/time.pug      |   47 +
 .../configuration/clusters/transactions.jade    |   69 -
 .../configuration/clusters/transactions.pug     |   69 +
 .../states/configuration/domains/general.jade   |   52 -
 .../states/configuration/domains/general.pug    |   52 +
 .../states/configuration/domains/query.jade     |  172 --
 .../states/configuration/domains/query.pug      |  172 ++
 .../states/configuration/domains/store.jade     |  127 -
 .../states/configuration/domains/store.pug      |  127 +
 .../modules/states/configuration/igfs/dual.jade |   42 -
 .../modules/states/configuration/igfs/dual.pug  |   42 +
 .../states/configuration/igfs/fragmentizer.jade |   43 -
 .../states/configuration/igfs/fragmentizer.pug  |   43 +
 .../states/configuration/igfs/general.jade      |   57 -
 .../states/configuration/igfs/general.pug       |   57 +
 .../modules/states/configuration/igfs/ipc.jade  |   60 -
 .../modules/states/configuration/igfs/ipc.pug   |   60 +
 .../modules/states/configuration/igfs/misc.jade |  108 -
 .../modules/states/configuration/igfs/misc.pug  |  108 +
 .../states/configuration/igfs/secondary.jade    |   45 -
 .../states/configuration/igfs/secondary.pug     |   45 +
 .../configuration/summary/summary.controller.js |   11 +-
 .../configuration/summary/summary.worker.js     |   34 +-
 .../frontend/app/modules/states/errors.state.js |    4 +-
 .../app/modules/states/password.state.js        |    6 +-
 .../app/modules/states/profile.state.js         |    4 +-
 .../frontend/app/modules/states/signin.state.js |    2 +-
 .../app/modules/user/AclRoute.provider.js       |   31 +-
 .../frontend/app/modules/user/Auth.service.js   |    2 +-
 .../frontend/app/modules/user/permissions.js    |    2 +-
 .../frontend/app/modules/user/user.module.js    |    6 +-
 .../frontend/app/primitives/badge/index.scss    |   36 +
 .../frontend/app/primitives/index.js            |   19 +
 .../frontend/app/primitives/tabs/index.scss     |   73 +
 .../frontend/app/primitives/tooltip/index.pug   |   25 +
 .../frontend/app/services/Clone.service.js      |   64 -
 .../frontend/app/services/Confirm.service.js    |    4 +-
 .../app/services/ConfirmBatch.service.js        |    4 +-
 modules/web-console/frontend/app/vendor.js      |    1 +
 .../frontend/controllers/admin-controller.js    |  234 --
 .../frontend/controllers/caches-controller.js   |   14 +-
 .../frontend/controllers/clusters-controller.js |    6 +-
 .../frontend/controllers/domains-controller.js  |   24 +-
 .../frontend/controllers/igfs-controller.js     |   10 +-
 .../frontend/gulpfile.babel.js/paths.js         |   28 +-
 .../frontend/gulpfile.babel.js/tasks/build.js   |    2 +-
 .../frontend/gulpfile.babel.js/tasks/bundle.js  |    8 +-
 .../frontend/gulpfile.babel.js/tasks/jade.js    |   49 -
 .../frontend/gulpfile.babel.js/tasks/watch.js   |    5 +-
 .../gulpfile.babel.js/webpack/common.js         |  292 +-
 .../webpack/environments/development.js         |   90 +-
 .../webpack/environments/production.js          |   41 +-
 .../webpack/environments/test.js                |   52 +-
 .../frontend/gulpfile.babel.js/webpack/index.js |    4 +-
 modules/web-console/frontend/package.json       |  183 +-
 .../stylesheets/_font-awesome-custom.scss       |   28 +
 .../frontend/public/stylesheets/style.scss      |   44 +-
 .../frontend/test/e2e/exampe.test.js            |    4 +-
 .../frontend/test/karma.conf.babel.js           |    7 +-
 .../frontend/test/protractor.conf.js            |   16 +-
 .../frontend/test/unit/JavaTransformer.test.js  |    2 +-
 .../frontend/test/unit/JavaTypes.test.js        |  137 +-
 .../frontend/test/unit/SharpTransformer.test.js |    2 +-
 .../test/unit/SpringTransformer.test.js         |    2 +-
 .../frontend/test/unit/SqlTypes.test.js         |    7 +-
 .../frontend/test/unit/UserAuth.test.js         |    4 +-
 .../frontend/test/unit/Version.test.js          |   27 +-
 .../test/unit/defaultName.filter.test.js        |   27 +-
 modules/web-console/frontend/views/403.jade     |   22 -
 modules/web-console/frontend/views/403.tpl.pug  |   22 +
 modules/web-console/frontend/views/404.jade     |   22 -
 modules/web-console/frontend/views/404.tpl.pug  |   22 +
 modules/web-console/frontend/views/base.jade    |   22 -
 modules/web-console/frontend/views/base.pug     |   22 +
 .../frontend/views/configuration/caches.jade    |   55 -
 .../frontend/views/configuration/caches.tpl.pug |   55 +
 .../frontend/views/configuration/clusters.jade  |   68 -
 .../views/configuration/clusters.tpl.pug        |   68 +
 .../views/configuration/domains-import.jade     |  170 --
 .../views/configuration/domains-import.tpl.pug  |  176 ++
 .../frontend/views/configuration/domains.jade   |   66 -
 .../views/configuration/domains.tpl.pug         |   66 +
 .../frontend/views/configuration/igfs.jade      |   51 -
 .../frontend/views/configuration/igfs.tpl.pug   |   51 +
 .../frontend/views/configuration/sidebar.jade   |   29 -
 .../views/configuration/sidebar.tpl.pug         |   29 +
 .../summary-project-structure.jade              |   27 -
 .../summary-project-structure.tpl.pug           |   28 +
 .../views/configuration/summary-tabs.jade       |   25 -
 .../views/configuration/summary-tabs.pug        |   25 +
 .../frontend/views/configuration/summary.jade   |   90 -
 .../views/configuration/summary.tpl.pug         |   90 +
 .../frontend/views/includes/footer.jade         |   23 -
 .../frontend/views/includes/footer.pug          |   23 +
 .../frontend/views/includes/header.jade         |   52 -
 .../frontend/views/includes/header.pug          |   52 +
 modules/web-console/frontend/views/index.jade   |   47 -
 modules/web-console/frontend/views/index.pug    |   47 +
 modules/web-console/frontend/views/reset.jade   |   48 -
 .../web-console/frontend/views/reset.tpl.pug    |   48 +
 .../frontend/views/settings/admin.jade          |   51 -
 .../frontend/views/settings/admin.tpl.pug       |   25 +
 .../frontend/views/settings/profile.jade        |   76 -
 .../frontend/views/settings/profile.tpl.pug     |   76 +
 modules/web-console/frontend/views/signin.jade  |  163 --
 .../web-console/frontend/views/signin.tpl.pug   |  163 ++
 .../frontend/views/sql/cache-metadata.jade      |   40 -
 .../frontend/views/sql/cache-metadata.tpl.pug   |   40 +
 .../frontend/views/sql/chart-settings.jade      |   40 -
 .../frontend/views/sql/chart-settings.tpl.pug   |   40 +
 .../frontend/views/sql/notebook-new.jade        |   33 -
 .../frontend/views/sql/notebook-new.tpl.pug     |   33 +
 .../frontend/views/sql/paragraph-rate.jade      |   31 -
 .../frontend/views/sql/paragraph-rate.tpl.pug   |   31 +
 modules/web-console/frontend/views/sql/sql.jade |  278 --
 .../web-console/frontend/views/sql/sql.tpl.pug  |  291 ++
 .../views/templates/agent-download.jade         |   50 -
 .../views/templates/agent-download.tpl.pug      |   50 +
 .../frontend/views/templates/alert.jade         |   21 -
 .../frontend/views/templates/alert.tpl.pug      |   21 +
 .../frontend/views/templates/batch-confirm.jade |   34 -
 .../views/templates/batch-confirm.tpl.pug       |   34 +
 .../frontend/views/templates/clone.jade         |   39 -
 .../frontend/views/templates/confirm.jade       |   33 -
 .../frontend/views/templates/confirm.tpl.pug    |   33 +
 .../frontend/views/templates/demo-info.jade     |   47 -
 .../frontend/views/templates/demo-info.tpl.pug  |   47 +
 .../frontend/views/templates/dropdown.jade      |   24 -
 .../frontend/views/templates/dropdown.tpl.pug   |   24 +
 .../views/templates/getting-started.jade        |   34 -
 .../views/templates/getting-started.tpl.pug     |   34 +
 .../frontend/views/templates/message.jade       |   28 -
 .../frontend/views/templates/message.tpl.pug    |   28 +
 .../frontend/views/templates/pagination.jade    |   32 -
 .../frontend/views/templates/select.jade        |   26 -
 .../frontend/views/templates/select.tpl.pug     |   26 +
 .../views/templates/validation-error.jade       |   25 -
 .../views/templates/validation-error.tpl.pug    |   25 +
 modules/web-console/web-agent/README.txt        |    4 +-
 .../web-agent/bin/ignite-web-agent.bat          |    4 +-
 .../web-agent/bin/ignite-web-agent.sh           |    2 +
 .../ignite/console/agent/AgentLauncher.java     |  259 +-
 .../apache/ignite/console/agent/AgentUtils.java |   80 +
 .../console/agent/handlers/AbstractHandler.java |  110 -
 .../agent/handlers/AbstractListener.java        |  104 +
 .../console/agent/handlers/DatabaseHandler.java |  298 --
 .../agent/handlers/DatabaseListener.java        |  316 ++
 .../console/agent/handlers/RestHandler.java     |  276 --
 .../console/agent/handlers/RestListener.java    |  287 ++
 .../ignite/console/demo/AgentClusterDemo.java   |  479 +--
 .../ignite/console/demo/AgentDemoUtils.java     |   79 +
 .../demo/service/DemoCachesLoadService.java     |  482 +++
 .../service/DemoRandomCacheLoadService.java     |  120 +
 .../service/DemoServiceClusterSingleton.java    |   41 +
 .../demo/service/DemoServiceKeyAffinity.java    |   41 +
 .../service/DemoServiceMultipleInstances.java   |   41 +
 .../demo/service/DemoServiceNodeSingleton.java  |   41 +
 .../cache/websession/WebSessionFilter.java      |   12 +-
 .../ignite/cache/websession/WebSessionV2.java   |    2 +-
 .../servlet/ServletContextListenerStartup.java  |   12 +-
 .../ignite/startup/servlet/ServletStartup.java  |    8 +-
 .../internal/websession/WebSessionSelfTest.java |   27 +-
 modules/yardstick/DEVNOTES-standalone.txt       |   16 +
 modules/yardstick/DEVNOTES.txt                  |   20 +
 modules/yardstick/README.txt                    |  140 +-
 .../config/benchmark-atomic-win.properties      |    2 +-
 .../config/benchmark-atomic.properties          |   56 +-
 .../config/benchmark-bin-identity.properties    |   24 +-
 .../config/benchmark-cache-load-win.properties  |    2 +-
 .../config/benchmark-cache-load.properties      |   19 +-
 .../config/benchmark-client-mode.properties     |   76 +-
 .../config/benchmark-compute-win.properties     |    2 +-
 .../config/benchmark-compute.properties         |   51 +-
 .../config/benchmark-failover.properties        |   24 +-
 .../yardstick/config/benchmark-full.properties  |   80 +-
 .../config/benchmark-multicast.properties       |  115 +-
 .../config/benchmark-put-indexed-val.properties |   44 +-
 .../benchmark-query-put-separated.properties    |   11 +-
 .../config/benchmark-query-win.properties       |    2 +-
 .../yardstick/config/benchmark-query.properties |   54 +-
 .../config/benchmark-remote-sample.properties   |   81 +
 .../config/benchmark-remote.properties          |  115 +
 .../config/benchmark-sample.properties          |   81 +
 .../config/benchmark-sql-dml.properties         |   57 +-
 .../yardstick/config/benchmark-store.properties |   41 +-
 .../config/benchmark-tx-win.properties          |    2 +-
 .../yardstick/config/benchmark-tx.properties    |   54 +-
 .../yardstick/config/benchmark-win.properties   |    2 +-
 modules/yardstick/config/benchmark.properties   |   94 +-
 modules/yardstick/config/ignite-base-config.xml |   25 +
 .../yardstick/config/ignite-remote-config.xml   |   47 +
 .../test-max-int-values-offheap.properties      |   31 +-
 .../test-max-int-values-onheap.properties       |   31 +-
 .../config/test-max-int-values-swap.properties  |   31 +-
 modules/yardstick/pom-standalone.xml            |  209 ++
 modules/yardstick/pom.xml                       |   14 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   28 +-
 .../ignite/yardstick/IgniteBenchmarkUtils.java  |    2 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    2 +-
 .../cache/IgniteBinaryIdentityBenchmark.java    |   21 -
 .../yardstick/cache/IgniteGetAllBenchmark.java  |   42 +
 .../cache/IgniteGetAllOffHeapBenchmark.java     |   30 +
 .../cache/IgniteGetAndPutBenchmark.java         |    2 +-
 .../cache/IgniteGetAndPutTxBenchmark.java       |    2 +-
 .../yardstick/cache/IgniteGetBenchmark.java     |   35 +
 .../IgniteLegacyBinaryIdentityGetBenchmark.java |   30 -
 .../IgniteLegacyBinaryIdentityPutBenchmark.java |   30 -
 .../cache/IgnitePutAllOffHeapBenchmark.java     |   30 +
 .../cache/IgnitePutAllTxOffHeapBenchmark.java   |   30 +
 .../IgnitePutOffHeapIndexedValue8Benchmark.java |   30 +
 .../IgnitePutRandomValueSizeBenchmark.java      |   41 +
 .../cache/IgnitePutRemoveBenchmark.java         |   42 +
 .../cache/IgnitePutRemoveTxBenchmark.java       |   30 +
 .../cache/IgnitePutValue8Benchmark.java         |   42 +
 .../cache/WaitMapExchangeFinishCallable.java    |    4 +-
 .../IgniteAtomicInvokeRetryBenchmark.java       |   12 +-
 .../failover/IgniteAtomicRetriesBenchmark.java  |   12 +-
 .../IgniteFailoverAbstractBenchmark.java        |   22 +-
 ...IgniteTransactionalInvokeRetryBenchmark.java |   10 +-
 ...IgniteTransactionalWriteInvokeBenchmark.java |   16 +-
 .../IgniteTransactionalWriteReadBenchmark.java  |   12 +-
 .../IgniteCacheRandomOperationBenchmark.java    |   74 +-
 .../apache/ignite/yarn/ApplicationMaster.java   |    4 +-
 .../apache/ignite/yarn/ClusterProperties.java   |    1 +
 .../org/apache/ignite/yarn/IgniteProvider.java  |    4 +-
 .../yarn/IgniteApplicationMasterSelfTest.java   |   13 +
 modules/zeromq/README.txt                       |   37 +
 modules/zeromq/licenses/apache-2.0.txt          |  202 ++
 modules/zeromq/pom.xml                          |   75 +
 .../stream/zeromq/IgniteZeroMqStreamer.java     |  146 +
 .../ignite/stream/zeromq/ZeroMqTypeSocket.java  |   56 +
 .../ignite/stream/zeromq/package-info.java      |   21 +
 .../stream/zeromq/IgniteZeroMqStreamerTest.java |  235 ++
 .../zeromq/IgniteZeroMqStreamerTestSuite.java   |   37 +
 .../ZeroMqStringSingleTupleExtractor.java       |   46 +
 .../ignite/stream/zeromq/package-info.java      |   21 +
 .../zk/TcpDiscoveryZookeeperIpFinder.java       |   37 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |   12 +-
 parent/pom.xml                                  |   16 +-
 pom.xml                                         |  101 +-
 3238 files changed, 113421 insertions(+), 52681 deletions(-)
----------------------------------------------------------------------