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

[06/31] ignite git commit: Merge remote-tracking branch 'apache/master' into ignite-4490

Merge remote-tracking branch 'apache/master' into ignite-4490

# Conflicts:
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/UpdatePlanBuilder.java


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

Branch: refs/heads/ignite-6022-proto
Commit: 336ad01a7ec01698b739dca766962c9f7c8957dd
Parents: e526948 651ffc5
Author: Alexander Paschenko <al...@gmail.com>
Authored: Thu Jul 6 13:17:14 2017 +0300
Committer: Alexander Paschenko <al...@gmail.com>
Committed: Thu Jul 6 14:12:36 2017 +0300

----------------------------------------------------------------------
 .gitignore                                      |   31 +-
 DEVNOTES.txt                                    |   77 +-
 NOTICE                                          |    2 +-
 RELEASE_NOTES.txt                               |   56 +
 assembly/LICENSE_FABRIC                         |    2 +-
 assembly/LICENSE_HADOOP                         |    2 +-
 assembly/NOTICE_FABRIC                          |    2 +-
 assembly/NOTICE_HADOOP                          |    2 +-
 assembly/dependencies-fabric-lgpl.xml           |    5 +-
 assembly/dependencies-fabric.xml                |    9 +-
 assembly/dependencies-hadoop.xml                |    3 +
 assembly/dependencies-schema-import.xml         |   57 -
 assembly/libs/README.txt                        |    2 +
 assembly/release-base.xml                       |    7 -
 assembly/release-fabric-base.xml                |   28 +-
 assembly/release-fabric-lgpl.xml                |    1 +
 assembly/release-fabric.xml                     |    1 +
 assembly/release-schema-import.xml              |   50 -
 assembly/release-sources.xml                    |    3 +-
 assembly/release-yardstick.xml                  |   98 +
 bin/control.bat                                 |  229 +
 bin/control.sh                                  |  180 +
 bin/ignite-schema-import.bat                    |  110 -
 bin/ignite-schema-import.sh                     |   87 -
 config/dotnet/default-dotnet.xml                |   45 -
 config/example-kube.xml                         |   53 +
 config/hadoop/default-config.xml                |   29 -
 config/ignite-log4j.xml                         |    6 +-
 config/ignite-log4j2.xml                        |    6 +-
 doap_Ignite.rdf                                 |   14 +-
 examples/README-LGPL.txt                        |    4 +-
 examples/README.txt                             |   12 +-
 examples/config/example-cache.xml               |    1 +
 examples/config/example-memory-policies.xml     |  111 +
 examples/config/filesystem/example-igfs.xml     |   32 +-
 .../example-persistent-store.xml                |   77 +
 examples/config/spark/example-shared-rdd.xml    |   83 +
 examples/pom-standalone-lgpl.xml                |   21 +-
 examples/pom-standalone.xml                     |   21 +-
 examples/pom.xml                                |   75 +-
 examples/redis/redis-example.php                |    4 +-
 examples/redis/redis-example.py                 |    3 +-
 examples/rest/http-rest-example.php             |    4 +-
 examples/schema-import/README.txt               |   38 -
 examples/schema-import/bin/db-init.sql          |   28 -
 examples/schema-import/bin/h2-server.bat        |   80 -
 examples/schema-import/bin/h2-server.sh         |   66 -
 .../schema-import/bin/schema-import.properties  |   28 -
 examples/schema-import/pom-standalone.xml       |   90 -
 examples/schema-import/pom.xml                  |  101 -
 .../org/apache/ignite/schema/CacheConfig.java   |   36 -
 .../java/org/apache/ignite/schema/Demo.java     |  134 -
 .../java/org/apache/ignite/schema/DemoNode.java |   38 -
 .../ignite/schema/H2DataSourceFactory.java      |   35 -
 .../java/org/apache/ignite/schema/Person.java   |   44 -
 .../org/apache/ignite/schema/PersonKey.java     |   37 -
 .../hibernate/HibernateL2CacheExample.java      |  106 +-
 .../datagrid/CacheClientBinaryQueryExample.java |    4 +-
 .../computegrid/ComputeAsyncExample.java        |    8 +-
 .../ComputeFibonacciContinuationExample.java    |   13 +-
 .../examples/datagrid/CacheAsyncApiExample.java |   17 +-
 .../examples/datagrid/CacheQueryExample.java    |   56 +-
 .../datagrid/MemoryPoliciesExample.java         |  114 +
 .../starschema/CacheStarSchemaExample.java      |   59 +-
 .../datastructures/IgniteLockExample.java       |    4 +-
 .../datastructures/IgniteSemaphoreExample.java  |    4 +-
 .../client/memcache/MemcacheRestExample.java    |    2 +-
 .../MemcacheRestExampleNodeStartup.java         |    8 +-
 .../ignite/examples/model/Organization.java     |    9 +
 .../persistentstore/PersistentStoreExample.java |   92 +
 .../PersistentStoreExampleNodeStartup.java      |   33 +
 .../examples/springdata/PersonRepository.java   |   59 +
 .../examples/springdata/SpringAppCfg.java       |   69 +
 .../examples/springdata/SpringDataExample.java  |  154 +
 .../streaming/wordcount/QueryWords.java         |    3 +-
 .../CholeskyDecompositionExample.java           |   80 +
 .../EigenDecompositionExample.java              |   69 +
 .../decompositions/LUDecompositionExample.java  |   83 +
 .../SingularValueDecompositionExample.java      |   70 +
 .../ml/math/decompositions/package-info.java    |   22 +
 .../ml/math/matrix/CacheMatrixExample.java      |  102 +
 .../ml/math/matrix/ExampleMatrixStorage.java    |  163 +
 .../math/matrix/MatrixCustomStorageExample.java |  141 +
 .../examples/ml/math/matrix/MatrixExample.java  |   79 +
 .../ml/math/matrix/MatrixExampleUtil.java       |   52 +
 .../ml/math/matrix/OffHeapMatrixExample.java    |   84 +
 .../matrix/SparseDistributedMatrixExample.java  |   70 +
 .../ml/math/matrix/SparseMatrixExample.java     |   84 +
 .../examples/ml/math/matrix/package-info.java   |   22 +
 .../ignite/examples/ml/math/package-info.java   |   22 +
 .../DistributedRegressionExample.java           |  149 +
 .../examples/ml/math/tracer/TracerExample.java  |   63 +
 .../examples/ml/math/tracer/package-info.java   |   22 +
 .../ml/math/vector/CacheVectorExample.java      |  109 +
 .../ml/math/vector/ExampleVectorStorage.java    |  127 +
 .../ml/math/vector/OffHeapVectorExample.java    |   78 +
 .../ml/math/vector/SparseVectorExample.java     |   76 +
 .../math/vector/VectorCustomStorageExample.java |  120 +
 .../examples/ml/math/vector/VectorExample.java  |   73 +
 .../examples/ml/math/vector/package-info.java   |   22 +
 .../examples/ScalarCacheAffinityExample.scala   |    2 +-
 .../examples/ScalarContinuationExample.scala    |   10 +-
 .../examples/spark/ScalarSharedRDDExample.scala |   89 +
 .../ignite/examples/spark/SharedRDDExample.java |  127 +
 .../ignite/examples/spark/package-info.java     |   22 +
 .../ignite/examples/CacheExamplesSelfTest.java  |    8 +
 .../examples/SpringDataExampleSelfTest.java     |   32 +
 .../testsuites/IgniteExamplesSelfTestSuite.java |    2 +
 .../examples/IndexingBridgeMethodTest.java      |   93 -
 .../IgniteExamplesJ8SelfTestSuite.java          |    3 +-
 .../tests/examples/ScalarExamplesSelfTest.scala |    6 +
 .../examples/SharedRDDExampleSelfTest.java      |   36 +
 .../IgniteExamplesSparkSelfTestSuite.java       |   46 +
 modules/aop/pom.xml                             |    2 +-
 .../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  |   10 +-
 .../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 +-
 .../optimized/OptimizedMarshallerAopTest.java   |  105 +
 .../optimized/OptimizedMarshallerAopTest.java   |  104 -
 .../apache/ignite/p2p/P2PGridifySelfTest.java   |    8 +-
 .../singlesplit/SingleSplitsLoadTest.java       |   10 +-
 .../gridify/GridifySingleSplitLoadTest.java     |    6 +-
 .../org/test/gridify/ExternalAopTarget.java     |   16 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |   12 +-
 modules/apache-license-gen/pom.xml              |    2 +-
 modules/aws/pom.xml                             |    8 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |   74 +-
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   31 +-
 .../s3/S3CheckpointManagerSelfTest.java         |    6 +-
 ...3IpFinderAwsCredentialsProviderSelfTest.java |    2 +-
 modules/benchmarks/pom.xml                      |    9 +-
 .../jmh/cache/JmhCacheAbstractBenchmark.java    |   13 +-
 .../jmh/future/JmhFutureAdapterBenchmark.java   |  145 +
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java |  327 ++
 modules/camel/pom.xml                           |    2 +-
 .../stream/camel/IgniteCamelStreamerTest.java   |   10 +-
 modules/cassandra/pom.xml                       |    2 +-
 modules/cassandra/serializers/pom.xml           |    4 +-
 modules/cassandra/store/pom.xml                 |    4 +-
 .../store/cassandra/CassandraCacheStore.java    |   31 +-
 .../cassandra/common/PropertyMappingHelper.java |   88 +-
 .../store/cassandra/datasource/DataSource.java  |   50 +-
 .../persistence/KeyPersistenceSettings.java     |  161 +-
 .../persistence/PersistenceSettings.java        |   81 +-
 .../store/cassandra/persistence/PojoField.java  |  146 +-
 .../persistence/PojoFieldAccessor.java          |  162 +
 .../cassandra/persistence/PojoKeyField.java     |   18 +-
 .../cassandra/persistence/PojoValueField.java   |   16 +-
 .../persistence/ValuePersistenceSettings.java   |   52 +-
 .../cassandra/session/CassandraSessionImpl.java |   23 +-
 .../session/LoadCacheCustomQueryWorker.java     |   26 +-
 .../cassandra/session/pool/SessionPool.java     |    6 +-
 .../cassandra/session/pool/SessionWrapper.java  |   15 +-
 .../store/cassandra/utils/DDLGenerator.java     |    9 +-
 .../ignite/ignite-cassandra-server-template.xml |    9 -
 .../tests/ignite-cassandra-client-template.xml  |    9 -
 .../tests/CassandraDirectPersistenceTest.java   |   81 +-
 .../apache/ignite/tests/DDLGeneratorTest.java   |    4 +
 .../ignite/tests/IgnitePersistentStoreTest.java |  181 +-
 .../org/apache/ignite/tests/pojos/Person.java   |   10 +-
 .../org/apache/ignite/tests/pojos/Product.java  |    7 -
 .../apache/ignite/tests/pojos/ProductOrder.java |    8 -
 .../apache/ignite/tests/pojos/SimplePerson.java |  186 +
 .../ignite/tests/pojos/SimplePersonId.java      |   89 +
 .../ignite/tests/utils/TestTransaction.java     |   11 +
 .../apache/ignite/tests/utils/TestsHelper.java  |  103 +-
 .../tests/persistence/blob/ignite-config.xml    |    4 +-
 .../persistence/loadall_blob/ignite-config.xml  |   90 +
 .../loadall_blob/persistence-settings.xml       |   29 +
 .../tests/persistence/pojo/ignite-config.xml    |   40 +-
 .../persistence/pojo/persistence-settings-5.xml |   21 +
 .../persistence/pojo/persistence-settings-6.xml |  174 +
 .../persistence/primitive/ignite-config.xml     |    4 +-
 .../primitive/ignite-remote-server-config.xml   |    4 +-
 modules/clients/pom.xml                         |    9 +-
 .../src/test/config/jdbc-config-cache-store.xml |  124 +
 modules/clients/src/test/config/jdbc-config.xml |    8 +-
 .../internal/TaskEventSubjectIdSelfTest.java    |    4 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |   41 +-
 .../client/ClientDefaultCacheSelfTest.java      |   10 +-
 .../internal/client/ClientStartNodeTask.java    |   24 +-
 .../internal/client/ClientStopNodeTask.java     |    2 +-
 .../ClientTcpSslAuthenticationSelfTest.java     |    4 +-
 ...skExecutionAfterTopologyRestartSelfTest.java |    4 +-
 .../internal/client/ClientTestRestServer.java   |    6 +-
 .../ClientAbstractMultiNodeSelfTest.java        |   45 +-
 .../integration/ClientAbstractSelfTest.java     |   19 +-
 .../integration/ClientPreferDirectSelfTest.java |    4 +-
 .../ClientTcpUnreachableMultiNodeSelfTest.java  |    6 +-
 .../client/router/ClientFailedInitSelfTest.java |    4 +-
 .../client/router/RouterFactorySelfTest.java    |    4 +-
 .../client/suite/IgniteClientTestSuite.java     |    8 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |  193 +-
 .../JdbcAbstractUpdateStatementSelfTest.java    |   11 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |   11 +-
 ...cBinaryMarshallerMergeStatementSelfTest.java |   11 +-
 .../ignite/internal/jdbc2/JdbcBlobTest.java     |  485 ++
 .../jdbc2/JdbcComplexQuerySelfTest.java         |   91 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |   73 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |   12 +-
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java |  369 ++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...bcDynamicIndexAtomicPartitionedSelfTest.java |   39 +
 ...dbcDynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java  |    6 +-
 .../jdbc2/JdbcInsertStatementSelfTest.java      |   71 +-
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java |   36 +-
 .../jdbc2/JdbcMergeStatementSelfTest.java       |   67 +-
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |  136 +-
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java  |   53 +-
 .../jdbc2/JdbcPreparedStatementSelfTest.java    |  110 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |   36 +-
 .../internal/jdbc2/JdbcSpringSelfTest.java      |  123 +
 .../internal/jdbc2/JdbcStatementSelfTest.java   |   10 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java   |  185 +
 .../jdbc2/JdbcUpdateStatementSelfTest.java      |   50 +
 .../rest/AbstractRestProcessorSelfTest.java     |    6 +-
 .../rest/ChangeStateCommandHandlerTest.java     |  125 +
 .../rest/ClientMemcachedProtocolSelfTest.java   |    4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |  534 +-
 .../rest/JettyRestProcessorSignedSelfTest.java  |    8 +-
 .../rest/RestBinaryProtocolSelfTest.java        |  105 +-
 .../rest/RestMemcacheProtocolSelfTest.java      |   51 +-
 .../rest/RestProcessorMultiStartSelfTest.java   |    4 +-
 .../rest/RestProcessorStartSelfTest.java        |    8 +-
 .../processors/rest/RestProcessorTest.java      |    2 +-
 .../rest/TaskCommandHandlerSelfTest.java        |   11 +-
 .../processors/rest/TestBinaryClient.java       |   23 +-
 .../processors/rest/TestMemcacheClient.java     |    2 +-
 .../rest/protocols/tcp/MockNioSession.java      |    5 +-
 .../tcp/redis/RedisCommonAbstractTest.java      |  133 +
 .../tcp/redis/RedisProtocolConnectSelfTest.java |   73 +
 .../tcp/redis/RedisProtocolSelfTest.java        |  559 --
 .../tcp/redis/RedisProtocolStringSelfTest.java  |  445 ++
 .../jdbc/AbstractJdbcPojoQuerySelfTest.java     |  167 +
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java   |   50 +-
 .../ignite/jdbc/JdbcConnectionSelfTest.java     |   13 +-
 .../ignite/jdbc/JdbcEmptyCacheSelfTest.java     |    6 +-
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java    |    6 +-
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |  121 +-
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |    9 +-
 .../jdbc/JdbcPojoLegacyQuerySelfTest.java       |   44 +
 .../ignite/jdbc/JdbcPojoQuerySelfTest.java      |   56 +
 .../jdbc/JdbcPreparedStatementSelfTest.java     |    8 +-
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |  129 +-
 .../ignite/jdbc/JdbcStatementSelfTest.java      |    8 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |   64 +-
 .../JdbcThinAbstractDmlStatementSelfTest.java   |  246 +
 .../jdbc/thin/JdbcThinAbstractSelfTest.java     |   27 +
 ...JdbcThinAbstractUpdateStatementSelfTest.java |   40 +
 .../thin/JdbcThinAutoCloseServerCursorTest.java |  359 ++
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java |  330 ++
 .../jdbc/thin/JdbcThinConnectionSelfTest.java   |  331 ++
 .../thin/JdbcThinDeleteStatementSelfTest.java   |   49 +
 .../JdbcThinDynamicIndexAbstractSelfTest.java   |  328 ++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...inDynamicIndexAtomicPartitionedSelfTest.java |   39 +
 ...hinDynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java   |  143 +
 .../thin/JdbcThinInsertStatementSelfTest.java   |  185 +
 .../thin/JdbcThinMergeStatementSelfTest.java    |  130 +
 .../jdbc/thin/JdbcThinMetadataSelfTest.java     |  357 ++
 .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java  |  158 +
 .../thin/JdbcThinPreparedStatementSelfTest.java |  768 +++
 .../jdbc/thin/JdbcThinResultSetSelfTest.java    |  762 +++
 .../jdbc/thin/JdbcThinStatementSelfTest.java    |  340 ++
 .../thin/JdbcThinUpdateStatementSelfTest.java   |   50 +
 modules/clients/src/test/resources/log4j.xml    |    2 +-
 .../clients/src/test/resources/spring-cache.xml |   10 -
 .../src/test/resources/spring-server-node.xml   |   73 +-
 .../test/resources/spring-server-ssl-node.xml   |   71 +-
 modules/cloud/pom.xml                           |    2 +-
 .../cloud/TcpDiscoveryCloudIpFinder.java        |   51 +-
 modules/codegen/pom.xml                         |    2 +-
 .../ignite/codegen/MessageCodeGenerator.java    |    6 +
 modules/core/pom.xml                            |   19 +-
 modules/core/src/main/java/META-INF/NOTICE      |    2 +-
 .../main/java/META-INF/services/java.sql.Driver |    2 +
 .../src/main/java/org/apache/ignite/Ignite.java |  139 +-
 .../java/org/apache/ignite/IgniteBinary.java    |   58 +-
 .../java/org/apache/ignite/IgniteCache.java     |  772 ++-
 .../ignite/IgniteCacheRestartingException.java  |   62 +
 .../apache/ignite/IgniteCheckedException.java   |   12 +
 .../java/org/apache/ignite/IgniteCluster.java   |  178 +-
 .../java/org/apache/ignite/IgniteCompute.java   |  314 +-
 .../org/apache/ignite/IgniteDataStreamer.java   |   12 +-
 .../java/org/apache/ignite/IgniteEvents.java    |  128 +-
 .../org/apache/ignite/IgniteFileSystem.java     |   98 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |  116 +-
 .../org/apache/ignite/IgniteJdbcThinDriver.java |  281 +
 .../java/org/apache/ignite/IgniteMessaging.java |   38 +-
 .../java/org/apache/ignite/IgniteServices.java  |  221 +-
 .../apache/ignite/IgniteSystemProperties.java   |  188 +-
 .../main/java/org/apache/ignite/Ignition.java   |   43 +-
 .../org/apache/ignite/IgnitionListener.java     |    2 +-
 .../java/org/apache/ignite/MemoryMetrics.java   |  119 +
 .../org/apache/ignite/PersistenceMetrics.java   |  117 +
 .../binary/BinaryAbstractIdentityResolver.java  |   53 -
 .../binary/BinaryArrayIdentityResolver.java     |  224 -
 .../ignite/binary/BinaryBasicIdMapper.java      |    5 +-
 .../ignite/binary/BinaryBasicNameMapper.java    |   10 +-
 .../binary/BinaryFieldIdentityResolver.java     |  307 --
 .../ignite/binary/BinaryIdentityResolver.java   |   42 -
 .../org/apache/ignite/binary/BinaryObject.java  |    8 +
 .../ignite/binary/BinaryObjectBuilder.java      |   10 -
 .../apache/ignite/binary/BinaryRawReader.java   |   13 +
 .../apache/ignite/binary/BinaryRawWriter.java   |   13 +
 .../org/apache/ignite/binary/BinaryReader.java  |   15 +
 .../org/apache/ignite/binary/BinaryType.java    |    5 +
 .../ignite/binary/BinaryTypeConfiguration.java  |   69 +-
 .../org/apache/ignite/binary/BinaryWriter.java  |   15 +
 .../ignite/cache/CacheAtomicWriteOrderMode.java |   64 -
 .../org/apache/ignite/cache/CacheEntry.java     |   12 -
 .../ignite/cache/CacheKeyConfiguration.java     |   10 +-
 .../org/apache/ignite/cache/CacheManager.java   |    2 +-
 .../apache/ignite/cache/CacheMemoryMode.java    |   63 -
 .../org/apache/ignite/cache/CacheMetrics.java   |  111 +-
 .../org/apache/ignite/cache/CachePeekMode.java  |    6 +-
 .../ignite/cache/CacheTypeFieldMetadata.java    |  149 -
 .../apache/ignite/cache/CacheTypeMetadata.java  |  379 --
 .../cache/CacheWriteSynchronizationMode.java    |    4 +-
 .../ignite/cache/PartitionLossPolicy.java       |   80 +
 .../org/apache/ignite/cache/QueryEntity.java    |  253 +-
 .../org/apache/ignite/cache/QueryIndex.java     |   77 +-
 .../org/apache/ignite/cache/QueryIndexType.java |   17 +-
 .../cache/affinity/AffinityKeyMapped.java       |   14 +-
 .../cache/affinity/AffinityKeyMapper.java       |    3 +
 .../AffinityNodeAddressHashResolver.java        |   44 -
 .../affinity/AffinityNodeHashResolver.java      |   47 -
 .../affinity/AffinityNodeIdHashResolver.java    |   45 -
 .../affinity/fair/FairAffinityFunction.java     | 1144 -----
 .../cache/affinity/fair/package-info.java       |   21 -
 .../rendezvous/RendezvousAffinityFunction.java  |  389 +-
 .../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/FieldsQueryCursor.java   |   39 +
 .../org/apache/ignite/cache/query/Query.java    |   48 +
 .../ignite/cache/query/SqlFieldsQuery.java      |   83 +-
 .../org/apache/ignite/cache/query/SqlQuery.java |   88 +-
 .../apache/ignite/cache/query/TextQuery.java    |    4 +-
 .../cache/query/annotations/QuerySqlField.java  |    2 +-
 .../cache/query/annotations/QueryTextField.java |    4 +-
 .../store/jdbc/CacheAbstractJdbcStore.java      |  233 +-
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |    5 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |   19 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |    4 +-
 .../org/apache/ignite/cluster/ClusterNode.java  |   11 +-
 .../apache/ignite/compute/gridify/Gridify.java  |   10 +
 .../ignite/compute/gridify/GridifySetToSet.java |   10 +
 .../compute/gridify/GridifySetToValue.java      |   10 +
 .../configuration/AtomicConfiguration.java      |   60 +-
 .../configuration/BinaryConfiguration.java      |   30 +-
 .../configuration/CacheConfiguration.java       | 1001 ++--
 .../configuration/CollectionConfiguration.java  |   68 +-
 .../configuration/ConnectorConfiguration.java   |  100 +-
 .../configuration/DataPageEvictionMode.java     |   68 +
 .../configuration/ExecutorConfiguration.java    |  115 +
 .../configuration/FileSystemConfiguration.java  |  419 +-
 .../configuration/HadoopConfiguration.java      |   31 +-
 .../configuration/IgniteConfiguration.java      |  432 +-
 .../configuration/MemoryConfiguration.java      |  303 ++
 .../MemoryPolicyConfiguration.java              |  376 ++
 .../configuration/NearCacheConfiguration.java   |    7 +-
 .../ignite/configuration/OdbcConfiguration.java |    4 +
 .../PersistentStoreConfiguration.java           |  540 ++
 .../SqlConnectorConfiguration.java              |  275 +
 .../ignite/configuration/TopologyValidator.java |   10 +-
 .../configuration/TransactionConfiguration.java |   45 +-
 .../apache/ignite/configuration/WALMode.java    |   60 +
 .../org/apache/ignite/events/CacheEvent.java    |    3 -
 .../java/org/apache/ignite/events/Event.java    |    1 -
 .../org/apache/ignite/events/EventType.java     |  111 +-
 .../apache/ignite/events/SwapSpaceEvent.java    |  105 -
 .../org/apache/ignite/hadoop/package-info.java  |   22 +
 .../igfs/IgfsGroupDataBlocksKeyMapper.java      |    5 +-
 .../igfs/IgfsIpcEndpointConfiguration.java      |   30 +-
 .../org/apache/ignite/igfs/IgfsMetrics.java     |    5 +-
 .../java/org/apache/ignite/igfs/IgfsPath.java   |   31 +-
 .../igfs/secondary/IgfsSecondaryFileSystem.java |    4 +-
 .../local/LocalIgfsSecondaryFileSystem.java     |    8 +-
 .../internal/ComputeTaskInternalFuture.java     |    3 -
 .../ignite/internal/ExecutorAwareMessage.java   |   31 +
 .../ignite/internal/GridCachePluginContext.java |   13 +-
 .../apache/ignite/internal/GridComponent.java   |   14 +-
 .../apache/ignite/internal/GridDiagnostic.java  |   16 +-
 .../internal/GridEventConsumeHandler.java       |   10 +-
 .../ignite/internal/GridJobCancelRequest.java   |    2 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   34 +-
 .../ignite/internal/GridJobExecuteResponse.java |    2 +-
 .../ignite/internal/GridJobSiblingImpl.java     |   34 +-
 .../ignite/internal/GridJobSiblingsRequest.java |    2 +-
 .../internal/GridJobSiblingsResponse.java       |    2 +-
 .../ignite/internal/GridKernalContext.java      |   78 +-
 .../ignite/internal/GridKernalContextImpl.java  |  123 +-
 .../ignite/internal/GridKernalGatewayImpl.java  |   47 +-
 .../apache/ignite/internal/GridLoggerProxy.java |   25 +-
 .../internal/GridMessageListenHandler.java      |   10 +-
 .../internal/GridPerformanceSuggestions.java    |   92 -
 .../ignite/internal/GridTaskCancelRequest.java  |    2 +-
 .../ignite/internal/GridTaskSessionImpl.java    |   15 +-
 .../ignite/internal/GridTaskSessionRequest.java |    2 +-
 .../org/apache/ignite/internal/GridTopic.java   |   16 +-
 .../ignite/internal/IgniteComputeImpl.java      |  609 ++-
 .../ignite/internal/IgniteDiagnosticAware.java  |   28 +
 .../ignite/internal/IgniteDiagnosticInfo.java   |   45 +
 .../internal/IgniteDiagnosticMessage.java       |  484 ++
 .../IgniteDiagnosticPrepareContext.java         |  279 +
 .../ignite/internal/IgniteEventsImpl.java       |   87 +-
 .../org/apache/ignite/internal/IgniteEx.java    |   46 +-
 .../ignite/internal/IgniteInternalFuture.java   |   15 -
 .../apache/ignite/internal/IgniteKernal.java    |  812 ++-
 .../ignite/internal/IgniteMessagingImpl.java    |   67 +-
 .../internal/IgniteNeedReconnectException.java  |   40 +
 .../ignite/internal/IgniteNodeAttributes.java   |   19 +-
 .../ignite/internal/IgniteServicesImpl.java     |  108 +
 .../ignite/internal/IgniteTransactionsEx.java   |    8 +-
 .../ignite/internal/IgniteVersionUtils.java     |    2 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |  403 +-
 .../apache/ignite/internal/LessNamingBean.java  |   28 -
 .../ignite/internal/MappingStoreTask.java       |    3 +-
 .../ignite/internal/MarshallerContextImpl.java  |  106 +-
 .../ignite/internal/MarshallerPlatformIds.java  |    3 +
 .../internal/StripedExecutorMXBeanAdapter.java  |   90 +
 .../binary/BinaryAbstractIdentityResolver.java  |   56 +
 .../binary/BinaryArrayIdentityResolver.java     |  222 +
 .../binary/BinaryCachingMetadataHandler.java    |   13 +
 .../internal/binary/BinaryClassDescriptor.java  |  142 +-
 .../ignite/internal/binary/BinaryContext.java   |  223 +-
 .../internal/binary/BinaryEnumObjectImpl.java   |   80 +-
 .../internal/binary/BinaryFieldAccessor.java    |   89 +-
 .../ignite/internal/binary/BinaryFieldEx.java   |   50 +
 .../ignite/internal/binary/BinaryFieldImpl.java |  180 +-
 .../internal/binary/BinaryFieldMetadata.java    |  127 +
 .../internal/binary/BinaryIdentityResolver.java |   43 +
 .../ignite/internal/binary/BinaryMetadata.java  |  141 +-
 .../binary/BinaryMetadataCollector.java         |   28 +-
 .../internal/binary/BinaryMetadataHandler.java  |   27 +-
 .../binary/BinaryNoopMetadataHandler.java       |   10 +
 .../internal/binary/BinaryObjectExImpl.java     |   20 +-
 .../internal/binary/BinaryObjectImpl.java       |  223 +-
 .../binary/BinaryObjectOffheapImpl.java         |   56 +-
 .../internal/binary/BinaryReaderExImpl.java     |  366 +-
 .../ignite/internal/binary/BinarySchema.java    |   11 +
 .../binary/BinarySerializedFieldComparator.java |    3 +
 .../ignite/internal/binary/BinaryTreeMap.java   |    6 +-
 .../ignite/internal/binary/BinaryTypeImpl.java  |   15 +
 .../ignite/internal/binary/BinaryTypeProxy.java |    9 +
 .../ignite/internal/binary/BinaryUtils.java     |  288 +-
 .../ignite/internal/binary/BinaryWriteMode.java |    6 +
 .../internal/binary/BinaryWriterExImpl.java     |  162 +-
 .../internal/binary/GridBinaryMarshaller.java   |   11 +-
 .../binary/builder/BinaryBuilderReader.java     |   45 +
 .../binary/builder/BinaryBuilderSerializer.java |   10 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |   89 +-
 .../streams/BinaryByteBufferInputStream.java    |  301 ++
 .../ignite/internal/client/GridClient.java      |    9 +
 .../internal/client/GridClientClusterState.java |   33 +
 .../client/GridClientConfiguration.java         |  100 +-
 .../client/GridClientDataConfiguration.java     |   15 +-
 .../ignite/internal/client/GridClientNode.java  |    9 +-
 .../client/GridClientPartitionAffinity.java     |   15 +-
 .../balancer/GridClientBalancerAdapter.java     |    5 +-
 .../client/impl/GridClientClusterStateImpl.java |   75 +
 .../client/impl/GridClientDataImpl.java         |    3 +-
 .../internal/client/impl/GridClientImpl.java    |   11 +
 .../client/impl/GridClientNodeImpl.java         |   22 +-
 .../impl/connection/GridClientConnection.java   |   17 +
 .../GridClientConnectionManagerAdapter.java     |    2 +-
 .../connection/GridClientNioTcpConnection.java  |   26 +-
 .../GridClientOptimizedMarshaller.java          |    2 +-
 .../GridClientZipOptimizedMarshaller.java       |    4 +-
 .../router/GridTcpRouterConfiguration.java      |   50 +-
 .../router/impl/GridRouterClientImpl.java       |    6 +
 .../client/router/impl/GridTcpRouterImpl.java   |    4 +-
 .../client/util/GridClientConsistentHash.java   |   14 +-
 .../internal/cluster/ClusterGroupAdapter.java   |   35 +-
 .../ignite/internal/cluster/ClusterGroupEx.java |    5 +-
 .../cluster/ClusterNodeLocalMapImpl.java        |    2 +-
 .../cluster/IgniteClusterAsyncImpl.java         |   39 +-
 .../internal/cluster/IgniteClusterImpl.java     |   64 +-
 .../internal/commandline/CommandHandler.java    |   89 +
 .../internal/direct/DirectMessageWriter.java    |    4 +-
 .../stream/v1/DirectByteBufferStreamImplV1.java |    8 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java |   37 +-
 .../internal/executor/GridExecutorService.java  |    3 +-
 .../igfs/common/IgfsControlResponse.java        |   28 +
 .../internal/igfs/common/IgfsIpcCommand.java    |    5 +-
 .../ignite/internal/igfs/common/IgfsLogger.java |   60 +-
 .../internal/igfs/common/IgfsMarshaller.java    |   12 +
 .../igfs/common/IgfsModeResolverRequest.java    |   35 +
 .../internal/jdbc/JdbcDriverPropertyInfo.java   |   37 +
 .../internal/jdbc/thin/JdbcThinConnection.java  |  663 +++
 .../jdbc/thin/JdbcThinPreparedStatement.java    |  485 ++
 .../internal/jdbc/thin/JdbcThinResultSet.java   | 1714 +++++++
 .../jdbc/thin/JdbcThinResultSetMetadata.java    |  161 +
 .../internal/jdbc/thin/JdbcThinStatement.java   |  495 ++
 .../internal/jdbc/thin/JdbcThinTcpIo.java       |  417 ++
 .../internal/jdbc/thin/JdbcThinUtils.java       |  226 +
 .../apache/ignite/internal/jdbc2/JdbcBlob.java  |  191 +
 .../ignite/internal/jdbc2/JdbcConnection.java   |  197 +-
 .../internal/jdbc2/JdbcPreparedStatement.java   |   38 +-
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |   48 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java  |  406 --
 .../ignite/internal/jdbc2/JdbcResultSet.java    |   75 +-
 .../internal/jdbc2/JdbcSqlFieldsQuery.java      |   57 +
 .../ignite/internal/jdbc2/JdbcStatement.java    |   38 +-
 .../jdbc2/JdbcStreamedPreparedStatement.java    |   60 +
 .../apache/ignite/internal/jdbc2/JdbcUtils.java |    4 +-
 .../internal/managers/GridManagerAdapter.java   |   46 +-
 .../checkpoint/GridCheckpointManager.java       |   51 +-
 .../checkpoint/GridCheckpointRequest.java       |    4 +-
 .../managers/communication/GridIoManager.java   |  960 +++-
 .../managers/communication/GridIoMessage.java   |   20 +-
 .../communication/GridIoMessageFactory.java     |  128 +-
 .../managers/communication/GridIoPolicy.java    |    8 +-
 .../communication/GridIoUserMessage.java        |    2 +-
 .../communication/GridMessageListener.java      |    3 +-
 .../communication/IgniteIoTestMessage.java      |  375 +-
 .../deployment/GridDeploymentClassLoader.java   |    3 +-
 .../deployment/GridDeploymentCommunication.java |   16 +-
 .../deployment/GridDeploymentInfoBean.java      |    2 +-
 .../deployment/GridDeploymentRequest.java       |    2 +-
 .../deployment/GridDeploymentResponse.java      |    2 +-
 .../internal/managers/discovery/DiscoCache.java |  279 +
 .../discovery/DiscoveryCustomMessage.java       |   48 +
 .../discovery/GridDiscoveryManager.java         | 1170 ++---
 .../eventstorage/DiscoveryEventListener.java    |   33 +
 .../eventstorage/GridEventStorageManager.java   |  343 +-
 .../eventstorage/GridEventStorageMessage.java   |    2 +-
 .../failover/GridFailoverContextImpl.java       |   11 -
 .../managers/failover/GridFailoverManager.java  |    3 -
 .../managers/indexing/GridIndexingManager.java  |   63 +-
 .../swapspace/GridSwapSpaceManager.java         |  417 --
 .../managers/swapspace/package-info.java        |   22 -
 .../optimized/OptimizedClassDescriptor.java     | 1141 +++++
 .../optimized/OptimizedFieldType.java           |   50 +
 .../optimized/OptimizedMarshaller.java          |  314 ++
 .../optimized/OptimizedMarshallerIdMapper.java  |   33 +
 .../optimized/OptimizedMarshallerUtils.java     |  551 ++
 .../optimized/OptimizedObjectInputStream.java   | 1231 +++++
 .../optimized/OptimizedObjectOutputStream.java  |  875 ++++
 .../OptimizedObjectStreamRegistry.java          |  244 +
 .../marshaller/optimized/package-info.java      |   22 +
 .../internal/mem/DirectMemoryProvider.java      |   40 +
 .../ignite/internal/mem/DirectMemoryRegion.java |   41 +
 .../mem/IgniteOutOfMemoryException.java         |   51 +
 .../apache/ignite/internal/mem/UnsafeChunk.java |   66 +
 .../ignite/internal/mem/file/MappedFile.java    |  152 +
 .../mem/file/MappedFileMemoryProvider.java      |  148 +
 .../mem/unsafe/UnsafeMemoryProvider.java        |  106 +
 .../ignite/internal/pagemem/FullPageId.java     |  157 +
 .../internal/pagemem/PageIdAllocator.java       |   53 +
 .../ignite/internal/pagemem/PageIdUtils.java    |  201 +
 .../ignite/internal/pagemem/PageMemory.java     |   46 +
 .../ignite/internal/pagemem/PageSupport.java    |  114 +
 .../ignite/internal/pagemem/PageUtils.java      |  201 +
 .../pagemem/impl/PageMemoryNoStoreImpl.java     |  820 +++
 ...ishSnapshotOperationAckDiscoveryMessage.java |   77 +
 .../pagemem/snapshot/SnapshotOperation.java     |  202 +
 .../pagemem/snapshot/SnapshotOperationType.java |   49 +
 ...artSnapshotOperationAckDiscoveryMessage.java |  149 +
 .../StartSnapshotOperationDiscoveryMessage.java |  192 +
 .../pagemem/store/IgnitePageStoreManager.java   |  196 +
 .../internal/pagemem/store/PageStore.java       |   96 +
 .../pagemem/wal/IgniteWriteAheadLogManager.java |  115 +
 .../internal/pagemem/wal/StorageException.java  |   44 +
 .../internal/pagemem/wal/WALIterator.java       |   29 +
 .../ignite/internal/pagemem/wal/WALPointer.java |   28 +
 .../internal/pagemem/wal/record/CacheState.java |  133 +
 .../pagemem/wal/record/CheckpointRecord.java    |  122 +
 .../internal/pagemem/wal/record/DataEntry.java  |  171 +
 .../internal/pagemem/wal/record/DataRecord.java |   70 +
 .../pagemem/wal/record/LazyDataEntry.java       |  116 +
 .../wal/record/MemoryRecoveryRecord.java        |   46 +
 .../pagemem/wal/record/PageSnapshot.java        |   81 +
 .../internal/pagemem/wal/record/TxRecord.java   |  129 +
 .../internal/pagemem/wal/record/WALRecord.java  |  258 +
 .../delta/DataPageInsertFragmentRecord.java     |   84 +
 .../wal/record/delta/DataPageInsertRecord.java  |   66 +
 .../wal/record/delta/DataPageRemoveRecord.java  |   67 +
 .../delta/DataPageSetFreeListPageRecord.java    |   62 +
 .../wal/record/delta/DataPageUpdateRecord.java  |   79 +
 .../record/delta/DeltaApplicationException.java |   35 +
 .../wal/record/delta/FixCountRecord.java        |   57 +
 .../record/delta/FixLeftmostChildRecord.java    |   58 +
 .../pagemem/wal/record/delta/FixRemoveId.java   |   62 +
 .../wal/record/delta/InitNewPageRecord.java     |   98 +
 .../wal/record/delta/InnerReplaceRecord.java    |   96 +
 .../pagemem/wal/record/delta/InsertRecord.java  |  110 +
 .../pagemem/wal/record/delta/MergeRecord.java   |   97 +
 .../wal/record/delta/MetaPageAddRootRecord.java |   57 +
 .../wal/record/delta/MetaPageCutRootRecord.java |   47 +
 .../wal/record/delta/MetaPageInitRecord.java    |   88 +
 .../delta/MetaPageInitRootInlineRecord.java     |   62 +
 .../record/delta/MetaPageInitRootRecord.java    |   61 +
 .../delta/MetaPageUpdateLastAllocatedIndex.java |   62 +
 ...aPageUpdateLastSuccessfulFullSnapshotId.java |   59 +
 .../MetaPageUpdateLastSuccessfulSnapshotId.java |   70 +
 .../delta/MetaPageUpdateNextSnapshotId.java     |   59 +
 .../MetaPageUpdatePartitionDataRecord.java      |  132 +
 .../wal/record/delta/NewRootInitRecord.java     |  115 +
 .../wal/record/delta/PageDeltaRecord.java       |   77 +
 .../delta/PageListMetaResetCountRecord.java     |   47 +
 .../record/delta/PagesListAddPageRecord.java    |   73 +
 .../delta/PagesListInitNewPageRecord.java       |  100 +
 .../record/delta/PagesListRemovePageRecord.java |   74 +
 .../record/delta/PagesListSetNextRecord.java    |   60 +
 .../delta/PagesListSetPreviousRecord.java       |   60 +
 .../record/delta/PartitionDestroyRecord.java    |   73 +
 .../record/delta/PartitionMetaStateRecord.java  |   82 +
 .../pagemem/wal/record/delta/RecycleRecord.java |   55 +
 .../pagemem/wal/record/delta/RemoveRecord.java  |   82 +
 .../pagemem/wal/record/delta/ReplaceRecord.java |   86 +
 .../record/delta/SplitExistingPageRecord.java   |   76 +
 .../record/delta/SplitForwardPageRecord.java    |  115 +
 .../record/delta/TrackingPageDeltaRecord.java   |   85 +
 .../processors/GridProcessorAdapter.java        |   10 +
 .../affinity/AffinityTopologyVersion.java       |   11 +-
 .../affinity/GridAffinityAssignmentCache.java   |   68 +-
 .../affinity/GridAffinityProcessor.java         |  102 +-
 .../cache/CacheAffinitySharedManager.java       | 1224 +++--
 .../CacheClientReconnectDiscoveryData.java      |  193 +
 .../cache/CacheClusterMetricsMXBeanImpl.java    |   85 +-
 .../internal/processors/cache/CacheData.java    |  191 +
 .../CacheDefaultBinaryAffinityKeyMapper.java    |   91 +-
 .../processors/cache/CacheEntryImplEx.java      |    8 +-
 .../cache/CacheEntryInfoCollection.java         |    2 +-
 .../cache/CacheEntryPredicateAdapter.java       |    9 +-
 .../cache/CacheEntryPredicateContainsValue.java |    2 +-
 .../cache/CacheEntrySerializablePredicate.java  |    2 +-
 .../cache/CacheEvictableEntryImpl.java          |   18 +-
 .../processors/cache/CacheEvictionEntry.java    |    2 +-
 .../processors/cache/CacheEvictionManager.java  |   63 +
 .../processors/cache/CacheGroupContext.java     |  965 ++++
 .../processors/cache/CacheGroupData.java        |  147 +
 .../processors/cache/CacheGroupDescriptor.java  |  210 +
 .../cache/CacheInvalidStateException.java       |   65 +
 .../cache/CacheInvokeDirectResult.java          |    2 +-
 .../cache/CacheJoinNodeDiscoveryData.java       |  159 +
 .../processors/cache/CacheLazyEntry.java        |    2 +-
 .../cache/CacheLocalMetricsMXBeanImpl.java      |   85 +-
 .../processors/cache/CacheMetricsImpl.java      |  301 +-
 .../processors/cache/CacheMetricsSnapshot.java  |  209 +-
 .../cache/CacheNodeCommonDiscoveryData.java     |  115 +
 .../internal/processors/cache/CacheObject.java  |   41 +-
 .../processors/cache/CacheObjectAdapter.java    |  127 +-
 .../cache/CacheObjectByteArrayImpl.java         |   36 +-
 .../processors/cache/CacheObjectContext.java    |  198 +-
 .../processors/cache/CacheObjectImpl.java       |   37 +-
 .../processors/cache/CacheObjectUtils.java      |  173 +
 .../cache/CacheObjectValueContext.java          |   50 +
 .../cache/CacheOffheapEvictionManager.java      |   67 +
 .../processors/cache/CacheOperationContext.java |   50 +-
 .../cache/CacheOsConflictResolutionManager.java |    2 +-
 .../cache/CachePartitionExchangeWorkerTask.java |   25 +
 .../processors/cache/CacheStoppedException.java |   35 +
 .../cache/CacheStoreBalancingWrapper.java       |    3 -
 .../internal/processors/cache/CacheType.java    |    7 +-
 .../cache/ChangeGlobalStateMessage.java         |  120 +
 .../ClientCacheChangeDiscoveryMessage.java      |  176 +
 .../ClientCacheChangeDummyDiscoveryMessage.java |  104 +
 .../cache/ClientCacheUpdateTimeout.java         |   44 +
 .../processors/cache/ClusterCachesInfo.java     | 1512 ++++++
 .../cache/ClusterCachesReconnectResult.java     |   61 +
 .../internal/processors/cache/ClusterState.java |   38 +
 .../cache/DynamicCacheChangeBatch.java          |   90 +-
 .../cache/DynamicCacheChangeRequest.java        |  206 +-
 .../cache/DynamicCacheDescriptor.java           |  257 +-
 .../processors/cache/EntryGetResult.java        |   95 +
 .../processors/cache/EntryGetWithTtlResult.java |   58 +
 .../processors/cache/ExchangeActions.java       |  434 ++
 .../processors/cache/GridCacheAdapter.java      | 1594 +++---
 .../cache/GridCacheAffinityManager.java         |   72 +-
 .../processors/cache/GridCacheAtomicFuture.java |    6 -
 .../cache/GridCacheAtomicVersionComparator.java |   24 +-
 .../processors/cache/GridCacheAttributes.java   |   59 +-
 .../cache/GridCacheBatchSwapEntry.java          |   76 -
 .../cache/GridCacheClearAllRunnable.java        |   56 +-
 .../cache/GridCacheCompoundFuture.java          |   63 +
 .../cache/GridCacheCompoundIdentityFuture.java  |   63 +
 .../cache/GridCacheConcurrentMap.java           |   73 +-
 .../cache/GridCacheConcurrentMapImpl.java       |  400 +-
 .../processors/cache/GridCacheContext.java      |  459 +-
 .../GridCacheDefaultAffinityKeyMapper.java      |   38 +-
 .../cache/GridCacheDeploymentManager.java       |   28 +-
 .../processors/cache/GridCacheEntryEx.java      |  127 +-
 .../processors/cache/GridCacheEntryInfo.java    |   99 +-
 .../GridCacheEntryInfoCollectSwapListener.java  |   70 -
 .../processors/cache/GridCacheEventManager.java |   74 +-
 .../cache/GridCacheEvictionManager.java         | 1912 +------
 .../cache/GridCacheEvictionRequest.java         |  248 -
 .../cache/GridCacheEvictionResponse.java        |  225 -
 .../processors/cache/GridCacheFuture.java       |   15 +
 .../cache/GridCacheFutureAdapter.java           |   62 +
 .../processors/cache/GridCacheGateway.java      |   55 +-
 .../cache/GridCacheGroupIdMessage.java          |  110 +
 .../processors/cache/GridCacheIdMessage.java    |  117 +
 .../processors/cache/GridCacheIoManager.java    |  843 +--
 .../cache/GridCacheLocalConcurrentMap.java      |   82 +
 .../processors/cache/GridCacheLogger.java       |    2 +-
 .../processors/cache/GridCacheManager.java      |    3 +-
 .../cache/GridCacheManagerAdapter.java          |    9 +-
 .../processors/cache/GridCacheMapEntry.java     | 3210 ++++++------
 .../cache/GridCacheMapEntryFactory.java         |    6 +-
 .../processors/cache/GridCacheMessage.java      |  114 +-
 .../cache/GridCacheMultiTxFuture.java           |    3 -
 .../processors/cache/GridCacheMvcc.java         |   23 +-
 .../processors/cache/GridCacheMvccManager.java  |  111 +-
 .../cache/GridCacheOffheapSwapEntry.java        |  191 -
 .../GridCachePartitionExchangeManager.java      | 1070 ++--
 .../processors/cache/GridCachePreloader.java    |   30 +-
 .../cache/GridCachePreloaderAdapter.java        |   53 +-
 .../processors/cache/GridCacheProcessor.java    | 2878 ++++++-----
 .../processors/cache/GridCacheProxyImpl.java    |  165 +-
 .../processors/cache/GridCacheReturn.java       |    8 +-
 .../cache/GridCacheSharedContext.java           |  186 +-
 .../cache/GridCacheSharedManagerAdapter.java    |   15 +
 .../cache/GridCacheSharedTtlCleanupManager.java |   11 +-
 .../processors/cache/GridCacheSwapEntry.java    |   82 -
 .../cache/GridCacheSwapEntryImpl.java           |  339 --
 .../processors/cache/GridCacheSwapListener.java |   33 -
 .../processors/cache/GridCacheSwapManager.java  | 2616 ----------
 .../cache/GridCacheTryPutFailedException.java   |   28 -
 .../processors/cache/GridCacheTtlManager.java   |  140 +-
 .../cache/GridCacheUpdateAtomicResult.java      |   96 +-
 .../processors/cache/GridCacheUtils.java        |  486 +-
 .../GridChangeGlobalStateMessageResponse.java   |  187 +
 .../cache/GridDeferredAckMessageSender.java     |   28 +-
 .../processors/cache/GridNoStorageCacheMap.java |   50 +-
 .../processors/cache/IgniteCacheFutureImpl.java |    8 +-
 .../cache/IgniteCacheOffheapManager.java        |  544 ++
 .../cache/IgniteCacheOffheapManagerImpl.java    | 2790 ++++++++++
 .../processors/cache/IgniteCacheProxy.java      |  858 +++-
 .../cache/IgniteFinishedCacheFutureImpl.java    |   32 +
 .../processors/cache/IgniteInternalCache.java   |  168 +-
 .../cache/IgniteRebalanceIterator.java          |   31 +
 .../processors/cache/IncompleteCacheObject.java |   84 +
 .../processors/cache/IncompleteObject.java      |   89 +
 .../processors/cache/KeyCacheObjectImpl.java    |   86 +-
 .../processors/cache/QueryCursorImpl.java       |   19 +-
 .../processors/cache/ReaderArguments.java       |   74 +
 .../processors/cache/StoredCacheData.java       |   93 +
 .../cache/affinity/GridCacheAffinityImpl.java   |    9 +-
 .../cache/binary/BinaryMetadataFileStore.java   |  114 +
 .../cache/binary/BinaryMetadataHolder.java      |   80 +
 .../cache/binary/BinaryMetadataTransport.java   |  683 +++
 .../binary/BinaryMetadataUpdatedListener.java   |   29 +
 .../CacheDefaultBinaryAffinityKeyMapper.java    |   51 -
 .../cache/binary/CacheObjectBinaryContext.java  |   16 +-
 .../binary/CacheObjectBinaryProcessor.java      |   31 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |  702 +--
 .../binary/ClientMetadataRequestFuture.java     |  166 +
 .../cache/binary/IgniteBinaryImpl.java          |   26 +
 .../cache/binary/MetadataRequestMessage.java    |  124 +
 .../cache/binary/MetadataResponseMessage.java   |  215 +
 .../binary/MetadataUpdateAcceptedMessage.java   |   96 +
 .../binary/MetadataUpdateProposedMessage.java   |  224 +
 .../cache/binary/MetadataUpdateResult.java      |   96 +
 .../CacheDataStructuresManager.java             |   38 +-
 .../distributed/GridCacheCommittedTxInfo.java   |  117 -
 .../distributed/GridCacheTtlUpdateRequest.java  |    6 +-
 .../distributed/GridCacheTxRecoveryFuture.java  |    9 +-
 .../distributed/GridCacheTxRecoveryRequest.java |    2 +-
 .../GridCacheTxRecoveryResponse.java            |    2 +-
 .../distributed/GridDistributedBaseMessage.java |    6 +-
 .../GridDistributedCacheAdapter.java            |   83 +-
 .../distributed/GridDistributedCacheEntry.java  |    8 +-
 .../distributed/GridDistributedLockRequest.java |   62 +-
 .../GridDistributedLockResponse.java            |    2 +-
 .../GridDistributedTxFinishRequest.java         |  219 +-
 .../GridDistributedTxFinishResponse.java        |   83 +-
 .../distributed/GridDistributedTxMapping.java   |  113 +-
 .../GridDistributedTxPrepareRequest.java        |  231 +-
 .../GridDistributedTxPrepareResponse.java       |   78 +-
 .../GridDistributedTxRemoteAdapter.java         |  504 +-
 .../GridDistributedUnlockRequest.java           |   20 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |   11 +-
 .../dht/ClientCacheDhtTopologyFuture.java       |   78 +
 .../dht/GridCachePartitionedConcurrentMap.java  |  109 +-
 .../dht/GridClientPartitionTopology.java        |  386 +-
 .../dht/GridDhtAffinityAssignmentRequest.java   |   78 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  |  173 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |   86 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |  653 ++-
 .../distributed/dht/GridDhtCacheEntry.java      |  103 +-
 .../distributed/dht/GridDhtEmbeddedFuture.java  |    3 -
 .../cache/distributed/dht/GridDhtGetFuture.java |  171 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |  181 +-
 .../distributed/dht/GridDhtLocalPartition.java  | 1024 ++--
 .../distributed/dht/GridDhtLockFuture.java      |   74 +-
 .../distributed/dht/GridDhtLockRequest.java     |   22 +-
 .../distributed/dht/GridDhtLockResponse.java    |    4 +-
 .../dht/GridDhtOffHeapCacheEntry.java           |   71 -
 .../distributed/dht/GridDhtPartitionState.java  |    5 +-
 .../dht/GridDhtPartitionTopology.java           |  118 +-
 .../dht/GridDhtPartitionTopologyImpl.java       | 1568 ++++--
 .../distributed/dht/GridDhtTopologyFuture.java  |   13 +-
 .../dht/GridDhtTopologyFutureAdapter.java       |  195 +
 .../dht/GridDhtTransactionalCacheAdapter.java   |  103 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   61 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |  253 +-
 .../dht/GridDhtTxFinishResponse.java            |   58 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |  164 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   66 +-
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java  |   18 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |  321 +-
 .../dht/GridDhtTxPrepareRequest.java            |  176 +-
 .../dht/GridDhtTxPrepareResponse.java           |  121 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |   24 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |   17 +-
 .../dht/GridPartitionedGetFuture.java           |  198 +-
 .../dht/GridPartitionedSingleGetFuture.java     |  282 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |  352 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |  409 +-
 .../dht/atomic/GridDhtAtomicCache.java          | 1651 +++---
 .../dht/atomic/GridDhtAtomicCacheEntry.java     |   58 -
 .../GridDhtAtomicDeferredUpdateResponse.java    |   74 +-
 .../dht/atomic/GridDhtAtomicNearResponse.java   |  314 ++
 .../atomic/GridDhtAtomicOffHeapCacheEntry.java  |   71 -
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |  104 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |  317 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   86 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  362 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |  121 +-
 ...idNearAtomicAbstractSingleUpdateRequest.java |  487 +-
 .../GridNearAtomicAbstractUpdateFuture.java     |  651 ++-
 .../GridNearAtomicAbstractUpdateRequest.java    |  554 +-
 .../GridNearAtomicCheckUpdateRequest.java       |  175 +
 .../atomic/GridNearAtomicFullUpdateRequest.java |  496 +-
 ...GridNearAtomicSingleUpdateFilterRequest.java |   38 +-
 .../GridNearAtomicSingleUpdateFuture.java       |  639 +--
 ...GridNearAtomicSingleUpdateInvokeRequest.java |   52 +-
 .../GridNearAtomicSingleUpdateRequest.java      |   77 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  | 1003 ++--
 .../atomic/GridNearAtomicUpdateResponse.java    |  366 +-
 .../dht/atomic/NearCacheUpdates.java            |  335 ++
 .../distributed/dht/atomic/UpdateErrors.java    |  222 +
 .../dht/colocated/GridDhtColocatedCache.java    |  285 +-
 .../colocated/GridDhtColocatedCacheEntry.java   |   57 -
 .../colocated/GridDhtColocatedLockFuture.java   |  184 +-
 .../GridDhtColocatedOffHeapCacheEntry.java      |   71 -
 .../colocated/GridDhtDetachedCacheEntry.java    |   28 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |   32 +-
 .../dht/preloader/GridDhtForceKeysRequest.java  |    6 +-
 .../dht/preloader/GridDhtForceKeysResponse.java |   10 +-
 .../GridDhtPartitionDemandMessage.java          |  110 +-
 .../dht/preloader/GridDhtPartitionDemander.java |  953 ++--
 .../preloader/GridDhtPartitionExchangeId.java   |    2 +-
 .../dht/preloader/GridDhtPartitionFullMap.java  |   45 +-
 .../dht/preloader/GridDhtPartitionMap.java      |  227 +-
 .../dht/preloader/GridDhtPartitionMap2.java     |  329 --
 .../dht/preloader/GridDhtPartitionSupplier.java |  694 +--
 .../GridDhtPartitionSupplyMessage.java          |  264 +-
 .../GridDhtPartitionSupplyMessageV2.java        |  384 --
 .../GridDhtPartitionsAbstractMessage.java       |   44 +-
 .../GridDhtPartitionsExchangeFuture.java        | 1160 ++++-
 .../preloader/GridDhtPartitionsFullMessage.java |  222 +-
 .../GridDhtPartitionsSingleMessage.java         |  178 +-
 .../GridDhtPartitionsSingleRequest.java         |   17 +-
 .../dht/preloader/GridDhtPreloader.java         |  574 +--
 .../IgniteDhtPartitionCountersMap.java          |   64 +
 .../IgniteDhtPartitionHistorySuppliersMap.java  |  110 +
 .../IgniteDhtPartitionsToReloadMap.java         |   88 +
 .../distributed/near/CacheVersionedValue.java   |    2 +-
 .../distributed/near/GridNearAtomicCache.java   |   50 +-
 .../distributed/near/GridNearCacheAdapter.java  |  111 +-
 .../distributed/near/GridNearCacheEntry.java    |   34 +-
 .../distributed/near/GridNearGetFuture.java     |   62 +-
 .../distributed/near/GridNearGetRequest.java    |  170 +-
 .../distributed/near/GridNearGetResponse.java   |    6 +-
 .../distributed/near/GridNearLockFuture.java    |   70 +-
 .../distributed/near/GridNearLockRequest.java   |  235 +-
 .../distributed/near/GridNearLockResponse.java  |   14 +-
 .../near/GridNearOffHeapCacheEntry.java         |   60 -
 ...arOptimisticSerializableTxPrepareFuture.java |  280 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |  160 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |   20 +-
 .../GridNearPessimisticTxPrepareFuture.java     |  242 +-
 .../near/GridNearSingleGetRequest.java          |   83 +-
 .../near/GridNearSingleGetResponse.java         |    8 +-
 .../near/GridNearTransactionalCache.java        |   23 +-
 .../near/GridNearTxFinishFuture.java            |  196 +-
 .../near/GridNearTxFinishRequest.java           |  176 +-
 .../near/GridNearTxFinishResponse.java          |   38 +-
 .../cache/distributed/near/GridNearTxLocal.java | 2773 +++++++++-
 .../near/GridNearTxPrepareFutureAdapter.java    |   55 +-
 .../near/GridNearTxPrepareRequest.java          |  256 +-
 .../near/GridNearTxPrepareResponse.java         |  102 +-
 .../distributed/near/GridNearTxRemote.java      |   12 +-
 .../distributed/near/GridNearUnlockRequest.java |   22 +-
 .../distributed/near/IgniteTxMappingsImpl.java  |    4 +-
 .../near/IgniteTxMappingsSingleImpl.java        |    6 +-
 .../cache/dr/GridOsCacheDrManager.java          |    2 +-
 .../extras/GridCacheAttributesEntryExtras.java  |    7 +-
 .../GridCacheAttributesMvccEntryExtras.java     |    5 +-
 ...dCacheAttributesMvccObsoleteEntryExtras.java |    5 +-
 ...cheAttributesMvccObsoleteTtlEntryExtras.java |    7 +-
 .../GridCacheAttributesMvccTtlEntryExtras.java  |    7 +-
 .../GridCacheAttributesObsoleteEntryExtras.java |    5 +-
 ...idCacheAttributesObsoleteTtlEntryExtras.java |    7 +-
 .../GridCacheAttributesTtlEntryExtras.java      |    7 +-
 .../cache/extras/GridCacheMvccEntryExtras.java  |    3 +-
 .../GridCacheMvccObsoleteEntryExtras.java       |    5 +-
 .../GridCacheMvccObsoleteTtlEntryExtras.java    |    7 +-
 .../extras/GridCacheMvccTtlEntryExtras.java     |    7 +-
 .../extras/GridCacheObsoleteEntryExtras.java    |    3 +-
 .../extras/GridCacheObsoleteTtlEntryExtras.java |    7 +-
 .../cache/extras/GridCacheTtlEntryExtras.java   |    5 +-
 .../processors/cache/local/GridLocalCache.java  |   77 +-
 .../cache/local/GridLocalCacheEntry.java        |   26 +-
 .../cache/local/GridLocalLockFuture.java        |   55 +-
 .../local/atomic/GridLocalAtomicCache.java      |  285 +-
 .../cache/persistence/CacheDataRow.java         |   57 +
 .../cache/persistence/CacheDataRowAdapter.java  |  593 +++
 .../cache/persistence/CacheSearchRow.java       |   45 +
 .../persistence/CheckpointLockStateChecker.java |   28 +
 .../cache/persistence/DataStructure.java        |  384 ++
 .../cache/persistence/DbCheckpointListener.java |   38 +
 .../FullPageIdIterableComparator.java           |   51 +
 .../GridCacheDatabaseSharedManager.java         | 3097 +++++++++++
 .../persistence/GridCacheOffheapManager.java    | 1321 +++++
 .../IgniteCacheDatabaseSharedManager.java       |  964 ++++
 .../persistence/IgniteCacheSnapshotManager.java |  140 +
 .../cache/persistence/MemoryMetricsImpl.java    |  284 ++
 .../persistence/MemoryMetricsMXBeanImpl.java    |  131 +
 .../persistence/MemoryMetricsSnapshot.java      |  112 +
 .../cache/persistence/MemoryPolicy.java         |   83 +
 .../processors/cache/persistence/MetaStore.java |   51 +
 .../cache/persistence/MetadataStorage.java      |  417 ++
 .../persistence/PersistenceMetricsImpl.java     |  297 ++
 .../persistence/PersistenceMetricsSnapshot.java |  144 +
 .../processors/cache/persistence/RootPage.java  |   62 +
 .../processors/cache/persistence/RowStore.java  |  107 +
 .../evict/FairFifoPageEvictionTracker.java      |   76 +
 .../evict/NoOpPageEvictionTracker.java          |   50 +
 .../evict/PageAbstractEvictionTracker.java      |  171 +
 .../persistence/evict/PageEvictionTracker.java  |   52 +
 .../evict/Random2LruPageEvictionTracker.java    |  180 +
 .../evict/RandomLruPageEvictionTracker.java     |  159 +
 .../cache/persistence/file/FilePageStore.java   |  529 ++
 .../persistence/file/FilePageStoreManager.java  |  671 +++
 .../cache/persistence/freelist/FreeList.java    |   51 +
 .../persistence/freelist/FreeListImpl.java      |  599 +++
 .../cache/persistence/freelist/PagesList.java   | 1482 ++++++
 .../freelist/io/PagesListMetaIO.java            |  186 +
 .../freelist/io/PagesListNodeIO.java            |  231 +
 .../pagemem/CheckpointMetricsTracker.java       |  183 +
 .../persistence/pagemem/EvictCandidate.java     |   77 +
 .../persistence/pagemem/FullPageIdTable.java    |  556 ++
 .../cache/persistence/pagemem/PageMemoryEx.java |  149 +
 .../persistence/pagemem/PageMemoryImpl.java     | 2322 +++++++++
 .../cache/persistence/tree/BPlusTree.java       | 4808 ++++++++++++++++++
 .../cache/persistence/tree/io/BPlusIO.java      |  403 ++
 .../cache/persistence/tree/io/BPlusInnerIO.java |  180 +
 .../cache/persistence/tree/io/BPlusLeafIO.java  |   56 +
 .../cache/persistence/tree/io/BPlusMetaIO.java  |  182 +
 .../persistence/tree/io/CacheVersionIO.java     |  255 +
 .../cache/persistence/tree/io/DataPageIO.java   | 1450 ++++++
 .../persistence/tree/io/DataPagePayload.java    |   64 +
 .../cache/persistence/tree/io/IOVersions.java   |   99 +
 .../cache/persistence/tree/io/PageIO.java       |  548 ++
 .../cache/persistence/tree/io/PageMetaIO.java   |  222 +
 .../tree/io/PagePartitionCountersIO.java        |  175 +
 .../tree/io/PagePartitionMetaIO.java            |  163 +
 .../persistence/tree/io/TrackingPageIO.java     |  334 ++
 .../cache/persistence/tree/reuse/ReuseBag.java  |   33 +
 .../cache/persistence/tree/reuse/ReuseList.java |   43 +
 .../persistence/tree/reuse/ReuseListImpl.java   |   95 +
 .../persistence/tree/util/PageHandler.java      |  509 ++
 .../persistence/tree/util/PageLockListener.java |   69 +
 .../wal/ByteBufferBackedDataInput.java          |   40 +
 .../wal/ByteBufferBackedDataInputImpl.java      |  173 +
 .../cache/persistence/wal/FileInput.java        |  453 ++
 .../cache/persistence/wal/FileWALPointer.java   |  139 +
 .../wal/FileWriteAheadLogManager.java           | 2540 +++++++++
 .../cache/persistence/wal/RecordSerializer.java |   52 +
 .../persistence/wal/SegmentEofException.java    |   37 +
 .../IgniteDataIntegrityViolationException.java  |   41 +
 .../persistence/wal/crc/PureJavaCrc32.java      |  655 +++
 .../persistence/wal/record/HeaderRecord.java    |   50 +
 .../wal/serializer/RecordV1Serializer.java      | 1654 ++++++
 .../query/GridCacheDistributedQueryFuture.java  |   44 +-
 .../query/GridCacheDistributedQueryManager.java |   33 +-
 .../cache/query/GridCacheLocalQueryFuture.java  |    3 +-
 .../cache/query/GridCacheQueryAdapter.java      |   13 +-
 .../query/GridCacheQueryFutureAdapter.java      |   49 +-
 .../cache/query/GridCacheQueryManager.java      |  972 +---
 .../cache/query/GridCacheQueryRequest.java      |   19 +-
 .../cache/query/GridCacheQueryResponse.java     |   55 +-
 .../cache/query/GridCacheSqlIndexMetadata.java  |    3 +-
 .../cache/query/GridCacheSqlMetadata.java       |    3 +-
 .../cache/query/GridCacheSqlQuery.java          |  224 +-
 .../cache/query/IgniteQueryErrorCode.java       |   27 +-
 .../CacheContinuousQueryAcknowledgeBuffer.java  |  120 +
 .../CacheContinuousQueryBatchAck.java           |   10 +-
 .../CacheContinuousQueryDeployableObject.java   |  110 +
 .../continuous/CacheContinuousQueryEntry.java   |  119 +-
 .../continuous/CacheContinuousQueryEvent.java   |    3 +-
 .../CacheContinuousQueryEventBuffer.java        |  486 ++
 .../continuous/CacheContinuousQueryHandler.java |  852 +---
 .../CacheContinuousQueryHandlerV2.java          |    6 +-
 .../CacheContinuousQueryListener.java           |   20 +
 .../continuous/CacheContinuousQueryManager.java |  178 +-
 .../CacheContinuousQueryPartitionRecovery.java  |  267 +
 .../query/continuous/CounterSkipContext.java    |   78 +
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   10 +-
 .../cache/ratemetrics/HitRateMetrics.java       |  179 +
 .../ratemetrics/HitRateMetricsSandbox.java      |   95 +
 .../cache/store/CacheOsStoreManager.java        |    3 +
 .../cache/store/CacheStoreManager.java          |   15 +-
 .../store/GridCacheStoreManagerAdapter.java     |  247 +-
 .../cache/store/GridCacheWriteBehindStore.java  |  639 ++-
 .../cache/transactions/IgniteInternalTx.java    |   80 +-
 .../transactions/IgniteTransactionsImpl.java    |   16 +-
 .../cache/transactions/IgniteTxAdapter.java     |  230 +-
 .../cache/transactions/IgniteTxEntry.java       |  134 +-
 .../cache/transactions/IgniteTxHandler.java     |  376 +-
 .../IgniteTxImplicitSingleStateImpl.java        |   31 +-
 .../cache/transactions/IgniteTxKey.java         |    2 +-
 .../transactions/IgniteTxLocalAdapter.java      | 2828 +---------
 .../cache/transactions/IgniteTxLocalEx.java     |  145 +-
 .../cache/transactions/IgniteTxManager.java     |  364 +-
 .../cache/transactions/IgniteTxRemoteEx.java    |   11 +
 .../IgniteTxRemoteSingleStateImpl.java          |    2 +-
 .../IgniteTxRemoteStateAdapter.java             |   17 +-
 .../cache/transactions/IgniteTxState.java       |   19 +-
 .../cache/transactions/IgniteTxStateImpl.java   |  101 +-
 .../transactions/TransactionProxyImpl.java      |   52 +-
 .../cache/transactions/TxDeadlock.java          |   21 +-
 .../cache/transactions/TxDeadlockDetection.java |    5 +-
 .../cache/transactions/TxEntryValueHolder.java  |    2 +-
 .../processors/cache/transactions/TxLock.java   |    4 +-
 .../cache/transactions/TxLockList.java          |    2 +-
 .../cache/transactions/TxLocksRequest.java      |   22 +-
 .../cache/transactions/TxLocksResponse.java     |   67 +-
 .../version/CacheVersionConflictResolver.java   |    2 +
 .../GridCacheLazyPlainVersionedEntry.java       |    5 +-
 .../version/GridCachePlainVersionedEntry.java   |    8 +-
 .../version/GridCacheRawVersionedEntry.java     |   12 +-
 .../cache/version/GridCacheVersion.java         |   51 +-
 .../GridCacheVersionConflictContext.java        |   16 +-
 .../cache/version/GridCacheVersionEx.java       |   21 +-
 .../cache/version/GridCacheVersionManager.java  |   14 +-
 .../cache/version/GridCacheVersionedEntry.java  |   11 +-
 .../cacheobject/IgniteCacheObjectProcessor.java |   56 +-
 .../IgniteCacheObjectProcessorImpl.java         |  171 +-
 .../processors/cacheobject/NoOpBinary.java      |   12 +
 .../clock/GridClockDeltaSnapshot.java           |  235 -
 .../clock/GridClockDeltaSnapshotMessage.java    |  154 -
 .../processors/clock/GridClockDeltaVersion.java |  194 -
 .../processors/clock/GridClockMessage.java      |  171 -
 .../processors/clock/GridClockServer.java       |  222 -
 .../processors/clock/GridClockSource.java       |   30 -
 .../clock/GridClockSyncProcessor.java           |  481 --
 .../processors/clock/GridJvmClockSource.java    |   28 -
 .../processors/closure/AffinityTask.java        |    6 -
 .../closure/GridClosureProcessor.java           |  602 +--
 .../processors/cluster/ClusterProcessor.java    |  315 +-
 .../cluster/GridClusterStateProcessor.java      | 1223 +++++
 .../processors/cluster/GridUpdateNotifier.java  |   66 +-
 .../cluster/HttpIgniteUpdatesChecker.java       |   82 +
 .../cluster/IgniteChangeGlobalStateSupport.java |   42 +
 .../continuous/GridContinuousBatchAdapter.java  |    2 +-
 .../continuous/GridContinuousHandler.java       |   10 +-
 .../continuous/GridContinuousMessage.java       |    2 +-
 .../continuous/GridContinuousProcessor.java     |   46 +-
 .../continuous/GridContinuousQueryBatch.java    |   16 +-
 .../StartRoutineAckDiscoveryMessage.java        |   13 +-
 .../StartRoutineDiscoveryMessage.java           |   19 +-
 .../datastreamer/DataStreamProcessor.java       |    8 +-
 .../datastreamer/DataStreamerEntry.java         |    2 +-
 .../datastreamer/DataStreamerFuture.java        |    3 -
 .../datastreamer/DataStreamerImpl.java          |  129 +-
 .../datastreamer/DataStreamerRequest.java       |    2 +-
 .../datastreamer/DataStreamerResponse.java      |    2 +-
 .../AtomicDataStructureValue.java               |   35 +
 .../CacheDataStructuresCacheKey.java            |   64 -
 .../CacheDataStructuresConfigurationKey.java    |   64 -
 .../datastructures/DataStructureInfoKey.java    |   58 +
 .../datastructures/DataStructureType.java       |  105 +
 .../datastructures/DataStructuresCacheKey.java  |   44 +
 .../datastructures/DataStructuresProcessor.java | 2214 +++-----
 .../DistributedCollectionMetadata.java          |   90 +
 .../GridAtomicCacheQueueImpl.java               |    7 +-
 .../datastructures/GridCacheAtomicLongImpl.java |  631 ++-
 .../GridCacheAtomicLongValue.java               |    8 +-
 .../GridCacheAtomicReferenceImpl.java           |  369 +-
 .../GridCacheAtomicReferenceValue.java          |    9 +-
 .../GridCacheAtomicSequenceImpl.java            |  240 +-
 .../GridCacheAtomicSequenceValue.java           |    8 +-
 .../GridCacheAtomicStampedImpl.java             |  362 +-
 .../GridCacheAtomicStampedValue.java            |    9 +-
 .../GridCacheCountDownLatchImpl.java            |   87 +-
 .../GridCacheCountDownLatchValue.java           |   23 +-
 .../datastructures/GridCacheInternalKey.java    |    6 +-
 .../GridCacheInternalKeyImpl.java               |   36 +-
 .../datastructures/GridCacheLockImpl.java       |  128 +-
 .../datastructures/GridCacheLockState.java      |   23 +-
 .../datastructures/GridCacheQueueAdapter.java   |   49 +-
 .../datastructures/GridCacheQueueProxy.java     |  310 +-
 .../datastructures/GridCacheSemaphoreImpl.java  |  352 +-
 .../datastructures/GridCacheSemaphoreState.java |   44 +-
 .../datastructures/GridCacheSetImpl.java        |   54 +-
 .../datastructures/GridCacheSetProxy.java       |  170 +-
 .../GridTransactionalCacheQueueImpl.java        |   18 +-
 .../VolatileAtomicDataStructureValue.java       |   32 +
 .../processors/hadoop/HadoopClasspathUtils.java |    3 +-
 .../internal/processors/hadoop/HadoopJobId.java |   12 +-
 .../processors/hadoop/HadoopPayloadAware.java   |   28 -
 .../shuffle/HadoopDirectShuffleMessage.java     |   24 +-
 .../hadoop/shuffle/HadoopShuffleAck.java        |   12 +-
 .../shuffle/HadoopShuffleFinishRequest.java     |    2 +-
 .../shuffle/HadoopShuffleFinishResponse.java    |    2 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |   20 +-
 .../processors/igfs/IgfsAckMessage.java         |    2 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java |   56 +-
 .../internal/processors/igfs/IgfsBlockKey.java  |    3 +-
 .../processors/igfs/IgfsBlocksMessage.java      |    2 +-
 .../internal/processors/igfs/IgfsContext.java   |   21 +-
 .../processors/igfs/IgfsDataManager.java        |  115 +-
 .../processors/igfs/IgfsDeleteMessage.java      |    2 +-
 .../ignite/internal/processors/igfs/IgfsEx.java |    7 -
 .../processors/igfs/IgfsFileAffinityRange.java  |    2 +-
 .../igfs/IgfsFragmentizerManager.java           |    8 +-
 .../igfs/IgfsFragmentizerRequest.java           |    2 +-
 .../igfs/IgfsFragmentizerResponse.java          |    2 +-
 .../processors/igfs/IgfsHandshakeResponse.java  |   22 +-
 .../internal/processors/igfs/IgfsImpl.java      |  161 +-
 .../processors/igfs/IgfsIpcHandler.java         |   24 +-
 .../processors/igfs/IgfsMetaManager.java        |  106 +-
 .../processors/igfs/IgfsModeResolver.java       |   91 +-
 .../processors/igfs/IgfsNoopProcessor.java      |    6 +-
 .../internal/processors/igfs/IgfsPaths.java     |  152 -
 .../internal/processors/igfs/IgfsProcessor.java |  180 +-
 .../processors/igfs/IgfsProcessorAdapter.java   |    4 +-
 .../igfs/IgfsSecondaryFileSystemImpl.java       |    4 +-
 .../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     |  216 +-
 .../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 |    8 +-
 .../igfs/client/IgfsClientSizeCallable.java     |    5 +-
 .../igfs/client/IgfsClientSummaryCallable.java  |    5 +-
 .../igfs/client/IgfsClientUpdateCallable.java   |    6 +-
 .../meta/IgfsClientMetaIdsForPathCallable.java  |    5 +-
 .../meta/IgfsClientMetaInfoForPathCallable.java |    5 +-
 .../meta/IgfsClientMetaUnlockCallable.java      |    8 +-
 .../IgfsMetaDirectoryListingAddProcessor.java   |    5 +-
 .../secondary/local/LocalFileSystemUtils.java   |   25 +
 .../processors/job/GridJobProcessor.java        |   58 +-
 .../internal/processors/job/GridJobWorker.java  |   25 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |    7 +-
 .../marshaller/ClientRequestFuture.java         |    4 +-
 .../GridMarshallerMappingProcessor.java         |   50 +-
 .../marshaller/MappingUpdatedListener.java      |   29 +
 .../marshaller/MarshallerMappingTransport.java  |   17 +-
 .../MissingMappingRequestMessage.java           |    8 +-
 .../MissingMappingResponseMessage.java          |   19 +-
 .../internal/processors/odbc/IgniteTypes.java   |   69 -
 .../processors/odbc/OdbcBufferedParser.java     |   81 -
 .../processors/odbc/OdbcColumnMeta.java         |  110 -
 .../processors/odbc/OdbcHandshakeRequest.java   |   83 -
 .../processors/odbc/OdbcHandshakeResult.java    |   73 -
 .../processors/odbc/OdbcMessageParser.java      |  311 --
 .../processors/odbc/OdbcNioListener.java        |  179 -
 .../processors/odbc/OdbcNioServerBuffer.java    |  114 -
 .../internal/processors/odbc/OdbcProcessor.java |  200 -
 .../processors/odbc/OdbcProtocolVersion.java    |  125 -
 .../processors/odbc/OdbcQueryCloseRequest.java  |   49 -
 .../processors/odbc/OdbcQueryCloseResult.java   |   40 -
 .../odbc/OdbcQueryExecuteRequest.java           |   78 -
 .../processors/odbc/OdbcQueryExecuteResult.java |   54 -
 .../processors/odbc/OdbcQueryFetchRequest.java  |   61 -
 .../processors/odbc/OdbcQueryFetchResult.java   |   66 -
 .../odbc/OdbcQueryGetColumnsMetaRequest.java    |   74 -
 .../odbc/OdbcQueryGetColumnsMetaResult.java     |   42 -
 .../odbc/OdbcQueryGetParamsMetaRequest.java     |   60 -
 .../odbc/OdbcQueryGetParamsMetaResult.java      |   40 -
 .../odbc/OdbcQueryGetTablesMetaRequest.java     |   85 -
 .../odbc/OdbcQueryGetTablesMetaResult.java      |   42 -
 .../internal/processors/odbc/OdbcRequest.java   |   61 -
 .../processors/odbc/OdbcRequestHandler.java     |  530 --
 .../internal/processors/odbc/OdbcResponse.java  |   96 -
 .../internal/processors/odbc/OdbcTableMeta.java |   88 -
 .../internal/processors/odbc/OdbcTypes.java     |  131 -
 .../internal/processors/odbc/OdbcUtils.java     |  141 -
 .../odbc/SqlListenerBufferedParser.java         |   81 +
 .../odbc/SqlListenerConnectionContext.java      |   56 +
 .../processors/odbc/SqlListenerDataTypes.java   |   69 +
 .../odbc/SqlListenerMessageParser.java          |   39 +
 .../processors/odbc/SqlListenerNioListener.java |  269 +
 .../odbc/SqlListenerNioServerBuffer.java        |  114 +
 .../processors/odbc/SqlListenerProcessor.java   |  277 +
 .../odbc/SqlListenerProtocolVersion.java        |  116 +
 .../processors/odbc/SqlListenerRequest.java     |   43 +
 .../odbc/SqlListenerRequestHandler.java         |   39 +
 .../processors/odbc/SqlListenerResponse.java    |   76 +
 .../processors/odbc/SqlListenerUtils.java       |  250 +
 .../odbc/escape/OdbcEscapeParseResult.java      |   73 -
 .../processors/odbc/escape/OdbcEscapeToken.java |   61 -
 .../processors/odbc/escape/OdbcEscapeType.java  |  112 -
 .../processors/odbc/escape/OdbcEscapeUtils.java |  440 --
 .../processors/odbc/jdbc/JdbcColumnMeta.java    |  129 +
 .../processors/odbc/jdbc/JdbcMessageParser.java |   87 +
 .../odbc/jdbc/JdbcQueryCloseRequest.java        |   72 +
 .../processors/odbc/jdbc/JdbcQueryCursor.java   |  135 +
 .../odbc/jdbc/JdbcQueryExecuteRequest.java      |  147 +
 .../odbc/jdbc/JdbcQueryExecuteResult.java       |  150 +
 .../odbc/jdbc/JdbcQueryFetchRequest.java        |   87 +
 .../odbc/jdbc/JdbcQueryFetchResult.java         |   84 +
 .../odbc/jdbc/JdbcQueryMetadataRequest.java     |   73 +
 .../odbc/jdbc/JdbcQueryMetadataResult.java      |   93 +
 .../odbc/jdbc/JdbcRawBinarylizable.java         |   44 +
 .../processors/odbc/jdbc/JdbcRequest.java       |  108 +
 .../odbc/jdbc/JdbcRequestHandler.java           |  310 ++
 .../processors/odbc/jdbc/JdbcResponse.java      |  104 +
 .../processors/odbc/jdbc/JdbcResult.java        |   91 +
 .../processors/odbc/jdbc/JdbcUtils.java         |   73 +
 .../processors/odbc/odbc/OdbcColumnMeta.java    |  110 +
 .../processors/odbc/odbc/OdbcMessageParser.java |  308 ++
 .../odbc/odbc/OdbcQueryCloseRequest.java        |   49 +
 .../odbc/odbc/OdbcQueryCloseResult.java         |   40 +
 .../odbc/odbc/OdbcQueryExecuteBatchRequest.java |   95 +
 .../odbc/odbc/OdbcQueryExecuteBatchResult.java  |   75 +
 .../odbc/odbc/OdbcQueryExecuteRequest.java      |   80 +
 .../odbc/odbc/OdbcQueryExecuteResult.java       |   54 +
 .../odbc/odbc/OdbcQueryFetchRequest.java        |   61 +
 .../odbc/odbc/OdbcQueryFetchResult.java         |   66 +
 .../odbc/OdbcQueryGetColumnsMetaRequest.java    |   74 +
 .../odbc/OdbcQueryGetColumnsMetaResult.java     |   42 +
 .../odbc/OdbcQueryGetParamsMetaRequest.java     |   61 +
 .../odbc/odbc/OdbcQueryGetParamsMetaResult.java |   40 +
 .../odbc/OdbcQueryGetTablesMetaRequest.java     |   85 +
 .../odbc/odbc/OdbcQueryGetTablesMetaResult.java |   42 +
 .../processors/odbc/odbc/OdbcRequest.java       |   63 +
 .../odbc/odbc/OdbcRequestHandler.java           |  634 +++
 .../processors/odbc/odbc/OdbcResponse.java      |   69 +
 .../processors/odbc/odbc/OdbcTableMeta.java     |   88 +
 .../processors/odbc/odbc/OdbcTypes.java         |  131 +
 .../processors/odbc/odbc/OdbcUtils.java         |  142 +
 .../odbc/odbc/escape/OdbcEscapeParseResult.java |   73 +
 .../odbc/odbc/escape/OdbcEscapeToken.java       |   61 +
 .../odbc/odbc/escape/OdbcEscapeType.java        |  112 +
 .../odbc/odbc/escape/OdbcEscapeUtils.java       |  441 ++
 .../platform/PlatformAbstractTarget.java        |   32 +-
 .../platform/PlatformAsyncResult.java           |   41 +
 .../platform/PlatformAsyncTarget.java           |   44 -
 .../platform/PlatformContextImpl.java           |  140 +-
 .../processors/platform/PlatformIgnition.java   |   34 +-
 .../platform/PlatformProcessorImpl.java         |   11 +-
 .../processors/platform/PlatformTarget.java     |   10 +
 .../platform/PlatformTargetProxy.java           |   23 +-
 .../platform/PlatformTargetProxyImpl.java       |   67 +-
 .../binary/PlatformBinaryProcessor.java         |   65 +-
 .../platform/cache/PlatformCache.java           |  292 +-
 .../cache/PlatformCacheEntryProcessorImpl.java  |    6 +-
 .../callback/PlatformCallbackGateway.java       |   65 +-
 .../platform/callback/PlatformCallbackOp.java   |    3 +
 .../platform/cluster/PlatformClusterGroup.java  |   86 +
 .../platform/compute/PlatformAbstractJob.java   |    2 +-
 .../platform/compute/PlatformCompute.java       |   24 +-
 .../dotnet/PlatformDotNetCacheStore.java        |   12 +-
 .../PlatformDotNetConfigurationClosure.java     |   72 +-
 .../dotnet/PlatformDotNetConfigurationEx.java   |   21 +-
 ...formDotNetEntityFrameworkCacheExtension.java |    8 +-
 .../platform/events/PlatformEvents.java         |   70 +-
 .../memory/PlatformOutputStreamImpl.java        |    8 +-
 .../platform/messaging/PlatformMessaging.java   |   35 +-
 .../cache/PlatformCachePluginConfiguration.java |    7 -
 .../cache/PlatformCachePluginProvider.java      |  123 -
 .../platform/services/PlatformServices.java     |   95 +-
 .../transactions/PlatformTransactions.java      |    9 +-
 .../utils/PlatformConfigurationUtils.java       |  686 ++-
 .../processors/plugin/CachePluginManager.java   |   20 +-
 .../plugin/IgnitePluginProcessor.java           |    3 +-
 .../internal/processors/pool/PoolProcessor.java |   40 +-
 .../processors/port/GridPortProcessor.java      |    2 +-
 .../query/CacheQueryObjectValueContext.java     |   64 +
 .../query/GridQueryCacheObjectsIterator.java    |   16 +-
 .../query/GridQueryIndexDescriptor.java         |   16 +-
 .../processors/query/GridQueryIndexType.java    |   32 -
 .../processors/query/GridQueryIndexing.java     |  198 +-
 .../processors/query/GridQueryProcessor.java    | 4054 +++++++--------
 .../query/GridQueryTypeDescriptor.java          |   46 +
 .../processors/query/GridRunningQueryInfo.java  |  132 +
 .../processors/query/IgniteSQLException.java    |    7 +
 .../query/QueryIndexDescriptorImpl.java         |  147 +
 .../processors/query/QueryIndexKey.java         |   71 +
 .../internal/processors/query/QuerySchema.java  |  166 +
 .../processors/query/QueryTypeCandidate.java    |   66 +
 .../query/QueryTypeDescriptorImpl.java          |  459 ++
 .../processors/query/QueryTypeIdKey.java        |   94 +
 .../processors/query/QueryTypeNameKey.java      |   68 +
 .../internal/processors/query/QueryUtils.java   | 1218 +++++
 .../messages/GridQueryCancelRequest.java        |    2 +-
 .../twostep/messages/GridQueryFailResponse.java |   12 +-
 .../messages/GridQueryNextPageRequest.java      |   31 +-
 .../messages/GridQueryNextPageResponse.java     |   31 +-
 .../h2/twostep/messages/GridQueryRequest.java   |  368 --
 .../query/property/QueryBinaryProperty.java     |  269 +
 .../query/property/QueryClassProperty.java      |  130 +
 .../query/property/QueryFieldAccessor.java      |   67 +
 .../query/property/QueryMethodsAccessor.java    |   82 +
 .../query/property/QueryPropertyAccessor.java   |   53 +
 .../property/QueryReadOnlyMethodsAccessor.java  |   71 +
 .../query/schema/SchemaExchangeWorkerTask.java  |   53 +
 .../query/schema/SchemaIndexCacheVisitor.java   |   33 +
 .../schema/SchemaIndexCacheVisitorClosure.java  |   42 +
 .../schema/SchemaIndexCacheVisitorImpl.java     |  197 +
 .../SchemaIndexOperationCancellationToken.java  |   53 +
 .../SchemaNodeLeaveExchangeWorkerTask.java      |   53 +
 .../schema/SchemaOperationClientFuture.java     |   52 +
 .../query/schema/SchemaOperationException.java  |  138 +
 .../query/schema/SchemaOperationManager.java    |  292 ++
 .../query/schema/SchemaOperationWorker.java     |  205 +
 .../message/SchemaAbstractDiscoveryMessage.java |   70 +
 .../message/SchemaFinishDiscoveryMessage.java   |   98 +
 .../message/SchemaOperationStatusMessage.java   |  168 +
 .../message/SchemaProposeDiscoveryMessage.java  |  132 +
 .../operation/SchemaAbstractOperation.java      |   78 +
 .../operation/SchemaIndexAbstractOperation.java |   41 +
 .../operation/SchemaIndexCreateOperation.java   |   93 +
 .../operation/SchemaIndexDropOperation.java     |   69 +
 .../resource/GridResourceProcessor.java         |   12 +-
 .../processors/rest/GridRestCommand.java        |   11 +-
 .../processors/rest/GridRestProcessor.java      |   30 +-
 .../rest/client/message/GridClientNodeBean.java |   27 +-
 .../client/message/GridClientStateRequest.java  |   80 +
 .../handlers/GridRestCommandHandlerAdapter.java |    3 +
 .../handlers/cache/GridCacheCommandHandler.java |   47 +-
 .../cluster/GridChangeStateCommandHandler.java  |   90 +
 .../handlers/query/QueryCommandHandler.java     |   16 +-
 .../handlers/redis/GridRedisCommandHandler.java |    4 +-
 .../GridRedisConnectionCommandHandler.java      |   47 +-
 .../redis/GridRedisRestCommandHandler.java      |   40 +-
 .../redis/key/GridRedisDelCommandHandler.java   |    1 +
 .../key/GridRedisExistsCommandHandler.java      |    1 +
 .../server/GridRedisDbSizeCommandHandler.java   |    1 +
 .../string/GridRedisAppendCommandHandler.java   |    3 +
 .../string/GridRedisGetCommandHandler.java      |    1 +
 .../string/GridRedisGetRangeCommandHandler.java |    1 +
 .../string/GridRedisGetSetCommandHandler.java   |    1 +
 .../string/GridRedisIncrDecrCommandHandler.java |    2 +
 .../string/GridRedisMGetCommandHandler.java     |    1 +
 .../string/GridRedisMSetCommandHandler.java     |    1 +
 .../string/GridRedisSetCommandHandler.java      |   44 +-
 .../string/GridRedisSetRangeCommandHandler.java |    2 +
 .../string/GridRedisStrlenCommandHandler.java   |    1 +
 .../handlers/task/GridTaskCommandHandler.java   |    8 +-
 .../handlers/task/GridTaskResultRequest.java    |    2 +-
 .../handlers/task/GridTaskResultResponse.java   |    2 +-
 .../top/GridTopologyCommandHandler.java         |   19 +-
 .../version/GridVersionCommandHandler.java      |    2 +-
 .../tcp/GridTcpMemcachedNioListener.java        |   25 +-
 .../protocols/tcp/GridTcpRestNioListener.java   |   20 +
 .../rest/protocols/tcp/GridTcpRestProtocol.java |    2 +-
 .../protocols/tcp/redis/GridRedisCommand.java   |    2 +
 .../protocols/tcp/redis/GridRedisMessage.java   |    8 +
 .../tcp/redis/GridRedisNioListener.java         |   26 +-
 .../request/GridRestChangeStateRequest.java     |   57 +
 .../processors/security/SecurityContext.java    |    9 +
 .../processors/security/SecurityUtils.java      |   92 +
 .../service/GridServiceDeploymentFuture.java    |    3 -
 .../service/GridServiceProcessor.java           |  524 +-
 .../processors/service/GridServiceProxy.java    |   14 +-
 .../session/GridTaskSessionProcessor.java       |   12 +-
 .../processors/task/GridTaskProcessor.java      |  100 +-
 .../task/GridTaskThreadContextKey.java          |   10 +-
 .../processors/task/GridTaskWorker.java         |   40 +-
 .../timeout/GridTimeoutProcessor.java           |    6 +-
 .../suggestions/GridPerformanceSuggestions.java |  105 +
 .../JvmConfigurationSuggestions.java            |  104 +
 .../suggestions/OsConfigurationSuggestions.java |  127 +
 .../internal/suggestions/package-info.java      |   21 +
 .../org/apache/ignite/internal/util/F0.java     |  196 +-
 .../apache/ignite/internal/util/GridArrays.java |  116 +
 .../ignite/internal/util/GridBusyLock.java      |    2 +-
 .../ignite/internal/util/GridByteArrayList.java |    2 +-
 .../util/GridCursorIteratorWrapper.java         |   52 +
 .../apache/ignite/internal/util/GridDebug.java  |    2 +-
 .../ignite/internal/util/GridIntIterator.java   |   33 +
 .../ignite/internal/util/GridIntList.java       |  603 +++
 .../ignite/internal/util/GridLongList.java      |    2 +-
 .../internal/util/GridMessageCollection.java    |    2 +-
 .../util/GridMultiCollectionWrapper.java        |  186 +
 .../internal/util/GridPartitionStateMap.java    |  222 +
 .../ignite/internal/util/GridStringBuilder.java |   19 +
 .../apache/ignite/internal/util/GridUnsafe.java |   67 +-
 .../internal/util/IgniteExceptionRegistry.java  |    3 +-
 .../apache/ignite/internal/util/IgniteTree.java |  134 +
 .../ignite/internal/util/IgniteUtils.java       |  861 ++--
 .../internal/util/OffheapReadWriteLock.java     |  665 +++
 .../util/StripedCompositeReadWriteLock.java     |   50 +-
 .../ignite/internal/util/StripedExecutor.java   |  101 +-
 .../internal/util/UUIDCollectionMessage.java    |    2 +-
 .../util/future/AsyncFutureListener.java        |   57 +
 .../internal/util/future/CountDownFuture.java   |   81 +
 .../util/future/GridCompoundFuture.java         |   56 +-
 .../util/future/GridEmbeddedFuture.java         |    3 -
 .../util/future/GridFinishedFuture.java         |   13 -
 .../internal/util/future/GridFutureAdapter.java |  479 +-
 .../internal/util/future/IgniteFutureImpl.java  |   43 +-
 .../util/future/IgniteRemoteMapTask.java        |  142 +
 .../internal/util/gridify/GridifyUtils.java     |    6 +-
 .../internal/util/ipc/IpcToNioAdapter.java      |    7 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   22 +-
 .../ignite/internal/util/lang/GridCursor.java   |   41 +
 .../ignite/internal/util/lang/GridFunc.java     | 1826 +------
 .../internal/util/lang/GridTreePrinter.java     |   81 +
 .../ignite/internal/util/lang/GridTupleV.java   |  195 -
 .../lang/gridfunc/AlwaysFalsePredicate.java     |   46 +
 .../util/lang/gridfunc/AlwaysTruePredicate.java |   46 +
 .../util/lang/gridfunc/AlwaysTrueReducer.java   |   56 +
 .../gridfunc/AtomicIntegerFactoryCallable.java  |   40 +
 .../gridfunc/CacheEntryGetValueClosure.java     |   42 +
 .../gridfunc/CacheEntryHasPeekPredicate.java    |   41 +
 .../lang/gridfunc/ClusterNodeGetIdClosure.java  |   41 +
 .../ConcurrentDequeFactoryCallable.java         |   40 +
 .../ConcurrentHashSetFactoryCallable.java       |   40 +
 .../gridfunc/ConcurrentMapFactoryCallable.java  |   41 +
 .../lang/gridfunc/ContainsNodeIdsPredicate.java |   52 +
 .../util/lang/gridfunc/ContainsPredicate.java   |   55 +
 .../gridfunc/EntryByKeyEvaluationPredicate.java |   53 +
 .../gridfunc/EqualsClusterNodeIdPredicate.java  |   51 +
 .../util/lang/gridfunc/EqualsUuidPredicate.java |   50 +
 .../lang/gridfunc/FlatCollectionWrapper.java    |   66 +
 .../util/lang/gridfunc/FlatIterator.java        |  104 +
 .../util/lang/gridfunc/HasEqualIdPredicate.java |   51 +
 .../lang/gridfunc/HasNotEqualIdPredicate.java   |   51 +
 .../util/lang/gridfunc/IdentityClosure.java     |   39 +
 .../util/lang/gridfunc/IntSumReducer.java       |   51 +
 .../util/lang/gridfunc/IsAllPredicate.java      |   52 +
 .../util/lang/gridfunc/IsNotAllPredicate.java   |   52 +
 .../util/lang/gridfunc/IsNotNullPredicate.java  |   44 +
 .../util/lang/gridfunc/LongSumReducer.java      |   51 +
 .../util/lang/gridfunc/MapFactoryCallable.java  |   41 +
 .../util/lang/gridfunc/MultipleIterator.java    |  106 +
 .../util/lang/gridfunc/NoOpClosure.java         |   39 +
 .../lang/gridfunc/NotContainsPredicate.java     |   54 +
 .../util/lang/gridfunc/NotEqualPredicate.java   |   53 +
 .../lang/gridfunc/PredicateCollectionView.java  |   73 +
 .../util/lang/gridfunc/PredicateMapView.java    |  115 +
 .../util/lang/gridfunc/PredicateSetView.java    |  147 +
 .../lang/gridfunc/ReadOnlyCollectionView.java   |   89 +
 .../lang/gridfunc/ReadOnlyCollectionView2X.java |   94 +
 .../lang/gridfunc/RunnableWrapperClosure.java   |   51 +
 .../util/lang/gridfunc/SetFactoryCallable.java  |   41 +
 .../util/lang/gridfunc/StringConcatReducer.java |   79 +
 .../util/lang/gridfunc/ToStringClosure.java     |   42 +
 .../lang/gridfunc/TransformCollectionView.java  |   74 +
 .../gridfunc/TransformFilteringIterator.java    |  138 +
 .../util/lang/gridfunc/TransformMapView.java    |  162 +
 .../util/lang/gridfunc/TransformMapView2.java   |  165 +
 .../util/lang/gridfunc/package-info.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 +-
 .../util/nio/GridNioBackPressureControl.java    |   39 +-
 .../internal/util/nio/GridNioCodecFilter.java   |    9 +-
 .../util/nio/GridNioEmbeddedFuture.java         |    8 +-
 .../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    |   19 +-
 .../util/nio/GridNioMessageTracker.java         |    7 +
 .../util/nio/GridNioRecoveryDescriptor.java     |    1 +
 .../ignite/internal/util/nio/GridNioServer.java |  415 +-
 .../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 +-
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |   14 +-
 .../internal/util/snaptree/SnapTreeMap.java     |   10 +-
 .../util/tostring/GridToStringBuilder.java      |  421 +-
 .../util/tostring/GridToStringThreadLocal.java  |    6 +-
 .../ignite/internal/util/worker/GridWorker.java |   24 +-
 .../internal/util/worker/GridWorkerFuture.java  |    3 -
 .../internal/visor/VisorDataTransferObject.java |  118 +
 .../visor/VisorDataTransferObjectInput.java     |  156 +
 .../visor/VisorDataTransferObjectOutput.java    |  141 +
 .../ignite/internal/visor/VisorEither.java      |  103 +
 .../internal/visor/VisorMultiNodeTask.java      |   15 +-
 .../ignite/internal/visor/VisorOneNodeTask.java |    5 +-
 .../internal/visor/VisorTaskArgument.java       |   53 +-
 .../visor/binary/VisorBinaryMetadata.java       |  138 +
 .../VisorBinaryMetadataCollectorTask.java       |   72 +
 .../VisorBinaryMetadataCollectorTaskArg.java    |   71 +
 .../VisorBinaryMetadataCollectorTaskResult.java |   87 +
 .../visor/binary/VisorBinaryMetadataField.java  |  101 +
 .../ignite/internal/visor/cache/VisorCache.java |  326 +-
 .../cache/VisorCacheAffinityConfiguration.java  |   93 +-
 .../visor/cache/VisorCacheAffinityNodeTask.java |   13 +-
 .../cache/VisorCacheAffinityNodeTaskArg.java    |   86 +
 .../cache/VisorCacheAggregatedMetrics.java      |  207 +-
 .../visor/cache/VisorCacheClearTask.java        |  128 +-
 .../visor/cache/VisorCacheClearTaskArg.java     |   72 +
 .../visor/cache/VisorCacheClearTaskResult.java  |   85 +
 .../visor/cache/VisorCacheConfiguration.java    |  493 +-
 .../VisorCacheConfigurationCollectorJob.java    |   27 +-
 .../VisorCacheConfigurationCollectorTask.java   |    7 +-
 ...VisorCacheConfigurationCollectorTaskArg.java |   73 +
 .../cache/VisorCacheDefaultConfiguration.java   |   58 -
 .../cache/VisorCacheEvictionConfiguration.java  |   97 +-
 .../visor/cache/VisorCacheJdbcType.java         |  189 +
 .../visor/cache/VisorCacheJdbcTypeField.java    |  117 +
 .../visor/cache/VisorCacheLoadTask.java         |   23 +-
 .../visor/cache/VisorCacheLoadTaskArg.java      |  101 +
 .../visor/cache/VisorCacheMetadataTask.java     |   26 +-
 .../visor/cache/VisorCacheMetadataTaskArg.java  |   72 +
 .../internal/visor/cache/VisorCacheMetrics.java |  349 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |   45 +-
 .../VisorCacheMetricsCollectorTaskArg.java      |   87 +
 .../visor/cache/VisorCacheMetricsV2.java        |   66 -
 .../cache/VisorCacheNearConfiguration.java      |   59 +-
 .../visor/cache/VisorCacheNodesTask.java        |   12 +-
 .../visor/cache/VisorCacheNodesTaskArg.java     |   72 +
 .../visor/cache/VisorCachePartition.java        |   90 -
 .../visor/cache/VisorCachePartitions.java       |   57 +-
 .../visor/cache/VisorCachePartitionsTask.java   |   42 +-
 .../cache/VisorCachePartitionsTaskArg.java      |   72 +
 .../cache/VisorCacheQueryConfiguration.java     |  112 -
 .../cache/VisorCacheQueryConfigurationV2.java   |   47 -
 .../cache/VisorCacheQueryDetailMetrics.java     |  167 -
 ...sorCacheQueryDetailMetricsCollectorTask.java |  146 -
 .../visor/cache/VisorCacheQueryMetrics.java     |  102 -
 .../cache/VisorCacheRebalanceConfiguration.java |   97 +-
 .../visor/cache/VisorCacheRebalanceTask.java    |   13 +-
 .../visor/cache/VisorCacheRebalanceTaskArg.java |   73 +
 .../visor/cache/VisorCacheResetMetricsTask.java |   14 +-
 .../cache/VisorCacheResetMetricsTaskArg.java    |   72 +
 .../VisorCacheResetQueryDetailMetricsTask.java  |   71 -
 .../cache/VisorCacheResetQueryMetricsTask.java  |   69 -
 .../visor/cache/VisorCacheSqlIndexMetadata.java |  115 +
 .../visor/cache/VisorCacheSqlMetadata.java      |  162 +
 .../visor/cache/VisorCacheStartTask.java        |   68 +-
 .../visor/cache/VisorCacheStartTaskArg.java     |  100 +
 .../visor/cache/VisorCacheStopTask.java         |   17 +-
 .../visor/cache/VisorCacheStopTaskArg.java      |   72 +
 .../cache/VisorCacheStoreConfiguration.java     |   99 +-
 .../cache/VisorCacheStoreConfigurationV2.java   |   48 -
 .../visor/cache/VisorCacheSwapBackupsTask.java  |  102 -
 .../cache/VisorCacheTypeFieldMetadata.java      |  102 -
 .../visor/cache/VisorCacheTypeMetadata.java     |  375 --
 .../internal/visor/cache/VisorCacheV2.java      |   73 -
 .../internal/visor/cache/VisorCacheV3.java      |   52 -
 .../internal/visor/cache/VisorCacheV4.java      |  124 -
 .../visor/cache/VisorMemoryMetrics.java         |  177 +
 .../internal/visor/cache/VisorPartitionMap.java |  110 +
 .../compute/VisorComputeCancelSessionsTask.java |   15 +-
 .../VisorComputeCancelSessionsTaskArg.java      |   76 +
 .../compute/VisorComputeMonitoringHolder.java   |    8 +-
 .../VisorComputeToggleMonitoringTask.java       |   52 +-
 .../VisorComputeToggleMonitoringTaskArg.java    |   86 +
 .../visor/compute/VisorGatewayTask.java         |  199 +-
 .../visor/debug/VisorThreadDumpTask.java        |   13 +-
 .../visor/debug/VisorThreadDumpTaskResult.java  |   88 +
 .../internal/visor/debug/VisorThreadInfo.java   |  234 +-
 .../visor/debug/VisorThreadLockInfo.java        |   51 +-
 .../visor/debug/VisorThreadMonitorInfo.java     |   77 +-
 .../visor/event/VisorGridDeploymentEvent.java   |   44 +-
 .../visor/event/VisorGridDiscoveryEvent.java    |   74 +-
 .../visor/event/VisorGridDiscoveryEventV2.java  |   80 -
 .../internal/visor/event/VisorGridEvent.java    |   66 +-
 .../visor/event/VisorGridEventsLost.java        |   15 +-
 .../internal/visor/event/VisorGridJobEvent.java |   62 +-
 .../visor/event/VisorGridTaskEvent.java         |   62 +-
 .../internal/visor/file/VisorFileBlock.java     |   60 +-
 .../internal/visor/file/VisorFileBlockTask.java |   68 +-
 .../visor/file/VisorFileBlockTaskArg.java       |  114 +
 .../visor/file/VisorFileBlockTaskResult.java    |   87 +
 .../visor/file/VisorLatestTextFilesTask.java    |   17 +-
 .../visor/file/VisorLatestTextFilesTaskArg.java |   86 +
 .../ignite/internal/visor/igfs/VisorIgfs.java   |   78 +-
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |   50 +-
 .../visor/igfs/VisorIgfsFormatTask.java         |   16 +-
 .../visor/igfs/VisorIgfsFormatTaskArg.java      |   72 +
 .../internal/visor/igfs/VisorIgfsMetrics.java   |  119 +-
 .../internal/visor/igfs/VisorIgfsProfiler.java  |   24 +-
 .../visor/igfs/VisorIgfsProfilerClearTask.java  |   29 +-
 .../igfs/VisorIgfsProfilerClearTaskArg.java     |   72 +
 .../igfs/VisorIgfsProfilerClearTaskResult.java  |   85 +
 .../visor/igfs/VisorIgfsProfilerEntry.java      |  106 +-
 .../visor/igfs/VisorIgfsProfilerTask.java       |   51 +-
 .../visor/igfs/VisorIgfsProfilerTaskArg.java    |   72 +
 .../VisorIgfsProfilerUniformityCounters.java    |   38 +-
 .../visor/igfs/VisorIgfsResetMetricsTask.java   |   13 +-
 .../igfs/VisorIgfsResetMetricsTaskArg.java      |   73 +
 .../visor/igfs/VisorIgfsSamplingStateTask.java  |   17 +-
 .../igfs/VisorIgfsSamplingStateTaskArg.java     |   86 +
 .../ignite/internal/visor/log/VisorLogFile.java |   43 +-
 .../visor/log/VisorLogSearchResult.java         |   80 +-
 .../internal/visor/log/VisorLogSearchTask.java  |   81 +-
 .../visor/log/VisorLogSearchTaskArg.java        |  114 +
 .../visor/log/VisorLogSearchTaskResult.java     |   92 +
 .../internal/visor/misc/VisorAckTask.java       |   14 +-
 .../internal/visor/misc/VisorAckTaskArg.java    |   72 +
 .../misc/VisorChangeGridActiveStateTask.java    |   65 +
 .../misc/VisorChangeGridActiveStateTaskArg.java |   71 +
 .../node/VisorAffinityTopologyVersion.java      |   87 +
 .../visor/node/VisorAtomicConfiguration.java    |   49 +-
 .../visor/node/VisorBasicConfiguration.java     |  387 +-
 .../visor/node/VisorBinaryConfiguration.java    |  131 +
 .../node/VisorBinaryTypeConfiguration.java      |  150 +
 .../visor/node/VisorCacheKeyConfiguration.java  |  108 +
 .../visor/node/VisorExecutorConfiguration.java  |  108 +
 .../node/VisorExecutorServiceConfiguration.java |  194 +-
 .../visor/node/VisorGridConfiguration.java      |  258 +-
 .../visor/node/VisorHadoopConfiguration.java    |  145 +
 .../visor/node/VisorIgfsConfiguration.java      |  293 +-
 .../visor/node/VisorLifecycleConfiguration.java |   39 +-
 .../visor/node/VisorMemoryConfiguration.java    |  167 +
 .../node/VisorMemoryPolicyConfiguration.java    |  166 +
 .../visor/node/VisorMetricsConfiguration.java   |   50 +-
 .../VisorNodeConfigurationCollectorJob.java     |    4 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |  120 +-
 .../node/VisorNodeDataCollectorJobResult.java   |  173 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |   50 +-
 .../node/VisorNodeDataCollectorTaskArg.java     |   68 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |  176 +-
 .../node/VisorNodeEventsCollectorTask.java      |  133 +-
 .../node/VisorNodeEventsCollectorTaskArg.java   |  163 +
 .../internal/visor/node/VisorNodeGcTask.java    |   18 +-
 .../visor/node/VisorNodeGcTaskResult.java       |   85 +
 .../internal/visor/node/VisorNodePingTask.java  |   20 +-
 .../visor/node/VisorNodePingTaskArg.java        |   73 +
 .../visor/node/VisorNodePingTaskResult.java     |   99 +
 .../visor/node/VisorNodeSuppressedErrors.java   |   89 +
 .../node/VisorNodeSuppressedErrorsTask.java     |   31 +-
 .../node/VisorNodeSuppressedErrorsTaskArg.java  |   74 +
 .../node/VisorPeerToPeerConfiguration.java      |   57 +-
 .../node/VisorPersistentStoreConfiguration.java |  307 ++
 .../visor/node/VisorRestConfiguration.java      |  282 +-
 .../node/VisorSegmentationConfiguration.java    |   80 +-
 .../visor/node/VisorServiceConfiguration.java   |  176 +
 .../visor/node/VisorSpiDescription.java         |   89 +
 .../visor/node/VisorSpisConfiguration.java      |  139 +-
 .../node/VisorSqlConnectorConfiguration.java    |  166 +
 .../visor/node/VisorSuppressedError.java        |  147 +
 .../node/VisorTransactionConfiguration.java     |  104 +-
 .../internal/visor/query/VisorQueryArg.java     |   81 -
 .../internal/visor/query/VisorQueryArgV2.java   |   49 -
 .../visor/query/VisorQueryCancelTask.java       |   72 +
 .../visor/query/VisorQueryCancelTaskArg.java    |   71 +
 .../visor/query/VisorQueryCleanupTask.java      |   16 +-
 .../visor/query/VisorQueryCleanupTaskArg.java   |   75 +
 .../visor/query/VisorQueryConfiguration.java    |  130 +
 .../visor/query/VisorQueryDetailMetrics.java    |  205 +
 .../VisorQueryDetailMetricsCollectorTask.java   |  149 +
 ...VisorQueryDetailMetricsCollectorTaskArg.java |   71 +
 .../internal/visor/query/VisorQueryEntity.java  |  188 +
 .../internal/visor/query/VisorQueryField.java   |   42 +-
 .../internal/visor/query/VisorQueryIndex.java   |  105 +
 .../visor/query/VisorQueryIndexField.java       |  106 +
 .../internal/visor/query/VisorQueryJob.java     |  274 -
 .../internal/visor/query/VisorQueryMetrics.java |  125 +
 .../visor/query/VisorQueryNextPageTask.java     |   33 +-
 .../visor/query/VisorQueryNextPageTaskArg.java  |   86 +
 .../query/VisorQueryResetDetailMetricsTask.java |   73 +
 .../visor/query/VisorQueryResetMetricsTask.java |   73 +
 .../query/VisorQueryResetMetricsTaskArg.java    |   72 +
 .../internal/visor/query/VisorQueryResult.java  |   97 +-
 .../visor/query/VisorQueryResultEx.java         |   89 -
 .../visor/query/VisorQueryScanRegexFilter.java  |   59 +
 .../query/VisorQueryScanSubstringFilter.java    |   64 -
 .../internal/visor/query/VisorQueryTask.java    |  103 +-
 .../internal/visor/query/VisorQueryTaskArg.java |  155 +
 .../internal/visor/query/VisorQueryUtils.java   |   43 +-
 .../query/VisorRunningQueriesCollectorTask.java |  100 +
 .../VisorRunningQueriesCollectorTaskArg.java    |   71 +
 .../internal/visor/query/VisorRunningQuery.java |  175 +
 .../visor/query/VisorScanQueryTask.java         |  185 +
 .../visor/query/VisorScanQueryTaskArg.java      |  157 +
 .../visor/service/VisorCancelServiceTask.java   |   12 +-
 .../service/VisorCancelServiceTaskArg.java      |   72 +
 .../visor/service/VisorServiceDescriptor.java   |   40 +-
 .../internal/visor/util/VisorEventMapper.java   |    4 +-
 .../visor/util/VisorExceptionWrapper.java       |   11 +-
 .../internal/visor/util/VisorMimeTypes.java     |   12 +-
 .../internal/visor/util/VisorTaskUtils.java     |   87 +-
 .../apache/ignite/lang/IgniteAsyncSupport.java  |   52 +-
 .../ignite/lang/IgniteAsyncSupported.java       |    4 +-
 .../org/apache/ignite/lang/IgniteFuture.java    |   29 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java |   25 +-
 .../apache/ignite/marshaller/Marshaller.java    |    2 -
 .../ignite/marshaller/MarshallerContext.java    |   27 +-
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    4 +-
 .../optimized/OptimizedClassDescriptor.java     | 1141 -----
 .../optimized/OptimizedFieldType.java           |   50 -
 .../optimized/OptimizedMarshaller.java          |  304 --
 .../optimized/OptimizedMarshallerIdMapper.java  |   33 -
 .../optimized/OptimizedMarshallerUtils.java     |  551 --
 .../optimized/OptimizedObjectInputStream.java   | 1231 -----
 .../optimized/OptimizedObjectOutputStream.java  |  875 ----
 .../OptimizedObjectStreamRegistry.java          |  244 -
 .../marshaller/optimized/package-info.java      |   22 -
 .../ignite/mxbean/CacheMetricsMXBean.java       |   48 +-
 .../apache/ignite/mxbean/IgniteMBeanAware.java  |   28 +
 .../org/apache/ignite/mxbean/IgniteMXBean.java  |   73 +-
 .../apache/ignite/mxbean/IgnitionMXBean.java    |   14 +-
 .../ignite/mxbean/MemoryMetricsMXBean.java      |  139 +
 .../ignite/mxbean/PersistenceMetricsMXBean.java |  121 +
 .../ignite/mxbean/StripedExecutorMXBean.java    |   90 +
 .../dotnet/PlatformDotNetAffinityFunction.java  |   10 +-
 .../PlatformDotNetBinaryConfiguration.java      |   31 +-
 .../PlatformDotNetBinaryTypeConfiguration.java  |   35 +-
 .../dotnet/PlatformDotNetConfiguration.java     |   10 +-
 .../ignite/plugin/CachePluginConfiguration.java |    7 -
 .../ignite/plugin/CachePluginContext.java       |    5 -
 .../ignite/plugin/CachePluginProvider.java      |    4 +-
 .../apache/ignite/plugin/PluginProvider.java    |   11 +-
 .../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/plugin/platform/package-info.java    |   22 +
 .../security/SecurityBasicPermissionSet.java    |  135 +-
 .../plugin/security/SecurityPermission.java     |   13 +-
 .../plugin/security/SecurityPermissionSet.java  |   11 +-
 .../security/SecurityPermissionSetBuilder.java  |   36 +-
 .../ignite/plugin/security/SecuritySubject.java |    3 +-
 .../plugin/segmentation/SegmentationPolicy.java |   18 +-
 .../ignite/services/ServiceConfiguration.java   |   35 +-
 .../java/org/apache/ignite/spi/IgniteSpi.java   |    6 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |  115 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |    6 +
 .../ignite/spi/IgniteSpiMBeanAdapter.java       |   78 +
 .../spi/IgniteSpiOperationTimeoutHelper.java    |    8 +-
 .../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    |  287 +-
 .../JobStealingCollisionSpiMBean.java           |    6 +-
 .../jobstealing/JobStealingRequest.java         |    2 +-
 .../spi/collision/noop/NoopCollisionSpi.java    |    9 +-
 .../PriorityQueueCollisionSpi.java              |  280 +-
 .../PriorityQueueCollisionSpiMBean.java         |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  | 1056 ++--
 .../tcp/TcpCommunicationSpiMBean.java           |   54 -
 .../deployment/local/LocalDeploymentSpi.java    |   43 +-
 .../ignite/spi/discovery/DiscoveryDataBag.java  |   18 +-
 .../ignite/spi/discovery/DiscoverySpi.java      |   20 +-
 .../spi/discovery/DiscoverySpiListener.java     |    9 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    |  417 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  527 +-
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |   27 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  642 ++-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java |   48 +-
 .../tcp/internal/TcpDiscoveryNode.java          |   52 +-
 .../tcp/internal/TcpDiscoveryNodesRing.java     |    3 +-
 .../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   |   29 +-
 .../messages/TcpDiscoveryClientAckResponse.java |    4 -
 .../TcpDiscoveryClientHeartbeatMessage.java     |   72 -
 .../TcpDiscoveryClientMetricsUpdateMessage.java |   72 +
 .../messages/TcpDiscoveryHeartbeatMessage.java  |  338 --
 .../TcpDiscoveryMetricsUpdateMessage.java       |  338 ++
 .../TcpDiscoveryRingLatencyCheckMessage.java    |   77 +
 .../spi/eventstorage/NoopEventStorageSpi.java   |   53 +
 .../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/IndexingQueryFilter.java       |    8 +-
 .../apache/ignite/spi/indexing/IndexingSpi.java |   36 +-
 .../spi/indexing/noop/NoopIndexingSpi.java      |   23 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |   57 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |   46 +-
 .../WeightedRandomLoadBalancingSpi.java         |   63 +-
 .../ignite/spi/swapspace/SwapContext.java       |   47 -
 .../apache/ignite/spi/swapspace/SwapKey.java    |  128 -
 .../ignite/spi/swapspace/SwapSpaceSpi.java      |  225 -
 .../spi/swapspace/SwapSpaceSpiListener.java     |   35 -
 .../spi/swapspace/file/FileSwapArray.java       |  188 -
 .../spi/swapspace/file/FileSwapSpaceSpi.java    | 1947 -------
 .../swapspace/file/FileSwapSpaceSpiMBean.java   |   67 -
 .../ignite/spi/swapspace/file/package-info.java |   22 -
 .../spi/swapspace/noop/NoopSwapSpaceSpi.java    |  152 -
 .../ignite/spi/swapspace/noop/package-info.java |   22 -
 .../ignite/spi/swapspace/package-info.java      |   22 -
 .../ignite/startup/BasicWarmupClosure.java      |    6 +-
 .../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 +
 .../TransactionDeadlockException.java           |    4 +-
 .../transactions/TransactionException.java      |   80 +
 .../TransactionHeuristicException.java          |    4 +-
 .../TransactionOptimisticException.java         |    4 +-
 .../TransactionRollbackException.java           |    4 +-
 .../TransactionTimeoutException.java            |    4 +-
 .../org/jsr166/ConcurrentLinkedHashMap.java     |    2 +-
 .../resources/META-INF/classnames.properties    |  676 +--
 .../core/src/main/resources/ignite.properties   |    2 +-
 .../spring-cache-client-benchmark-1.xml         |    3 -
 .../spring-cache-client-benchmark-2.xml         |    3 -
 .../spring-cache-client-benchmark-3.xml         |    3 -
 .../test/config/default-spring-url-testing.xml  |    2 +-
 .../core/src/test/config/discovery-stress.xml   |    2 +-
 modules/core/src/test/config/example-cache.xml  |    8 +-
 .../core/src/test/config/examples.properties    |    1 +
 modules/core/src/test/config/igfs-loopback.xml  |   45 -
 modules/core/src/test/config/igfs-shmem.xml     |   45 -
 .../src/test/config/load/cache-benchmark.xml    |    4 -
 .../test/config/load/cache-client-benchmark.xml |    2 -
 .../config/load/dsi-49-server-production.xml    |    2 -
 .../core/src/test/config/load/dsi-load-base.xml |    5 +-
 .../src/test/config/load/dsi-load-client.xml    |    2 -
 .../src/test/config/load/dsi-load-server.xml    |    2 -
 .../src/test/config/load/merge-sort-base.xml    |    7 +-
 .../test/config/loaders/grid-cfg-2-grids.xml    |   10 +-
 .../core/src/test/config/loaders/grid-cfg.xml   |    2 +-
 modules/core/src/test/config/log4j-test.xml     |    8 +-
 modules/core/src/test/config/log4j2-test.xml    |    6 +-
 .../src/test/config/log4j2-verbose-test.xml     |    4 +-
 .../core/src/test/config/spring-cache-load.xml  |    1 +
 .../core/src/test/config/spring-cache-swap.xml  |    2 +
 .../src/test/config/spring-cache-teststore.xml  |    2 +
 .../core/src/test/config/spring-multicache.xml  |   33 +-
 .../src/test/config/spring-start-nodes-attr.xml |    4 +-
 .../core/src/test/config/spring-start-nodes.xml |    4 +-
 .../test/config/store/jdbc/ignite-jdbc-type.xml |  285 ++
 .../config/store/jdbc/ignite-type-metadata.xml  |  276 -
 .../config/streamer/spring-streamer-base.xml    |    5 +-
 .../config/websession/example-cache-base.xml    |    9 +-
 .../config/websession/example-cache-client.xml  |    6 +-
 .../test/config/websession/example-cache2.xml   |    2 +-
 .../test/config/websession/spring-cache-1.xml   |    8 +-
 .../test/config/websession/spring-cache-2.xml   |    8 +-
 .../test/config/websession/spring-cache-3.xml   |    8 +-
 .../org.apache.ignite.plugin.PluginProvider     |    3 +-
 ...atformCachePluginConfigurationClosureFactory |    1 +
 ...rm.PlatformPluginConfigurationClosureFactory |    1 +
 .../GridCacheAffinityBackupsSelfTest.java       |   26 +-
 .../java/org/apache/ignite/GridTestJob.java     |   19 +
 .../apache/ignite/GridTestStoreNodeStartup.java |    2 +-
 .../java/org/apache/ignite/GridTestTask.java    |   18 +-
 .../ignite/IgniteCacheAffinitySelfTest.java     |   20 +-
 .../IgniteExternalizableAbstractTest.java       |   15 +-
 .../cache/IgniteWarmupClosureSelfTest.java      |    6 +-
 .../ignite/cache/LargeEntryUpdateTest.java      |  176 +
 .../affinity/AffinityClientNodeSelfTest.java    |   35 +-
 ...ityFunctionBackupFilterAbstractSelfTest.java |   25 +-
 ...unctionExcludeNeighborsAbstractSelfTest.java |    8 +-
 .../affinity/AffinityHistoryCleanupTest.java    |    9 +-
 .../fair/FairAffinityDynamicCacheSelfTest.java  |   86 -
 ...airAffinityFunctionBackupFilterSelfTest.java |   44 -
 ...ffinityFunctionExcludeNeighborsSelfTest.java |   31 -
 .../fair/FairAffinityFunctionNodesSelfTest.java |  247 -
 .../fair/FairAffinityFunctionSelfTest.java      |   31 -
 .../local/LocalAffinityFunctionTest.java        |   16 +-
 ...inityFunctionFastPowerOfTwoHashSelfTest.java |   33 +
 ...ndezvousAffinityFunctionSimpleBenchmark.java | 1054 ++++
 ...ousAffinityFunctionStandardHashSelfTest.java |   33 +
 ...cheStoreSessionListenerAbstractSelfTest.java |   10 +-
 ...heStoreSessionListenerLifecycleSelfTest.java |    4 +-
 .../store/GridCacheBalancingStoreSelfTest.java  |   40 +-
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |    4 +-
 .../IgniteCacheExpiryStoreLoadSelfTest.java     |   38 +-
 .../store/StoreResourceInjectionSelfTest.java   |    6 +-
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   73 +-
 ...BinaryMarshallerStoreKeepBinarySelfTest.java |   28 +
 ...lerStoreKeepBinaryWithSqlEscapeSelfTest.java |   28 +
 ...dbcPojoStoreOptimizedMarshallerSelfTest.java |   31 -
 ...ptimizedMarshallerWithSqlEscapeSelfTest.java |   28 -
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |  136 +-
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   76 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |   13 +-
 .../cache/store/jdbc/model/Organization.java    |    2 -
 .../cache/store/jdbc/model/OrganizationKey.java |    2 -
 .../ignite/cache/store/jdbc/model/Person.java   |    2 -
 .../store/jdbc/model/PersonComplexKey.java      |    4 +-
 .../cache/store/jdbc/model/PersonKey.java       |    2 -
 .../ignite/custom/DummyEventFilterFactory.java  |   47 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |   66 +-
 .../igfs/IgfsFragmentizerAbstractSelfTest.java  |   23 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |    5 +-
 .../apache/ignite/igfs/IgfsPathSelfTest.java    |    9 +-
 .../internal/ClusterGroupAbstractTest.java      |   77 +-
 .../internal/ClusterGroupHostsSelfTest.java     |    4 +-
 .../ignite/internal/ClusterGroupSelfTest.java   |  100 +
 .../ignite/internal/ClusterMetricsSelfTest.java |    4 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |   88 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |   14 +-
 .../ignite/internal/GridAffinityMappedTest.java |   22 +-
 .../internal/GridAffinityNoCacheSelfTest.java   |   33 +-
 .../internal/GridAffinityP2PSelfTest.java       |   20 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   20 +-
 .../GridAlwaysFailoverSpiFailSelfTest.java      |    4 +-
 ...chePartitionExchangeManagerHistSizeTest.java |   76 +
 .../internal/GridCancelOnGridStopSelfTest.java  |    2 +-
 .../internal/GridCancelUnusedJobSelfTest.java   |    6 +-
 .../GridCancelledJobsMetricsSelfTest.java       |   19 +-
 .../GridCollisionJobsContextSelfTest.java       |   10 +-
 .../internal/GridCommunicationSelfTest.java     |    2 +-
 ...omputationBinarylizableClosuresSelfTest.java |    4 +-
 .../GridContinuousJobAnnotationSelfTest.java    |    4 +-
 .../internal/GridContinuousTaskSelfTest.java    |  100 +-
 .../ignite/internal/GridDeploymentSelfTest.java |   16 +-
 .../internal/GridDiscoveryEventSelfTest.java    |    4 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    8 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |   14 +-
 .../GridEventStorageDefaultExceptionTest.java   |   94 +
 ...ventStorageRuntimeConfigurationSelfTest.java |    4 +-
 .../internal/GridFactoryVmShutdownTest.java     |    2 +-
 ...ridFailFastNodeFailureDetectionSelfTest.java |   10 +-
 .../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         |    6 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |  101 +-
 .../internal/GridJobStealingSelfTest.java       |    4 +-
 .../GridJobStealingZeroActiveJobsSelfTest.java  |    6 +-
 .../internal/GridLifecycleAwareSelfTest.java    |    9 +-
 .../internal/GridLifecycleBeanSelfTest.java     |   16 +-
 .../GridLocalEventListenerSelfTest.java         |    6 +-
 .../internal/GridMultipleJobsSelfTest.java      |   26 +-
 .../internal/GridMultipleSpisSelfTest.java      |    4 +-
 .../GridMultipleVersionsDeploymentSelfTest.java |    4 +-
 .../GridMultithreadedJobStealingSelfTest.java   |    4 +-
 .../ignite/internal/GridNodeLocalSelfTest.java  |    2 +-
 .../internal/GridNodeMetricsLogSelfTest.java    |   17 +-
 .../GridNodeVisorAttributesSelfTest.java        |    4 +-
 .../internal/GridNonHistoryMetricsSelfTest.java |    4 +-
 .../GridProjectionForCachesSelfTest.java        |   51 +-
 ...ectionLocalJobMultipleArgumentsSelfTest.java |    8 +-
 .../ignite/internal/GridReduceSelfTest.java     |    9 +-
 .../internal/GridReleaseTypeSelfTest.java       |    4 +-
 .../internal/GridRuntimeExceptionSelfTest.java  |    8 +-
 .../internal/GridSpiExceptionSelfTest.java      |    8 +-
 .../ignite/internal/GridStartStopSelfTest.java  |   14 +-
 .../internal/GridStopWithWaitSelfTest.java      |   12 +-
 .../GridTaskCancelSingleNodeSelfTest.java       |    7 +-
 .../internal/GridTaskExecutionSelfTest.java     |   58 +-
 ...xecutionWithoutPeerClassLoadingSelfTest.java |   31 +
 .../GridTaskFailoverAffinityRunTest.java        |   15 +-
 .../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  |   32 +-
 .../IgniteClientReconnectAtomicsTest.java       |   15 +-
 .../IgniteClientReconnectCacheTest.java         |  230 +-
 ...eClientReconnectContinuousProcessorTest.java |   10 +-
 ...niteClientReconnectFailoverAbstractTest.java |    4 +-
 .../IgniteClientReconnectFailoverTest.java      |    8 +-
 .../internal/IgniteClientReconnectStopTest.java |    2 +-
 .../IgniteClientReconnectStreamerTest.java      |    6 +-
 .../ignite/internal/IgniteClientRejoinTest.java |  378 ++
 .../IgniteComputeEmptyClusterGroupTest.java     |   40 +-
 .../IgniteComputeTopologyExceptionTest.java     |    2 +-
 ...eConcurrentEntryProcessorAccessStopTest.java |    2 +-
 .../internal/IgniteExecutorServiceTest.java     |   14 +-
 ...gniteExplicitImplicitDeploymentSelfTest.java |    4 +-
 .../IgniteLocalNodeMapBeforeStartTest.java      |    2 +-
 ...RoundRobinErrorAfterClientReconnectTest.java |    6 +-
 .../IgniteSlowClientDetectionSelfTest.java      |   13 +-
 ...UpdateNotifierPerClusterSettingSelfTest.java |    4 +-
 .../MarshallerContextLockingSelfTest.java       |   38 +-
 .../internal/SensitiveInfoTestLoggerProxy.java  |  493 ++
 .../SensitiveInfoTestLoggerProxy_Exclude.txt    |   20 +
 .../SensitiveInfoTestLoggerProxy_Include.txt    |   18 +
 .../ignite/internal/TaskNodeRestartTest.java    |    4 +-
 .../internal/TestRecordingCommunicationSpi.java |   81 +-
 .../BinaryArrayIdentityResolverSelfTest.java    |    8 +-
 .../BinaryConfigurationConsistencySelfTest.java |    4 +-
 ...ryConfigurationCustomSerializerSelfTest.java |  149 +
 .../internal/binary/BinaryEnumsSelfTest.java    |  154 +-
 .../binary/BinaryFieldExtractionSelfTest.java   |  213 +
 .../BinaryFieldIdentityResolverSelfTest.java    |  333 --
 ...ryIdentityResolverConfigurationSelfTest.java |  138 -
 .../binary/BinaryMarshallerSelfTest.java        |  139 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |   14 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java |  130 +-
 ...ilderSimpleNameLowerCaseMappersSelfTest.java |    4 +-
 .../binary/BinaryObjectExceptionSelfTest.java   |  209 +
 .../binary/BinaryObjectToStringSelfTest.java    |    4 +-
 .../BinarySerialiedFieldComparatorSelfTest.java |    4 +-
 .../BinarySimpleNameTestPropertySelfTest.java   |   17 +
 .../internal/binary/BinaryTreeSelfTest.java     |    6 +-
 .../binary/GridBinaryAffinityKeySelfTest.java   |   36 +-
 ...GridBinaryMarshallerCtxDisabledSelfTest.java |    5 +
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |   22 +-
 ...CaseBinaryMappersBinaryMetaDataSelfTest.java |    4 +-
 .../binary/TestCachingMetadataHandler.java      |   10 +
 .../mutabletest/GridBinaryTestClasses.java      |    9 +
 ...ByteBufferStreamImplV2ByteOrderSelfTest.java |    2 +-
 ...GridManagerLocalMessageListenerSelfTest.java |    8 +-
 ...dManagerMxBeanIllegalArgumentHandleTest.java |  125 +
 .../managers/GridManagerStopSelfTest.java       |   23 +-
 .../managers/GridNoopManagerSelfTest.java       |    2 +-
 ...agnosticMessagesMultipleConnectionsTest.java |   35 +
 .../managers/IgniteDiagnosticMessagesTest.java  |  542 ++
 .../GridCheckpointManagerAbstractSelfTest.java  |   33 +-
 .../checkpoint/GridCheckpointTaskSelfTest.java  |    4 +-
 ...idCommunicationManagerListenersSelfTest.java |    8 +-
 .../GridCommunicationSendMessageSelfTest.java   |   92 +-
 .../communication/GridIoManagerSelfTest.java    |   36 +-
 .../IgniteCommunicationBalanceTest.java         |    4 +-
 .../communication/IgniteIoTestMessagesTest.java |    4 +-
 .../IgniteVariousConnectionNumberTest.java      |   10 +-
 .../GridDeploymentManagerStopSelfTest.java      |    2 +-
 .../GridDeploymentMessageCountSelfTest.java     |   22 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   69 +-
 .../GridDiscoveryManagerAttributesSelfTest.java |   84 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |  214 -
 .../IgniteTopologyPrintFormatSelfTest.java      |    8 +-
 .../events/GridEventStorageManagerSelfTest.java |    4 +-
 .../GridSwapSpaceCustomLocalValue.java          |   85 -
 .../swapspace/GridSwapSpaceManagerSelfTest.java |  170 -
 .../managers/swapspace/package-info.java        |   22 -
 .../OptimizedMarshallerEnumSelfTest.java        |   87 +
 .../OptimizedMarshallerNodeFailoverTest.java    |  358 ++
 .../OptimizedMarshallerPooledSelfTest.java      |   46 +
 .../optimized/OptimizedMarshallerSelfTest.java  |  284 ++
 ...arshallerSerialPersistentFieldsSelfTest.java |  116 +
 .../optimized/OptimizedMarshallerTest.java      |  798 +++
 .../OptimizedObjectStreamSelfTest.java          | 2162 ++++++++
 .../TestTcpDiscoveryIpFinderAdapter.java        |   43 +
 .../marshaller/optimized/package-info.java      |   22 +
 .../pagemem/impl/PageIdUtilsSelfTest.java       |  146 +
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java  |  380 ++
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java |    6 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |    6 +-
 .../AtomicCacheAffinityConfigurationTest.java   |  185 +
 .../BinaryObjectOffHeapUnswapTemporaryTest.java |  367 --
 .../cache/CacheAffinityCallSelfTest.java        |    6 +-
 .../CacheAtomicSingleMessageCountSelfTest.java  |   12 +-
 .../cache/CacheClientStoreSelfTest.java         |   43 +-
 .../cache/CacheConcurrentReadThroughTest.java   |  180 +
 .../cache/CacheConfigurationLeakTest.java       |   27 +-
 .../cache/CacheDeferredDeleteQueueTest.java     |    6 +-
 .../CacheDeferredDeleteSanitySelfTest.java      |    4 +-
 ...cheDhtLocalPartitionAfterRemoveSelfTest.java |   12 +-
 .../cache/CacheEntryProcessorCopySelfTest.java  |    4 +-
 .../cache/CacheEnumOperationsAbstractTest.java  |   60 +-
 ...CacheExchangeMessageDuplicatedStateTest.java |  162 +-
 .../cache/CacheFutureExceptionSelfTest.java     |   14 +-
 .../cache/CacheGetEntryAbstractTest.java        |   44 +-
 .../processors/cache/CacheGetFromJobTest.java   |    7 +-
 .../cache/CacheGroupsMetricsRebalanceTest.java  |  140 +
 ...erceptorPartitionCounterLocalSanityTest.java |   31 +-
 ...torPartitionCounterRandomOperationsTest.java |  119 +-
 .../cache/CacheKeepBinaryTransactionTest.java   |  121 +
 .../CacheMemoryPolicyConfigurationTest.java     |  172 +
 .../CacheMetricsForClusterGroupSelfTest.java    |    4 +-
 .../processors/cache/CacheNamesSelfTest.java    |   12 +-
 .../CacheNamesWithSpecialCharactersTest.java    |    8 +-
 .../cache/CacheNearReaderUpdateTest.java        |   30 +-
 ...cheNearUpdateTopologyChangeAbstractTest.java |    8 +-
 .../cache/CacheOffheapMapEntrySelfTest.java     |   62 +-
 ...cTransactionsWithFilterSingleServerTest.java |   28 +
 ...cheOptimisticTransactionsWithFilterTest.java |  493 ++
 .../CachePutEventListenerErrorSelfTest.java     |   52 +-
 .../processors/cache/CachePutIfAbsentTest.java  |    6 +-
 .../cache/CacheReadThroughRestartSelfTest.java  |   14 +-
 .../cache/CacheRebalancingSelfTest.java         |   27 +-
 .../cache/CacheRemoveAllSelfTest.java           |    5 +-
 .../CacheSerializableTransactionsTest.java      |  244 +-
 .../CacheStartupInDeploymentModesTest.java      |   47 +-
 .../cache/CacheStopAndDestroySelfTest.java      |   88 +-
 .../CacheStoreUsageMultinodeAbstractTest.java   |   20 +-
 ...eUsageMultinodeDynamicStartAbstractTest.java |    4 +-
 .../cache/CacheSwapUnswapGetTest.java           |  313 --
 .../CacheSwapUnswapGetTestSmallQueueSize.java   |   35 -
 .../processors/cache/CacheTxFastFinishTest.java |   10 +-
 .../CacheTxNotAllowReadFromBackupTest.java      |    4 +-
 .../cache/ClusterStateAbstractTest.java         |  439 ++
 .../cache/ClusterStatePartitionedSelfTest.java  |   41 +
 .../cache/ClusterStateReplicatedSelfTest.java   |   42 +
 .../processors/cache/CrossCacheLockTest.java    |   10 +-
 ...sCacheTxNearEnabledRandomOperationsTest.java |   28 +
 .../cache/CrossCacheTxRandomOperationsTest.java |   55 +-
 .../EntryVersionConsistencyReadThroughTest.java |   22 +-
 ...idAbstractCacheInterceptorRebalanceTest.java |   40 +-
 ...ridCacheAbstractByteArrayValuesSelfTest.java |   10 +-
 .../GridCacheAbstractFailoverSelfTest.java      |   32 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java |  105 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java | 1195 +++--
 .../GridCacheAbstractLocalStoreSelfTest.java    |  119 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |  192 +-
 .../GridCacheAbstractRemoveFailureTest.java     |   50 +-
 .../cache/GridCacheAbstractSelfTest.java        |   53 +-
 .../cache/GridCacheAbstractTxReadTest.java      |   10 +-
 ...acheAbstractUsersAffinityMapperSelfTest.java |   11 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |   30 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |   16 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |   13 +-
 ...eAtomicEntryProcessorDeploymentSelfTest.java |    6 +-
 .../GridCacheAtomicMessageCountSelfTest.java    |   88 +-
 .../cache/GridCacheBasicApiAbstractTest.java    |   34 +-
 .../cache/GridCacheBasicStoreAbstractTest.java  |   10 +-
 ...acheBasicStoreMultithreadedAbstractTest.java |    5 +-
 .../cache/GridCacheClearAllSelfTest.java        |    4 +-
 .../cache/GridCacheClearLocallySelfTest.java    |   18 +-
 .../cache/GridCacheClearSelfTest.java           |  136 +-
 ...GridCacheConcurrentGetCacheOnClientTest.java |  129 +
 .../cache/GridCacheConcurrentMapSelfTest.java   |   15 +-
 .../cache/GridCacheConcurrentMapTest.java       |  138 -
 .../GridCacheConcurrentTxMultiNodeTest.java     |   50 +-
 .../GridCacheConditionalDeploymentSelfTest.java |   49 +-
 ...idCacheConfigurationConsistencySelfTest.java |   67 +-
 ...ridCacheConfigurationValidationSelfTest.java |   73 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   12 +-
 .../GridCacheDeploymentOffHeapSelfTest.java     |   41 -
 ...ridCacheDeploymentOffHeapValuesSelfTest.java |   41 -
 .../cache/GridCacheDeploymentSelfTest.java      |   68 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |  114 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |   22 +-
 .../GridCacheEvictionEventAbstractTest.java     |   10 +-
 .../GridCacheFinishPartitionsSelfTest.java      |   20 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |    6 +-
 ...idCacheGetAndTransformStoreAbstractTest.java |    5 +-
 .../cache/GridCacheIncrementTransformTest.java  |   10 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |   71 +-
 ...heInterceptorAtomicOffheapRebalanceTest.java |   30 -
 ...erceptorAtomicPrimaryWriteOrderSelfTest.java |   47 -
 ...GridCacheInterceptorAtomicRebalanceTest.java |    6 -
 ...omicReplicatedPrimaryWriteOrderSelfTest.java |   48 -
 ...acheInterceptorAtomicReplicatedSelfTest.java |    8 -
 .../GridCacheInterceptorAtomicSelfTest.java     |    8 -
 ...GridCacheInterceptorLocalAtomicSelfTest.java |    8 -
 ...ceptorTransactionalOffheapRebalanceTest.java |   35 -
 ...heInterceptorTransactionalRebalanceTest.java |    6 -
 .../cache/GridCacheIteratorPerformanceTest.java |   10 +-
 .../cache/GridCacheKeyCheckSelfTest.java        |   10 +-
 .../processors/cache/GridCacheLeakTest.java     |   11 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   38 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |    4 +-
 .../GridCacheMarshallerTxAbstractTest.java      |   14 +-
 .../GridCacheMarshallingNodeJoinSelfTest.java   |    8 +-
 .../cache/GridCacheMemoryModeSelfTest.java      |  289 --
 .../GridCacheMissingCommitVersionSelfTest.java  |    8 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    8 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |   10 +-
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |   10 +-
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    4 +-
 .../cache/GridCacheMvccFlagsTest.java           |    8 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |   13 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |   58 +-
 .../processors/cache/GridCacheMvccSelfTest.java |   66 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |   16 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    9 +-
 .../cache/GridCacheOffHeapCleanupTest.java      |  169 -
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |   31 +-
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   14 +-
 .../processors/cache/GridCacheOffHeapTest.java  |  274 -
 .../GridCacheOffHeapTieredAbstractSelfTest.java |  675 ---
 .../GridCacheOffHeapTieredAtomicSelfTest.java   |   32 -
 ...heOffHeapTieredEvictionAbstractSelfTest.java |  364 --
 ...acheOffHeapTieredEvictionAtomicSelfTest.java |   32 -
 .../GridCacheOffHeapTieredEvictionSelfTest.java |   33 -
 .../cache/GridCacheOffHeapTieredSelfTest.java   |   33 -
 .../GridCacheOffHeapValuesEvictionSelfTest.java |  210 -
 .../cache/GridCacheOffheapUpdateSelfTest.java   |   21 +-
 .../GridCacheOnCopyFlagAbstractSelfTest.java    |    4 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |   58 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |   45 +-
 .../GridCachePartitionedAffinitySpreadTest.java |  169 -
 .../cache/GridCachePartitionedGetSelfTest.java  |   24 +-
 ...chePartitionedOffHeapLocalStoreSelfTest.java |   44 -
 ...hePartitionedProjectionAffinitySelfTest.java |   12 +-
 .../cache/GridCachePartitionedWritesTest.java   |    5 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |   23 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   85 +-
 .../cache/GridCacheQueryEmbeddedValue.java      |   37 +
 .../GridCacheQueryIndexingDisabledSelfTest.java |    6 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |   10 +-
 .../GridCacheReferenceCleanupSelfTest.java      |   29 +-
 .../cache/GridCacheReloadSelfTest.java          |    8 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |   14 +-
 .../GridCacheReturnValueTransferSelfTest.java   |   23 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    4 +-
 .../processors/cache/GridCacheStopSelfTest.java |   20 +-
 ...ridCacheStoreManagerDeserializationTest.java |   35 +-
 .../cache/GridCacheStorePutxSelfTest.java       |    6 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |   13 +-
 .../cache/GridCacheSwapCleanupTest.java         |   99 -
 .../cache/GridCacheSwapPreloadSelfTest.java     |   16 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |  260 -
 ...ridCacheSwapSpaceSpiConsistencySelfTest.java |  146 -
 ...acheTcpClientDiscoveryMultiThreadedTest.java |    8 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   80 +-
 .../processors/cache/GridCacheTestStore.java    |    2 -
 ...cheTransactionalAbstractMetricsSelfTest.java |    8 +-
 .../GridCacheTtlManagerEvictionSelfTest.java    |   62 +-
 .../cache/GridCacheTtlManagerLoadTest.java      |    4 +-
 .../GridCacheTtlManagerNotificationTest.java    |   12 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |   17 +-
 .../cache/GridCacheUtilsSelfTest.java           |    4 -
 .../GridCacheValueBytesPreloadingSelfTest.java  |   79 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |   75 +-
 .../GridCacheVariableTopologySelfTest.java      |    8 +-
 .../cache/GridCacheVersionMultinodeTest.java    |   52 +-
 .../cache/GridCacheVersionSelfTest.java         |   11 +-
 .../GridCacheVersionTopologyChangeTest.java     |   13 +-
 ...calCacheStoreManagerDeserializationTest.java |    2 +-
 .../cache/GridLocalIgniteSerializationTest.java |   10 +-
 ...ProjectionForCachesOnDaemonNodeSelfTest.java |   20 +-
 .../processors/cache/H2CacheStoreStrategy.java  |   37 +-
 .../cache/IgniteActiveClusterTest.java          |  182 +
 .../IgniteCacheAbstractStopBusySelfTest.java    |   16 +-
 .../cache/IgniteCacheAbstractTest.java          |   43 +-
 .../cache/IgniteCacheAtomicInvokeTest.java      |    7 -
 .../cache/IgniteCacheAtomicPeekModesTest.java   |    7 -
 ...eCacheAtomicPrimaryWriteOrderInvokeTest.java |   57 -
 ...maryWriteOrderNearEnabledStoreValueTest.java |   31 -
 ...heAtomicPrimaryWriteOrderStoreValueTest.java |   32 -
 ...micPrimaryWriteOrderWithStoreInvokeTest.java |   32 -
 ...IgniteCacheAtomicPutAllFailoverSelfTest.java |    5 -
 .../cache/IgniteCacheAtomicStoreValueTest.java  |    7 -
 .../IgniteCacheAtomicWithStoreInvokeTest.java   |   32 +
 ...IgniteCacheBinaryEntryProcessorSelfTest.java |   12 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |   17 +-
 .../IgniteCacheConfigVariationsFullApiTest.java | 1362 +++--
 ...teCacheConfigurationDefaultTemplateTest.java |   10 +-
 .../IgniteCacheConfigurationTemplateTest.java   |   33 +-
 .../IgniteCacheContainsKeyAbstractSelfTest.java |    8 +-
 .../cache/IgniteCacheContainsKeyAtomicTest.java |  103 +
 ...niteCacheCopyOnReadDisabledAbstractTest.java |    6 +-
 .../cache/IgniteCacheCreateRestartSelfTest.java |    4 +-
 .../cache/IgniteCacheDynamicStopSelfTest.java   |   10 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |   28 +-
 ...cheEntryListenerAtomicOffheapTieredTest.java |   32 -
 ...cheEntryListenerAtomicOffheapValuesTest.java |   32 -
 .../IgniteCacheEntryListenerAtomicTest.java     |    7 -
 ...niteCacheEntryListenerExpiredEventsTest.java |   34 +-
 ...teCacheEntryListenerTxOffheapTieredTest.java |   32 -
 ...teCacheEntryListenerTxOffheapValuesTest.java |   32 -
 .../IgniteCacheEntryProcessorCallTest.java      |   19 +-
 .../IgniteCacheEntryProcessorNodeJoinTest.java  |   20 +-
 ...niteCacheExpireAndUpdateConsistencyTest.java |   43 +-
 ...IgniteCacheGetCustomCollectionsSelfTest.java |    6 +-
 .../processors/cache/IgniteCacheGroupsTest.java | 4319 ++++++++++++++++
 .../cache/IgniteCacheIncrementTxTest.java       |   16 +-
 .../IgniteCacheInterceptorSelfTestSuite.java    |   14 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |   24 +-
 ...gniteCacheInvokeReadThroughAbstractTest.java |  104 +-
 ...iteCacheInvokeReadThroughSingleNodeTest.java |   32 +-
 .../cache/IgniteCacheInvokeReadThroughTest.java |   92 +-
 ...gniteCacheLoadRebalanceEvictionSelfTest.java |   13 +-
 .../IgniteCacheManyAsyncOperationsTest.java     |   12 +-
 .../cache/IgniteCacheNearLockValueSelfTest.java |    6 +-
 .../cache/IgniteCacheNoSyncForGetTest.java      |  395 ++
 .../cache/IgniteCacheObjectPutSelfTest.java     |  179 +
 .../IgniteCacheP2pUnmarshallingErrorTest.java   |   14 +-
 ...gniteCacheP2pUnmarshallingNearErrorTest.java |   14 +-
 ...CacheP2pUnmarshallingRebalanceErrorTest.java |    4 +-
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java |    6 +-
 .../IgniteCachePartitionMapUpdateTest.java      |    8 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |  312 +-
 .../cache/IgniteCachePutAllRestartTest.java     |    4 +-
 .../IgniteCachePutStackOverflowSelfTest.java    |    4 +-
 .../IgniteCacheReadThroughEvictionSelfTest.java |   14 +-
 .../IgniteCacheReadThroughStoreCallTest.java    |    8 +-
 ...iteCacheScanPredicateDeploymentSelfTest.java |    8 +-
 .../cache/IgniteCacheSerializationSelfTest.java |   10 +-
 .../cache/IgniteCacheStartStopLoadTest.java     |    6 +-
 .../processors/cache/IgniteCacheStartTest.java  |  192 +
 .../cache/IgniteCacheStoreCollectionTest.java   |    8 +-
 .../IgniteCacheStoreValueAbstractTest.java      |   51 +-
 .../IgniteCacheTopologySafeGetSelfTest.java     |    6 +-
 .../cache/IgniteCacheTxNearPeekModesTest.java   |    5 +-
 .../cache/IgniteCacheTxPeekModesTest.java       |   12 +-
 .../cache/IgniteCacheTxPreloadNoWriteTest.java  |   16 +-
 .../cache/IgniteCachingProviderSelfTest.java    |    8 +-
 .../IgniteClientAffinityAssignmentSelfTest.java |   46 +-
 ...IgniteClientCacheInitializationFailTest.java |  366 ++
 .../IgniteClientCacheStartFailoverTest.java     |  585 +++
 .../IgniteDaemonNodeMarshallerCacheTest.java    |    6 +-
 .../cache/IgniteDynamicCacheAndNodeStop.java    |    8 +-
 .../cache/IgniteDynamicCacheFilterTest.java     |   14 +-
 ...eDynamicCacheStartNoExchangeTimeoutTest.java |   51 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java  |   46 +-
 ...niteDynamicCacheStartStopConcurrentTest.java |   10 +-
 ...niteDynamicCacheWithConfigStartSelfTest.java |    4 +-
 .../IgniteDynamicClientCacheStartSelfTest.java  |  296 +-
 .../cache/IgniteExchangeFutureHistoryTest.java  |    8 +-
 .../IgniteIncompleteCacheObjectSelfTest.java    |  186 +
 .../cache/IgniteInternalCacheTypesTest.java     |   16 +-
 ...iteMarshallerCacheClassNameConflictTest.java |  113 +-
 ...lerCacheClientRequestsMappingOnMissTest.java |  136 +-
 ...eMarshallerCacheConcurrentReadWriteTest.java |   12 +-
 .../cache/IgniteNearClientCacheCloseTest.java   |  264 +
 .../cache/IgniteOnePhaseCommitInvokeTest.java   |  213 +
 .../IgniteOnePhaseCommitNearReadersTest.java    |  270 +
 .../cache/IgniteOnePhaseCommitNearSelfTest.java |   18 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |   22 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |   16 +-
 .../IgniteStartCacheInTransactionSelfTest.java  |   22 +-
 .../cache/IgniteStaticCacheStartSelfTest.java   |    6 +-
 .../cache/IgniteSystemCacheOnClientTest.java    |    6 +-
 ...gniteTopologyValidatorAbstractCacheTest.java |  163 +-
 ...ologyValidatorAbstractTxCacheGroupsTest.java |  126 +
 ...iteTopologyValidatorAbstractTxCacheTest.java |   48 +-
 ...opologyValidatorCacheGroupsAbstractTest.java |  131 +
 ...niteTopologyValidatorGridSplitCacheTest.java |  344 ++
 ...torNearPartitionedAtomicCacheGroupsTest.java |   31 +
 ...lidatorNearPartitionedTxCacheGroupsTest.java |   31 +
 ...lidatorPartitionedAtomicCacheGroupsTest.java |   45 +
 ...logyValidatorPartitionedAtomicCacheTest.java |    7 -
 ...gyValidatorPartitionedTxCacheGroupsTest.java |   31 +
 ...alidatorReplicatedAtomicCacheGroupsTest.java |   45 +
 ...ologyValidatorReplicatedAtomicCacheTest.java |    7 -
 ...ogyValidatorReplicatedTxCacheGroupsTest.java |   31 +
 .../processors/cache/IgniteTxAbstractTest.java  |   10 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |   10 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |   15 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |   62 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |   62 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |    4 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |    6 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   50 +-
 .../MarshallerCacheJobRunNodeRestartTest.java   |    4 +-
 .../cache/MemoryPolicyConfigValidationTest.java |  398 ++
 ...AffinityCoordinatorDynamicStartStopTest.java |  139 +
 .../cache/OffHeapTieredTransactionSelfTest.java |  135 -
 ...heapCacheMetricsForClusterGroupSelfTest.java |    7 +-
 .../cache/OffheapCacheOnClientsTest.java        |  143 -
 ...sExchangeOnDiscoveryHistoryOverflowTest.java |  183 +
 .../cache/WithKeepBinaryCacheFullApiTest.java   |  228 +-
 .../BinaryAtomicCacheLocalEntriesSelfTest.java  |   30 +
 .../binary/BinaryMetadataUpdatesFlowTest.java   |  592 +++
 .../BinaryTxCacheLocalEntriesSelfTest.java      |   84 +
 .../CacheKeepBinaryWithInterceptorTest.java     |   26 +-
 ...ryDuplicateIndexObjectsAbstractSelfTest.java |  161 -
 ...yAtomicEntryProcessorDeploymentSelfTest.java |    6 +-
 ...naryObjectMetadataExchangeMultinodeTest.java |  463 ++
 ...acheBinaryObjectUserClassloaderSelfTest.java |   14 +-
 ...naryObjectsAbstractDataStreamerSelfTest.java |    8 +-
 ...aryObjectsAbstractMultiThreadedSelfTest.java |    6 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |  212 +-
 .../GridCacheBinaryStoreAbstractSelfTest.java   |    6 +-
 ...yStoreBinariesSimpleNameMappersSelfTest.java |    4 +-
 ...ntNodeBinaryObjectMetadataMultinodeTest.java |   14 +-
 ...CacheClientNodeBinaryObjectMetadataTest.java |   10 +-
 .../DataStreamProcessorBinarySelfTest.java      |    4 +-
 .../GridDataStreamerImplSelfTest.java           |   30 +-
 .../GridCacheAffinityRoutingBinarySelfTest.java |    4 +-
 ...sNearPartitionedByteArrayValuesSelfTest.java |    4 +-
 ...sPartitionedOnlyByteArrayValuesSelfTest.java |    4 +-
 ...ateIndexObjectPartitionedAtomicSelfTest.java |   38 -
 ...xObjectPartitionedTransactionalSelfTest.java |   41 -
 ...AtomicNearDisabledOffheapTieredSelfTest.java |   29 -
 ...ObjectsAtomicNearDisabledOnheapSelfTest.java |   25 +
 ...inaryObjectsAtomicOffheapTieredSelfTest.java |   29 -
 ...dCacheBinaryObjectsAtomicOnheapSelfTest.java |   25 +
 ...tionedNearDisabledOffheapTieredSelfTest.java |   30 -
 ...tsPartitionedNearDisabledOnheapSelfTest.java |   25 +
 ...ObjectsPartitionedOffheapTieredSelfTest.java |   30 -
 ...eBinaryObjectsPartitionedOnheapSelfTest.java |   25 +
 .../dht/GridCacheMemoryModeBinarySelfTest.java  |   36 -
 ...dCacheOffHeapTieredAtomicBinarySelfTest.java |   48 -
 .../GridCacheOffHeapTieredBinarySelfTest.java   |   48 -
 ...fHeapTieredEvictionAtomicBinarySelfTest.java |   96 -
 ...acheOffHeapTieredEvictionBinarySelfTest.java |   96 -
 ...BinaryObjectsLocalOffheapTieredSelfTest.java |   29 -
 ...idCacheBinaryObjectsLocalOnheapSelfTest.java |   26 +
 ...IgniteCacheAbstractExecutionContextTest.java |   12 +-
 .../IgniteCacheAtomicExecutionContextTest.java  |    7 -
 ...niteCacheContinuousExecutionContextTest.java |    4 +-
 ...IgniteCacheIsolatedExecutionContextTest.java |    4 +-
 ...niteCacheP2PDisableExecutionContextTest.java |    4 +-
 ...iteCachePartitionedExecutionContextTest.java |    7 -
 .../IgniteCachePrivateExecutionContextTest.java |    4 +-
 ...niteCacheReplicatedExecutionContextTest.java |    7 -
 .../IgniteCacheSharedExecutionContextTest.java  |    4 +-
 .../IgniteCacheTxExecutionContextTest.java      |    7 -
 ...eAbstractDataStructuresFailoverSelfTest.java |  140 +-
 ...actQueueFailoverDataConsistencySelfTest.java |   21 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |  132 +-
 ...idCacheAtomicStampedApiSelfAbstractTest.java |  106 +
 .../GridCacheQueueApiSelfAbstractTest.java      |  192 +-
 .../GridCacheQueueCleanupSelfTest.java          |   34 +-
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   12 +-
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |    6 +-
 ...dCacheQueueMultiNodeConsistencySelfTest.java |    7 -
 .../GridCacheSequenceApiSelfAbstractTest.java   |   72 +-
 .../GridCacheSetAbstractSelfTest.java           |  184 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |    6 +-
 .../IgniteAtomicLongApiAbstractSelfTest.java    |   80 +-
 .../IgniteAtomicsAbstractTest.java              |    4 +-
 .../IgniteClientDataStructuresAbstractTest.java |    6 +-
 .../IgniteCollectionAbstractTest.java           |   34 +-
 .../IgniteCountDownLatchAbstractSelfTest.java   |   55 +-
 .../IgniteDataStructureUniqueNameTest.java      |   73 +-
 .../IgniteDataStructureWithJobTest.java         |    4 +-
 ...IgniteDataStructuresNoClassOnServerTest.java |   30 +
 .../IgniteLockAbstractSelfTest.java             |   63 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   71 +-
 ...SemaphoreFailoverSafeReleasePermitsTest.java |   13 +-
 .../GridCacheLocalAtomicOffheapSetSelfTest.java |   32 -
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    6 -
 .../local/GridCacheLocalAtomicSetSelfTest.java  |    7 -
 .../GridCacheLocalOffheapQueueApiSelfTest.java  |   31 -
 .../local/GridCacheLocalQueueApiSelfTest.java   |    7 -
 .../local/GridCacheLocalSetSelfTest.java        |    7 -
 ...artitionedAtomicOffheapQueueApiSelfTest.java |   32 -
 ...omicOffheapQueueCreateMultiNodeSelfTest.java |   32 -
 ...onedAtomicOffheapQueueMultiNodeSelfTest.java |   32 -
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    7 -
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    7 -
 ...micQueueFailoverDataConsistencySelfTest.java |    7 -
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    7 -
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    7 -
 ...titionedAtomicSequenceMultiThreadedTest.java |   32 +
 ...achePartitionedAtomicSequenceTxSelfTest.java |    6 +-
 ...chePartitionedAtomicSetFailoverSelfTest.java |    7 -
 ...rtitionedDataStructuresFailoverSelfTest.java |    7 -
 ...idCachePartitionedNodeRestartTxSelfTest.java |   31 +-
 ...artitionedOffHeapValuesQueueApiSelfTest.java |   35 -
 ...achePartitionedOffHeapValuesSetSelfTest.java |   32 -
 ...edOffheapDataStructuresFailoverSelfTest.java |   33 -
 ...hePartitionedOffheapSetFailoverSelfTest.java |   32 -
 .../GridCachePartitionedQueueApiSelfTest.java   |    7 -
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   15 +-
 ...dCachePartitionedQueueEntryMoveSelfTest.java |    9 +-
 ...nedQueueFailoverDataConsistencySelfTest.java |    7 -
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    7 -
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    7 -
 ...hePartitionedQueueRotativeMultiNodeTest.java |    7 -
 ...GridCachePartitionedSetFailoverSelfTest.java |    7 -
 .../GridCachePartitionedSetSelfTest.java        |    7 -
 .../IgnitePartitionedQueueNoBackupsTest.java    |   13 +-
 .../IgnitePartitionedSetNoBackupsSelfTest.java  |    6 +-
 ...eplicatedDataStructuresFailoverSelfTest.java |    7 -
 .../GridCacheReplicatedQueueApiSelfTest.java    |    7 -
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    7 -
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    7 -
 .../GridCacheReplicatedSetSelfTest.java         |    7 -
 .../CacheAbstractRestartSelfTest.java           |    6 +-
 .../distributed/CacheAffinityEarlyTest.java     |   11 +-
 ...acheAsyncOperationsFailoverAbstractTest.java |   20 +-
 .../distributed/CacheAsyncOperationsTest.java   |   40 +-
 ...CacheAtomicNearUpdateTopologyChangeTest.java |    7 -
 .../CacheAtomicPrimarySyncBackPressureTest.java |  165 +
 .../CacheClientsConcurrentStartTest.java        |  250 +
 .../CacheDiscoveryDataConcurrentJoinTest.java   |  215 +
 .../CacheGetFutureHangsSelfTest.java            |   16 +-
 .../CacheGetInsideLockChangingTopologyTest.java |    6 +-
 .../distributed/CacheGroupsPreloadTest.java     |  194 +
 ...eLateAffinityAssignmentFairAffinityTest.java |   32 -
 ...ffinityAssignmentNodeJoinValidationTest.java |    4 +-
 .../CacheLateAffinityAssignmentTest.java        |  225 +-
 ...CacheLoadingConcurrentGridStartSelfTest.java |   52 +-
 .../CacheLockReleaseNodeLeaveTest.java          |   94 +-
 ...NearDisabledAtomicInvokeRestartSelfTest.java |    6 -
 .../CacheNoValueClassOnServerNodeTest.java      |  112 +-
 .../CachePutAllFailoverAbstractTest.java        |   16 +-
 .../cache/distributed/CacheStartOnJoinTest.java |  260 +
 .../CacheTryLockMultithreadedTest.java          |    8 +-
 ...tractDistributedByteArrayValuesSelfTest.java |  167 +-
 .../GridCacheAbstractJobExecutionTest.java      |   37 +-
 .../GridCacheAbstractNodeRestartSelfTest.java   |  122 +-
 ...tractPartitionedByteArrayValuesSelfTest.java |   41 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java   |   10 +-
 .../GridCacheBasicOpAbstractTest.java           |   68 +-
 .../GridCacheClientModesAbstractSelfTest.java   |   40 +-
 ...ientModesTcpClientDiscoveryAbstractTest.java |    4 +-
 .../GridCacheEntrySetAbstractSelfTest.java      |    2 +-
 ...acheEntrySetIterationPreloadingSelfTest.java |   10 +-
 .../distributed/GridCacheEventAbstractTest.java |  173 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |  122 -
 .../distributed/GridCacheLockAbstractTest.java  |   10 +-
 .../distributed/GridCacheMixedModeSelfTest.java |   16 +-
 .../GridCacheMultiNodeAbstractTest.java         |   39 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |   31 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |   29 +-
 .../GridCacheNodeFailureAbstractTest.java       |   13 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |   33 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |   23 +-
 .../GridCachePreloadEventsAbstractSelfTest.java |    8 +-
 .../GridCachePreloadLifecycleAbstractTest.java  |    4 +-
 ...GridCachePreloadRestartAbstractSelfTest.java |   17 +-
 .../GridCacheTransformEventSelfTest.java        |    8 +-
 ...yMetadataUpdateChangingTopologySelfTest.java |   24 +-
 ...niteBinaryMetadataUpdateNodeRestartTest.java |    6 +-
 .../distributed/IgniteCache150ClientsTest.java  |   13 +-
 ...micMessageRecoveryPairedConnectionsTest.java |    4 +-
 .../IgniteCacheAtomicNodeJoinTest.java          |    6 -
 .../IgniteCacheAtomicNodeRestartTest.java       |    5 -
 ...heClientMultiNodeUpdateTopologyLockTest.java |  201 +
 ...niteCacheClientNodeChangingTopologyTest.java |  296 +-
 .../IgniteCacheClientNodeConcurrentStart.java   |    8 +-
 ...teCacheClientNodePartitionsExchangeTest.java |   63 +-
 .../IgniteCacheClientReconnectTest.java         |    6 +-
 ...acheConnectionRecovery10ConnectionsTest.java |    4 +-
 .../IgniteCacheConnectionRecoveryTest.java      |   16 +-
 .../IgniteCacheCreatePutMultiNodeSelfTest.java  |   11 +-
 .../distributed/IgniteCacheCreatePutTest.java   |   17 +-
 .../distributed/IgniteCacheGetRestartTest.java  |   14 +-
 ...eCacheGroupsPartitionLossPolicySelfTest.java |  355 ++
 .../distributed/IgniteCacheManyClientsTest.java |   10 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java |   12 +-
 ...eCacheMessageRecoveryIdleConnectionTest.java |   12 +-
 .../IgniteCacheMessageWriteTimeoutTest.java     |    4 +-
 .../IgniteCacheNearOffheapGetSelfTest.java      |  136 -
 .../IgniteCacheNearRestartRollbackSelfTest.java |   18 +-
 .../IgniteCacheNodeJoinAbstractTest.java        |    4 +-
 .../IgniteCachePartitionLossPolicySelfTest.java |  337 ++
 .../distributed/IgniteCachePrimarySyncTest.java |    8 +-
 .../IgniteCachePutGetRestartAbstractTest.java   |   10 +-
 .../IgniteCacheReadFromBackupTest.java          |   26 +-
 .../IgniteCacheServerNodeConcurrentStart.java   |   10 +-
 .../IgniteCacheSingleGetMessageTest.java        |    6 +-
 .../IgniteCacheSizeFailoverTest.java            |   10 +-
 .../IgniteCacheSystemTransactionsSelfTest.java  |   17 +-
 .../IgniteCacheTxFairAffinityNodeJoinTest.java  |   35 -
 .../IgniteCacheTxIteratorSelfTest.java          |   59 +-
 ...arDisabledFairAffinityPutGetRestartTest.java |   35 -
 .../IgniteCrossCacheTxStoreSelfTest.java        |   24 +-
 .../IgniteNoClassOnServerAbstractTest.java      |  135 +
 .../IgniteRejectConnectOnNodeStopTest.java      |  188 +
 .../IgniteTxCachePrimarySyncTest.java           |  107 +-
 ...teSynchronizationModesMultithreadedTest.java |   24 +-
 ...iteTxConsistencyRestartAbstractSelfTest.java |   22 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |   27 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |   45 +-
 .../IgniteTxPreloadAbstractTest.java            |    4 +-
 .../IgniteTxTimeoutAbstractTest.java            |    2 +-
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |   64 +-
 ...heAbstractTransformWriteThroughSelfTest.java |    6 +-
 ...acheAtomicExpiredEntriesPreloadSelfTest.java |   46 -
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   19 -
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |  193 +-
 ...EnabledPrimaryWriteOrderFullApiSelfTest.java |   31 -
 ...eAtomicPrimaryWriteOrderFullApiSelfTest.java |   32 -
 ...tomicPrimaryWriteOrderReloadAllSelfTest.java |   32 -
 .../dht/GridCacheColocatedDebugTest.java        |  117 +-
 ...eColocatedOptimisticTransactionSelfTest.java |   10 +-
 ...dCacheColocatedTxSingleThreadedSelfTest.java |    6 +-
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    7 -
 .../dht/GridCacheDhtEntrySelfTest.java          |   24 +-
 .../dht/GridCacheDhtEntrySetSelfTest.java       |    4 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   19 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |  357 --
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |   10 +-
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java |   39 -
 .../dht/GridCacheDhtMappingSelfTest.java        |    8 +-
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |   14 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |   49 +-
 .../GridCacheDhtPreloadDisabledSelfTest.java    |   27 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |   12 +-
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   10 +-
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |   38 -
 .../dht/GridCacheDhtPreloadOnheapSelfTest.java  |   26 +
 .../dht/GridCacheDhtPreloadPerformanceTest.java |    4 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |    8 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |   79 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |   12 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |   28 +-
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    4 +-
 .../dht/GridCacheGlobalLoadTest.java            |   25 +-
 ...icOffHeapTieredMultiNodeFullApiSelfTest.java |   43 -
 ...NearDisabledAtomicOnheapFullApiSelfTest.java |   38 +
 ...ledAtomicOnheapMultiNodeFullApiSelfTest.java |   38 +
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |   36 -
 ...ePartitionedNearDisabledMetricsSelfTest.java |   20 +-
 ...sabledMultiNodeWithGroupFullApiSelfTest.java |   35 +
 ...ionedNearDisabledOffHeapFullApiSelfTest.java |   33 -
 ...DisabledOffHeapMultiNodeFullApiSelfTest.java |   33 -
 ...abledOffHeapTieredAtomicFullApiSelfTest.java |   57 -
 ...earDisabledOffHeapTieredFullApiSelfTest.java |   33 -
 ...edOffHeapTieredMultiNodeFullApiSelfTest.java |   33 -
 ...tionedNearDisabledOnheapFullApiSelfTest.java |   27 +
 ...rDisabledOnheapMultiNodeFullApiSelfTest.java |   27 +
 ...idCachePartitionedPreloadEventsSelfTest.java |   10 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |   24 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |   14 +-
 ...ridCachePartitionedUnloadEventsSelfTest.java |   23 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java     |   47 +-
 .../dht/GridNearCacheTxNodeFailureSelfTest.java |   31 -
 ...gniteAtomicLongChangingTopologySelfTest.java |    4 +-
 .../IgniteCacheClearDuringRebalanceTest.java    |  126 +
 .../IgniteCacheCommitDelayTxRecoveryTest.java   |   26 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |   35 +-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |   60 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java    |   16 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |   10 +-
 ...artitionedBackupNodeFailureRecoveryTest.java |   31 +-
 ...woBackupsPrimaryNodeFailureRecoveryTest.java |    4 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |   25 +-
 .../IgniteCachePutRetryAbstractSelfTest.java    |  191 +-
 .../dht/IgniteCachePutRetryAtomicSelfTest.java  |    6 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |   38 +-
 .../dht/IgniteCacheTxRecoveryRollbackTest.java  |  502 ++
 .../dht/IgniteCrossCacheTxSelfTest.java         |   12 +-
 .../dht/IgniteTxReentryColocatedSelfTest.java   |    2 +-
 .../dht/TxRecoveryStoreEnabledTest.java         |  231 +
 .../AtomicPutAllChangingTopologyTest.java       |    6 +-
 .../atomic/GridCacheAtomicFailoverSelfTest.java |    7 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |  128 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |   14 +-
 ...AtomicPrimaryWriteOrderFailoverSelfTest.java |   36 -
 ...tomicPrimaryWriteOrderRemoveFailureTest.java |   53 -
 .../GridCacheAtomicRemoveFailureTest.java       |    7 -
 ...micPrimaryWriteOrderNearEnabledSelfTest.java |   39 -
 ...sistencyAtomicPrimaryWriteOrderSelfTest.java |   32 -
 .../atomic/IgniteCacheAtomicProtocolTest.java   |  965 ++++
 ...PutRetryAtomicPrimaryWriteOrderSelfTest.java |   32 -
 ...tionedMultiNodeLongTxTimeoutFullApiTest.java |    4 +-
 ...nabledMultiNodeLongTxTimeoutFullApiTest.java |    4 +-
 ...nlyFairAffinityMultiNodeFullApiSelfTest.java |   36 -
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |  177 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 ...yOnReadDisabledMultiNodeFullApiSelfTest.java |    4 +-
 ...micFairAffinityMultiNodeFullApiSelfTest.java |   35 -
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |   35 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   35 -
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |   14 +-
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |   19 -
 ...AtomicMultiNodeWithGroupFullApiSelfTest.java |   34 +
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |   36 -
 ...nabledMultiNodeWithGroupFullApiSelfTest.java |   35 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   31 -
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |   58 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 .../GridCacheAtomicNearRemoveFailureTest.java   |    7 -
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |   67 -
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |   68 -
 ...CacheAtomicOffHeapTieredFullApiSelfTest.java |   32 -
 ...icOffHeapTieredMultiNodeFullApiSelfTest.java |   33 -
 .../GridCacheAtomicOnheapFullApiSelfTest.java   |   28 +
 ...cheAtomicOnheapMultiNodeFullApiSelfTest.java |   26 +
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    6 +-
 ...AtomicPartitionedTckMetricsSelfTestImpl.java |    8 +-
 ...derFairAffinityMultiNodeFullApiSelfTest.java |   36 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   32 -
 ...rderMultiNodeP2PDisabledFullApiSelfTest.java |   33 -
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |   52 -
 ...erNoStripedPoolMultiNodeFullApiSelfTest.java |   35 -
 ...PrimaryWriteOrderOffHeapFullApiSelfTest.java |   32 -
 ...yWriteOrderOffHeapTieredFullApiSelfTest.java |   33 -
 ...ityOrderOffHeapMultiNodeFullApiSelfTest.java |   33 -
 ...erOffHeapTieredMultiNodeFullApiSelfTest.java |   33 -
 .../near/GridCacheGetStoreErrorSelfTest.java    |    8 +-
 .../near/GridCacheNearEvictionSelfTest.java     |   17 +-
 ...dCacheNearExpiredEntriesPreloadSelfTest.java |   33 -
 .../near/GridCacheNearJobExecutionSelfTest.java |    4 +-
 .../near/GridCacheNearMetricsSelfTest.java      |   65 +-
 .../near/GridCacheNearMultiGetSelfTest.java     |   14 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |   54 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |    2 +-
 ...nlyFairAffinityMultiNodeFullApiSelfTest.java |   35 -
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   43 +-
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |   20 +-
 .../GridCacheNearPartitionedClearSelfTest.java  |    6 +-
 .../GridCacheNearReaderPreloadSelfTest.java     |    8 +-
 .../near/GridCacheNearReadersSelfTest.java      |   89 +-
 .../near/GridCacheNearTxForceKeyTest.java       |   22 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   22 +-
 .../near/GridCacheNearTxPreloadSelfTest.java    |    4 +-
 ...AffinityExcludeNeighborsPerformanceTest.java |    6 +-
 ...rtitionedAffinityHashIdResolverSelfTest.java |  102 -
 .../GridCachePartitionedAffinitySelfTest.java   |   28 +-
 ...ePartitionedAtomicOnheapFullApiSelfTest.java |   38 +
 ...nedAtomicOnheapMultiNodeFullApiSelfTest.java |   38 +
 .../near/GridCachePartitionedBasicApiTest.java  |    4 +-
 .../GridCachePartitionedBasicOpSelfTest.java    |    4 +-
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |   27 +-
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |    8 +-
 ...yOnReadDisabledMultiNodeFullApiSelfTest.java |    4 +-
 .../near/GridCachePartitionedEventSelfTest.java |    2 +-
 .../GridCachePartitionedEvictionSelfTest.java   |    9 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    8 +-
 ...GridCachePartitionedFilteredPutSelfTest.java |    6 +-
 .../GridCachePartitionedFullApiSelfTest.java    |   35 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |    9 +-
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |    4 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |   15 +-
 .../near/GridCachePartitionedLockSelfTest.java  |    4 +-
 .../GridCachePartitionedMetricsSelfTest.java    |    8 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |  115 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |  142 +-
 ...onedMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 .../GridCachePartitionedMultiNodeSelfTest.java  |    4 +-
 ...tionedMultiNodeWithGroupFullApiSelfTest.java |   34 +
 ...ePartitionedMultiThreadedPutGetSelfTest.java |   15 +-
 .../near/GridCachePartitionedNestedTxTest.java  |    4 +-
 ...edNoStripedPoolMultiNodeFullApiSelfTest.java |   35 -
 ...GridCachePartitionedNodeFailureSelfTest.java |    4 +-
 .../GridCachePartitionedNodeRestartTest.java    |    5 +-
 ...dCachePartitionedOffHeapFullApiSelfTest.java |   32 -
 ...titionedOffHeapMultiNodeFullApiSelfTest.java |   32 -
 ...PartitionedOffHeapTieredFullApiSelfTest.java |   32 -
 ...edOffHeapTieredMultiNodeFullApiSelfTest.java |   73 -
 ...idCachePartitionedOnheapFullApiSelfTest.java |   26 +
 ...rtitionedOnheapMultiNodeFullApiSelfTest.java |   26 +
 ...ePartitionedOptimisticTxNodeRestartTest.java |    5 +-
 ...achePartitionedPreloadLifecycleSelfTest.java |    5 +-
 .../GridCachePartitionedStorePutSelfTest.java   |   10 +-
 ...GridCachePartitionedTxConcurrentGetTest.java |    4 +-
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    4 +-
 ...CachePartitionedTxMultiThreadedSelfTest.java |    4 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |   15 +-
 ...achePartitionedTxSingleThreadedSelfTest.java |    6 +-
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    4 +-
 .../near/GridCachePutArrayValueSelfTest.java    |    6 +-
 ...idCacheRendezvousAffinityClientSelfTest.java |    6 +-
 .../near/GridNearCacheStoreUpdateTest.java      |  466 ++
 .../near/GridPartitionedBackupLoadSelfTest.java |   12 +-
 .../near/IgniteCacheNearOnlyTxTest.java         |   42 +-
 .../near/IgniteCacheNearReadCommittedTest.java  |    4 +-
 .../near/IgniteCacheNearTxRollbackTest.java     |    4 +-
 .../near/IgniteTxReentryNearSelfTest.java       |    2 +-
 .../near/NearCacheMultithreadedUpdateTest.java  |   12 +-
 .../near/NearCachePutAllMultinodeTest.java      |    9 +-
 .../near/NearCacheSyncUpdateTest.java           |   35 +-
 .../near/NoneRebalanceModeSelfTest.java         |   12 +-
 .../rebalancing/CacheManualRebalancingTest.java |  178 +
 ...cingDelayedPartitionMapExchangeSelfTest.java |   12 +-
 .../GridCacheRebalancingAsyncSelfTest.java      |    4 +-
 .../GridCacheRebalancingOrderingTest.java       |   10 +-
 ...cheRebalancingPartitionDistributionTest.java |    4 +-
 .../GridCacheRebalancingSyncCheckDataTest.java  |   10 +-
 .../GridCacheRebalancingSyncSelfTest.java       |  118 +-
 ...eRebalancingUnmarshallingFailedSelfTest.java |   12 +-
 ...xcludeNeighborsMultiNodeFullApiSelfTest.java |   36 -
 ...tedFairAffinityMultiNodeFullApiSelfTest.java |   35 -
 ...xcludeNeighborsMultiNodeFullApiSelfTest.java |    4 +-
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |    4 +-
 ...stractReplicatedByteArrayValuesSelfTest.java |   36 +-
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    6 +-
 ...nedFairAffinityMultiNodeFullApiSelfTest.java |   37 -
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |   19 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   33 -
 .../GridCacheReplicatedBasicApiTest.java        |    4 +-
 .../GridCacheReplicatedBasicOpSelfTest.java     |    4 +-
 .../GridCacheReplicatedEvictionSelfTest.java    |  135 -
 .../GridCacheReplicatedFullApiSelfTest.java     |   13 +-
 .../GridCacheReplicatedJobExecutionTest.java    |    4 +-
 .../GridCacheReplicatedMarshallerTxTest.java    |    4 +-
 .../GridCacheReplicatedMetricsSelfTest.java     |    4 +-
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |    4 +-
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    4 +-
 .../GridCacheReplicatedNodeFailureSelfTest.java |    4 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java |    7 +-
 ...idCacheReplicatedOffHeapFullApiSelfTest.java |   32 -
 ...plicatedOffHeapMultiNodeFullApiSelfTest.java |   32 -
 ...eReplicatedOffHeapTieredFullApiSelfTest.java |   33 -
 ...edOffHeapTieredMultiNodeFullApiSelfTest.java |   33 -
 ...ridCacheReplicatedOnheapFullApiSelfTest.java |   26 +
 ...eplicatedOnheapMultiNodeFullApiSelfTest.java |   26 +
 .../GridCacheReplicatedTxConcurrentGetTest.java |    4 +-
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    4 +-
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |    4 +-
 ...CacheReplicatedTxSingleThreadedSelfTest.java |    4 +-
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    4 +-
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |  153 -
 .../GridCacheSyncReplicatedPreloadSelfTest.java |   18 +-
 .../replicated/GridReplicatedTxPreloadTest.java |    4 +-
 .../IgniteCacheSyncRebalanceModeSelfTest.java   |    4 +-
 ...CacheReplicatedPreloadLifecycleSelfTest.java |    5 +-
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |   37 -
 .../GridCacheReplicatedPreloadSelfTest.java     |   92 +-
 ...eplicatedPreloadStartStopEventsSelfTest.java |    6 +-
 .../cache/eviction/EvictionAbstractTest.java    |   70 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |  200 -
 ...heConcurrentEvictionConsistencySelfTest.java |   14 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |    9 +-
 .../GridCacheDistributedEvictionsSelfTest.java  |  237 -
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   33 +-
 .../GridCacheEvictableEntryEqualsSelfTest.java  |    1 +
 .../GridCacheEvictionFilterSelfTest.java        |   11 +-
 .../GridCacheEvictionLockUnlockSelfTest.java    |    5 +-
 .../GridCacheEvictionTouchSelfTest.java         |   26 +-
 ...cheSynchronousEvictionsFailoverSelfTest.java |  167 -
 .../lru/LruNearEvictionPolicySelfTest.java      |   39 +-
 .../LruNearOnlyNearEvictionPolicySelfTest.java  |   68 +-
 .../paged/PageEvictionAbstractTest.java         |  138 +
 .../paged/PageEvictionMultinodeTest.java        |  128 +
 .../paged/PageEvictionReadThroughTest.java      |  140 +
 .../paged/PageEvictionTouchOrderTest.java       |  109 +
 .../paged/PageEvictionWithRebalanceTest.java    |   81 +
 ...LruNearEnabledPageEvictionMultinodeTest.java |   28 +
 .../Random2LruPageEvictionMultinodeTest.java    |   30 +
 ...Random2LruPageEvictionWithRebalanceTest.java |   30 +
 ...LruNearEnabledPageEvictionMultinodeTest.java |   28 +
 .../RandomLruPageEvictionMultinodeTest.java     |   30 +
 .../RandomLruPageEvictionWithRebalanceTest.java |   30 +
 .../cache/eviction/paged/TestObject.java        |   78 +
 .../SortedEvictionPolicyPerformanceTest.java    |    8 +-
 .../IgniteCacheAtomicExpiryPolicyTest.java      |    7 -
 ...iteCacheAtomicExpiryPolicyWithStoreTest.java |    7 -
 ...CacheAtomicLocalOffheapExpiryPolicyTest.java |   30 -
 ...eCacheAtomicLocalOnheapExpiryPolicyTest.java |   26 +
 ...gniteCacheAtomicOffheapExpiryPolicyTest.java |   30 -
 ...IgniteCacheAtomicOnheapExpiryPolicyTest.java |   26 +
 ...AtomicPrimaryWriteOrderExpiryPolicyTest.java |   32 -
 ...rimaryWriteOrderOffheapExpiryPolicyTest.java |   31 -
 ...maryWriteOrderWithStoreExpiryPolicyTest.java |   32 -
 ...teOrderWithStoreOffheapExpiryPolicyTest.java |   31 -
 ...AtomicReplicatedOffheapExpiryPolicyTest.java |   30 -
 ...eAtomicWithStoreOffheapExpiryPolicyTest.java |   30 -
 .../IgniteCacheClientNearCacheExpiryTest.java   |   36 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |  187 +-
 .../IgniteCacheExpiryPolicyTestSuite.java       |   17 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |   32 +-
 .../expiry/IgniteCacheLargeValueExpireTest.java |  175 +
 ...eCacheOnlyOneTtlCleanupThreadExistsTest.java |    5 +-
 .../expiry/IgniteCacheTtlCleanupSelfTest.java   |   14 +-
 ...niteCacheTxLocalOffheapExpiryPolicyTest.java |   30 -
 .../IgniteCacheTxOffheapExpiryPolicyTest.java   |   30 -
 ...acheTxReplicatedOffheapExpiryPolicyTest.java |   30 -
 ...CacheTxWithStoreOffheapExpiryPolicyTest.java |   30 -
 .../IgniteCacheAtomicLoadAllTest.java           |    7 -
 .../IgniteCacheAtomicLoaderWriterTest.java      |    7 -
 ...gniteCacheAtomicNoLoadPreviousValueTest.java |    7 -
 .../IgniteCacheAtomicNoReadThroughTest.java     |    7 -
 .../IgniteCacheAtomicNoWriteThroughTest.java    |    7 -
 .../IgniteCacheAtomicStoreSessionTest.java      |    7 -
 ...eCacheAtomicStoreSessionWriteBehindTest.java |    7 -
 ...IgniteCacheJdbcBlobStoreNodeRestartTest.java |   11 +-
 .../IgniteCacheLoadAllAbstractTest.java         |   15 +-
 ...iteCacheNoLoadPreviousValueAbstractTest.java |    8 +-
 .../IgniteCacheNoReadThroughAbstractTest.java   |    8 +-
 .../IgniteCacheNoWriteThroughAbstractTest.java  |    8 +-
 ...IgniteCacheStoreNodeRestartAbstractTest.java |    6 +-
 .../IgniteCacheStoreSessionAbstractTest.java    |   11 +-
 ...acheStoreSessionWriteBehindAbstractTest.java |    8 +-
 .../IgniteCacheTxStoreSessionTest.java          |   22 +-
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |    4 +-
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    6 +-
 ...dCacheAtomicLocalTckMetricsSelfTestImpl.java |    8 +-
 ...LocalAtomicMetricsNoReadThroughSelfTest.java |   48 +
 ...dCacheLocalAtomicOffHeapFullApiSelfTest.java |   42 -
 ...LocalAtomicOffHeapTieredFullApiSelfTest.java |   32 -
 ...acheLocalAtomicWithGroupFullApiSelfTest.java |   34 +
 .../local/GridCacheLocalBasicApiSelfTest.java   |    4 +-
 ...cheLocalBasicStoreMultithreadedSelfTest.java |    1 +
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   75 +-
 .../local/GridCacheLocalFullApiSelfTest.java    |   18 +-
 .../local/GridCacheLocalLoadAllSelfTest.java    |    4 +-
 .../cache/local/GridCacheLocalLockSelfTest.java |    6 +-
 .../local/GridCacheLocalMetricsSelfTest.java    |    8 +-
 .../GridCacheLocalMultithreadedSelfTest.java    |    2 +-
 .../GridCacheLocalOffHeapFullApiSelfTest.java   |   30 -
 ...dCacheLocalOffHeapTieredFullApiSelfTest.java |   32 -
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    4 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    4 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |    2 +-
 .../GridCacheLocalWithGroupFullApiSelfTest.java |   34 +
 ...LocalCacheOffHeapAndSwapMetricsSelfTest.java |  621 ---
 ...OnlyFairAffinityMultiJvmFullApiSelfTest.java |   31 -
 ...omicFairAffinityMultiJvmFullApiSelfTest.java |   31 -
 ...bledFairAffinityMultiJvmFullApiSelfTest.java |   36 -
 ...rimaryWriteOrderMultiJvmFullApiSelfTest.java |   31 -
 ...cheAtomicOffHeapMultiJvmFullApiSelfTest.java |   31 -
 ...micOffHeapTieredMultiJvmFullApiSelfTest.java |   36 -
 ...acheAtomicOnheapMultiJvmFullApiSelfTest.java |   28 +
 ...rderFairAffinityMultiJvmFullApiSelfTest.java |   31 -
 ...rimaryWriteOrderMultiJvmFullApiSelfTest.java |   31 -
 ...OrderMultiJvmP2PDisabledFullApiSelfTest.java |   31 -
 ...rityOrderOffHeapMultiJvmFullApiSelfTest.java |   31 -
 ...derOffHeapTieredMultiJvmFullApiSelfTest.java |   36 -
 ...OnlyFairAffinityMultiJvmFullApiSelfTest.java |   31 -
 ...onedFairAffinityMultiJvmFullApiSelfTest.java |   31 -
 ...micOffHeapTieredMultiJvmFullApiSelfTest.java |   36 -
 ...bledAtomicOnheapMultiJvmFullApiSelfTest.java |   28 +
 ...bledFairAffinityMultiJvmFullApiSelfTest.java |   31 -
 ...rDisabledOffHeapMultiJvmFullApiSelfTest.java |   31 -
 ...ledOffHeapTieredMultiJvmFullApiSelfTest.java |   36 -
 ...arDisabledOnheapMultiJvmFullApiSelfTest.java |   28 +
 ...rtitionedOffHeapMultiJvmFullApiSelfTest.java |   31 -
 ...nedOffHeapTieredMultiJvmFullApiSelfTest.java |   36 -
 ...artitionedOnheapMultiJvmFullApiSelfTest.java |   28 +
 ...rimaryWriteOrderMultiJvmFullApiSelfTest.java |   31 -
 ...eplicatedOffHeapMultiJvmFullApiSelfTest.java |   31 -
 ...tedOffHeapTieredMultiJvmFullApiSelfTest.java |   36 -
 ...ReplicatedOnheapMultiJvmFullApiSelfTest.java |   28 +
 .../IgnitePdsAtomicCacheRebalancingTest.java    |   40 +
 ...tePdsBinaryMetadataOnClusterRestartTest.java |  514 ++
 .../IgnitePdsCacheRebalancingAbstractTest.java  |  539 ++
 .../IgnitePdsClientNearCachePutGetTest.java     |   55 +
 .../IgnitePdsContinuousRestartTest.java         |  261 +
 .../persistence/IgnitePdsDynamicCacheTest.java  |  181 +
 .../IgnitePdsMultiNodePutGetRestartTest.java    |  256 +
 .../persistence/IgnitePdsPageSizesTest.java     |  154 +
 ...gnitePdsRecoveryAfterFileCorruptionTest.java |  365 ++
 .../IgnitePdsRemoveDuringRebalancingTest.java   |  145 +
 ...gnitePdsSingleNodePutGetPersistenceTest.java |   55 +
 .../IgnitePdsTxCacheRebalancingTest.java        |   61 +
 .../IgnitePersistenceMetricsSelfTest.java       |  225 +
 .../IgnitePersistentStoreCacheGroupsTest.java   |  514 ++
 ...IgnitePersistentStoreDataStructuresTest.java |  269 +
 .../MemoryPolicyInitializationTest.java         |  313 ++
 .../db/IgnitePdsMultiNodePutGetRestartTest.java |  246 +
 ...PdsPageEvictionDuringPartitionClearTest.java |  176 +
 .../db/IgnitePdsPageEvictionTest.java           |  241 +
 ...tePdsRebalancingOnNotStableTopologyTest.java |  217 +
 .../db/IgnitePdsTransactionsHangTest.java       |  306 ++
 .../db/IgnitePdsWholeClusterRestartTest.java    |  165 +
 .../db/file/IgnitePdsCacheIntegrationTest.java  |  291 ++
 ...ckpointSimulationWithRealCpDisabledTest.java |  984 ++++
 .../db/file/IgnitePdsEvictionTest.java          |  299 ++
 .../file/IgnitePdsNoActualWalHistoryTest.java   |  219 +
 .../persistence/db/wal/IgnitePdsWalTlbTest.java |  136 +
 .../wal/IgniteWalHistoryReservationsTest.java   |  403 ++
 .../IgniteWalRecoverySeveralRestartsTest.java   |  359 ++
 .../db/wal/IgniteWalRecoveryTest.java           | 1334 +++++
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java |  981 ++++
 .../db/wal/crc/IgniteDataIntegrityTests.java    |  137 +
 .../pagemem/BPlusTreePageMemoryImplTest.java    |   96 +
 .../BPlusTreeReuseListPageMemoryImplTest.java   |   97 +
 .../pagemem/FullPageIdTableTest.java            |  115 +
 .../MetadataStoragePageMemoryImplTest.java      |  102 +
 .../pagemem/NoOpPageStoreManager.java           |  199 +
 .../persistence/pagemem/NoOpWALManager.java     |  128 +
 .../pagemem/PageIdDistributionTest.java         |  234 +
 .../pagemem/PageMemoryImplNoLoadTest.java       |   98 +
 .../persistence/pagemem/PageMemoryImplTest.java |  119 +
 .../AbstractNodeJoinTemplate.java               |  756 +++
 .../IgniteChangeGlobalStateAbstractTest.java    |  366 ++
 .../IgniteChangeGlobalStateCacheTest.java       |  163 +
 ...IgniteChangeGlobalStateDataStreamerTest.java |  112 +
 ...gniteChangeGlobalStateDataStructureTest.java |  278 +
 .../IgniteChangeGlobalStateFailOverTest.java    |  355 ++
 .../IgniteChangeGlobalStateServiceTest.java     |  102 +
 .../IgniteChangeGlobalStateTest.java            |  711 +++
 .../IgniteStandByClusterTest.java               |  322 ++
 .../extended/GridActivateExtensionTest.java     |  239 +
 .../extended/GridActivationAtomicCacheSuit.java |   79 +
 .../GridActivationCacheAbstractTestSuit.java    |  108 +
 .../GridActivationLocalAndNearCacheSuit.java    |   47 +
 .../GridActivationPartitionedCacheSuit.java     |   80 +
 .../GridActivationReplicatedCacheSuit.java      |   63 +
 .../join/JoinActiveNodeToActiveCluster.java     |  442 ++
 .../join/JoinActiveNodeToInActiveCluster.java   |  231 +
 .../join/JoinInActiveNodeToActiveCluster.java   |  373 ++
 .../join/JoinInActiveNodeToInActiveCluster.java |  230 +
 ...ctiveNodeToActiveClusterWithPersistence.java |  106 +
 ...iveNodeToInActiveClusterWithPersistence.java |   31 +
 ...ctiveNodeToActiveClusterWithPersistence.java |   86 +
 ...iveNodeToInActiveClusterWithPersistence.java |   31 +
 ...gniteAbstractStandByClientReconnectTest.java |  336 ++
 .../IgniteStandByClientReconnectTest.java       |  283 ++
 ...eStandByClientReconnectToNewClusterTest.java |  289 ++
 .../persistence/tree/io/TrackingPageIOTest.java |  283 ++
 .../BinaryAtomicCacheLocalEntriesSelfTest.java  |   30 -
 .../BinaryTxCacheLocalEntriesSelfTest.java      |   84 -
 .../GridCacheQueryTransformerSelfTest.java      |    4 +-
 .../GridCacheSwapScanQueryAbstractSelfTest.java |  435 --
 .../query/GridCacheSwapScanQuerySelfTest.java   |   25 -
 .../IgniteCacheQueryCacheDestroySelfTest.java   |    2 -
 .../cache/query/IndexingSpiQuerySelfTest.java   |  105 +-
 .../cache/query/IndexingSpiQueryTxSelfTest.java |   24 +-
 .../IndexingSpiQueryWithH2IndexingSelfTest.java |   36 +
 .../continuous/CacheContinuousBatchAckTest.java |   87 +-
 ...heContinuousBatchForceServerModeAckTest.java |    8 +-
 ...FailoverAtomicPrimaryWriteOrderSelfTest.java |   50 -
 ...tinuousQueryAsyncFailoverAtomicSelfTest.java |   42 +
 ...eContinuousQueryAsyncFilterListenerTest.java |  190 +-
 ...nuousQueryConcurrentPartitionUpdateTest.java |  389 ++
 ...CacheContinuousQueryCounterAbstractTest.java |    8 +-
 .../CacheContinuousQueryEventBufferTest.java    |  217 +
 ...acheContinuousQueryExecuteInPrimaryTest.java |   10 +-
 ...usQueryFactoryFilterRandomOperationTest.java |    2 -
 ...ContinuousQueryFailoverAbstractSelfTest.java |  232 +-
 ...ryFailoverAtomicNearEnabledSelfSelfTest.java |    9 +-
 ...tomicPrimaryWriteOrderOffheapTieredTest.java |   33 -
 ...FailoverAtomicPrimaryWriteOrderSelfTest.java |   44 -
 ...usQueryFailoverAtomicReplicatedSelfTest.java |    9 +-
 ...heContinuousQueryFailoverAtomicSelfTest.java |   36 +
 ...tinuousQueryFailoverTxOffheapTieredTest.java |   32 -
 .../CacheContinuousQueryLostPartitionTest.java  |    6 +-
 ...ontinuousQueryOperationFromCallbackTest.java |    8 +-
 .../CacheContinuousQueryOperationP2PTest.java   |   39 +-
 .../CacheContinuousQueryOrderingEventTest.java  |  136 +-
 ...acheContinuousQueryRandomOperationsTest.java |  331 +-
 .../CacheContinuousQueryVariationsTest.java     |   11 +-
 ...eEntryProcessorExternalizableFailedTest.java |    4 +-
 .../CacheEntryProcessorNonSerializableTest.java |    9 +-
 ...CacheKeepBinaryIterationNearEnabledTest.java |    6 +-
 ...acheKeepBinaryIterationStoreEnabledTest.java |    6 +-
 ...CacheKeepBinaryIterationSwapEnabledTest.java |   56 -
 .../CacheKeepBinaryIterationTest.java           |  111 +-
 .../ClientReconnectContinuousQueryTest.java     |  201 +
 .../ContinuousQueryPeerClassLoadingTest.java    |  142 +
 ...yRemoteFilterMissingInClassPathSelfTest.java |    6 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |   90 +-
 ...eContinuousQueryAtomicOffheapTieredTest.java |   32 -
 ...eContinuousQueryAtomicOffheapValuesTest.java |   32 -
 .../GridCacheContinuousQueryConcurrentTest.java |   58 +-
 ...eContinuousQueryMultiNodesFilteringTest.java |   10 +-
 ...dCacheContinuousQueryNodesFilteringTest.java |    2 +-
 ...dCacheContinuousQueryReplicatedSelfTest.java |    8 +-
 ...eContinuousQueryReplicatedTxOneNodeTest.java |   11 +-
 ...CacheContinuousQueryTxOffheapTieredTest.java |   32 -
 ...CacheContinuousQueryTxOffheapValuesTest.java |   32 -
 ...niteCacheContinuousQueryBackupQueueTest.java |   23 +-
 ...CacheContinuousQueryClientReconnectTest.java |   10 +-
 .../IgniteCacheContinuousQueryClientTest.java   |   45 +-
 ...eCacheContinuousQueryImmutableEntryTest.java |   22 +-
 ...teCacheContinuousQueryNoUnsubscribeTest.java |   20 +-
 ...IgniteCacheContinuousQueryReconnectTest.java |   12 +-
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   24 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |    5 +-
 ...heWriteBehindStoreMultithreadedSelfTest.java |   87 +-
 ...BehindStorePartitionedMultiNodeSelfTest.java |   10 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |  159 +-
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java |    6 +-
 ...CacheClientWriteBehindStoreAbstractTest.java |   14 +-
 ...teCacheClientWriteBehindStoreAtomicTest.java |    7 -
 ...ClientWriteBehindStoreNonCoalescingTest.java |  168 +
 .../transactions/DepthFirstSearchTest.java      |   18 +-
 .../cache/transactions/TxDeadlockCauseTest.java |  279 +
 ...DeadlockDetectionMessageMarshallingTest.java |  116 +
 .../TxDeadlockDetectionNoHangsTest.java         |    4 +-
 .../transactions/TxDeadlockDetectionTest.java   |    4 +-
 .../TxDeadlockDetectionUnmasrhalErrorsTest.java |  225 +
 ...timisticDeadlockDetectionCrossCacheTest.java |    4 +-
 .../TxOptimisticDeadlockDetectionTest.java      |   46 +-
 ...simisticDeadlockDetectionCrossCacheTest.java |    7 +-
 .../TxPessimisticDeadlockDetectionTest.java     |   23 +-
 .../CacheVersionedEntryAbstractTest.java        |   27 +-
 ...edEntryPartitionedAtomicOffHeapSelfTest.java |   35 -
 ...PartitionedTransactionalOffHeapSelfTest.java |   36 -
 ...nedEntryReplicatedAtomicOffHeapSelfTest.java |   35 -
 ...yReplicatedTransactionalOffHeapSelfTest.java |   36 -
 .../clock/GridTimeSyncProcessorSelfTest.java    |  224 -
 .../closure/GridClosureProcessorRemoteTest.java |    2 +-
 .../closure/GridClosureProcessorSelfTest.java   |   78 +-
 .../closure/GridClosureSerializationTest.java   |    4 +-
 .../cluster/GridAddressResolverSelfTest.java    |    6 +-
 .../cluster/GridUpdateNotifierSelfTest.java     |   10 +-
 ...ComputeJobExecutionErrorToLogManualTest.java |   14 +-
 ...gniteComputeConfigVariationsFullApiTest.java |  617 ++-
 ...puteCustomExecutorConfigurationSelfTest.java |   85 +
 .../IgniteComputeCustomExecutorSelfTest.java    |  245 +
 .../compute/PublicThreadpoolStarvationTest.java |    4 +-
 .../continuous/GridEventConsumeSelfTest.java    |  203 +-
 .../continuous/GridMessageListenSelfTest.java   |    4 +-
 .../IgniteNoCustomEventsOnNodeStart.java        |    4 +-
 .../database/BPlusTreeFakeReuseSelfTest.java    |   63 +
 .../database/BPlusTreeReuseSelfTest.java        |  131 +
 .../processors/database/BPlusTreeSelfTest.java  | 1833 +++++++
 .../database/FreeListImplSelfTest.java          |  563 ++
 .../database/IgniteDbAbstractTest.java          |  393 ++
 .../IgniteDbClientNearCachePutGetTest.java      |   39 +
 .../database/IgniteDbDynamicCacheSelfTest.java  |  157 +
 .../IgniteDbMemoryLeakAbstractTest.java         |  272 +
 .../IgniteDbMemoryLeakLargeObjectsTest.java     |   56 +
 .../IgniteDbMemoryLeakLargePagesTest.java       |   33 +
 .../IgniteDbMemoryLeakNonTransactionalTest.java |   31 +
 .../database/IgniteDbMemoryLeakTest.java        |   46 +
 .../IgniteDbMemoryLeakWithExpirationTest.java   |   44 +
 .../database/IgniteDbMultiNodePutGetTest.java   |   33 +
 .../database/IgniteDbPutGetAbstractTest.java    | 1211 +++++
 .../database/IgniteDbSingleNodePutGetTest.java  |   33 +
 .../IgniteDbSingleNodeTinyPutGetTest.java       |  151 +
 .../database/MemoryMetricsSelfTest.java         |  348 ++
 .../database/MetadataStorageSelfTest.java       |  171 +
 .../DataStreamProcessorSelfTest.java            |   76 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |   50 +-
 .../DataStreamerMultiThreadedSelfTest.java      |    6 +-
 .../DataStreamerMultinodeCreateCacheTest.java   |    4 +-
 .../datastreamer/DataStreamerTimeoutTest.java   |    4 +-
 .../DataStreamerUpdateAfterLoadTest.java        |   27 +-
 .../IgniteDataStreamerPerformanceTest.java      |    8 +-
 ...faultIgfsSecondaryFileSystemTestAdapter.java |    4 +-
 .../igfs/IgfsAbstractBaseSelfTest.java          |   64 +-
 .../processors/igfs/IgfsAbstractSelfTest.java   |   32 +-
 .../IgfsAtomicPrimaryOffheapTieredSelfTest.java |   39 -
 .../IgfsAtomicPrimaryOffheapValuesSelfTest.java |   39 -
 .../igfs/IgfsBackupFailoverSelfTest.java        |   20 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |   31 +-
 ...sCachePerBlockLruEvictionPolicySelfTest.java |   25 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |   26 +-
 .../processors/igfs/IgfsCommonAbstractTest.java |    8 +-
 .../igfs/IgfsDataManagerSelfTest.java           |   40 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |   39 +-
 .../processors/igfs/IgfsFileInfoSelfTest.java   |   16 +-
 .../processors/igfs/IgfsIgniteMock.java         |   99 +-
 ...fsLocalSecondaryFileSystemProxySelfTest.java |    1 -
 ...IgfsLocalSecondaryFileSystemTestAdapter.java |    2 +-
 .../processors/igfs/IgfsMaxSizeSelfTest.java    |  122 -
 .../igfs/IgfsMetaManagerSelfTest.java           |   15 +-
 .../processors/igfs/IgfsMetricsSelfTest.java    |   22 +-
 .../internal/processors/igfs/IgfsMock.java      |   52 +-
 .../processors/igfs/IgfsModesSelfTest.java      |  185 +-
 .../processors/igfs/IgfsOneClientNodeTest.java  |   20 +-
 .../igfs/IgfsPrimaryOffheapTieredSelfTest.java  |   33 -
 .../igfs/IgfsPrimaryOffheapValuesSelfTest.java  |   33 -
 .../IgfsPrimaryOptimziedMarshallerSelfTest.java |   28 -
 .../processors/igfs/IgfsProcessorSelfTest.java  |   42 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   |  341 +-
 ...gfsSecondaryFileSystemInjectionSelfTest.java |   16 +-
 .../IgfsSecondaryFileSystemTestAdapter.java     |    2 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |   21 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |   86 +-
 .../processors/igfs/IgfsStartCacheTest.java     |   34 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |   55 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |   35 +-
 .../IgfsAbstractRecordResolverSelfTest.java     |   16 +-
 ...niteMessagingConfigVariationFullApiTest.java |  108 +-
 .../OdbcConfigurationValidationSelfTest.java    |  186 +
 .../odbc/OdbcEscapeSequenceSelfTest.java        |    2 +-
 .../odbc/OdbcProcessorValidationSelfTest.java   |  175 -
 .../cache/GridCacheCommandHandlerSelfTest.java  |    4 +
 .../query/GridQueryCommandHandlerTest.java      |    3 +-
 .../top/CacheTopologyCommandHandlerTest.java    |  152 +
 .../service/ClosureServiceClientsNodesTest.java |   14 +-
 .../service/GridServiceClientNodeTest.java      |   11 +-
 .../GridServiceContinuousQueryRedeployTest.java |  167 +
 .../GridServiceProcessorAbstractSelfTest.java   |  328 +-
 ...ServiceProcessorMultiNodeConfigSelfTest.java |  156 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |  196 +-
 .../GridServiceProcessorProxySelfTest.java      |   24 +-
 .../GridServiceProcessorStopSelfTest.java       |   82 +-
 ...GridServiceProxyClientReconnectSelfTest.java |    6 +-
 .../GridServiceProxyNodeStopSelfTest.java       |    4 +-
 .../GridServiceSerializationSelfTest.java       |    6 +-
 ...gniteServiceConfigVariationsFullApiTest.java |   13 +-
 ...yment2ClassLoadersDefaultMarshallerTest.java |   18 +-
 ...ent2ClassLoadersOptimizedMarshallerTest.java |    2 +-
 ...oymentClassLoadingDefaultMarshallerTest.java |   16 +-
 ...mentClassLoadingOptimizedMarshallerTest.java |    2 +-
 .../IgniteServiceDynamicCachesSelfTest.java     |   18 +-
 ...gniteServiceProxyTimeoutInitializedTest.java |    6 +-
 .../service/IgniteServiceReassignmentTest.java  |    4 +-
 .../ServicePredicateAccessCacheTest.java        |   10 +-
 .../internal/util/GridArraysSelfTest.java       |  129 +
 .../internal/util/StripedExecutorTest.java      |  168 +
 .../util/future/IgniteCacheFutureImplTest.java  |   46 +
 .../util/future/IgniteFutureImplTest.java       |  504 +-
 .../nio/GridNioEmbeddedFutureSelfTest.java      |    2 +-
 .../util/future/nio/GridNioFutureSelfTest.java  |   25 +-
 ...GridUnsafeDataOutputArraySizingSelfTest.java |    4 +-
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   30 +-
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |    6 +-
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |    2 +-
 .../IpcSharedMemoryBenchmarkReader.java         |    3 +-
 .../internal/util/nio/GridNioSelfTest.java      |    2 +-
 .../internal/util/nio/GridNioSslSelfTest.java   |    2 +-
 .../nio/IgniteExceptionInNioWorkerSelfTest.java |    8 +-
 .../nio/impl/GridNioFilterChainSelfTest.java    |   12 +-
 .../offheap/GridOffHeapMapAbstractSelfTest.java |    3 +-
 .../unsafe/GridUnsafeMemorySelfTest.java        |   38 +-
 .../tostring/IncludeSensitiveAtomicTest.java    |   29 +
 .../util/tostring/IncludeSensitiveTest.java     |  149 +
 .../IncludeSensitiveTransactionalTest.java      |   43 +
 .../apache/ignite/lang/GridTupleSelfTest.java   |   35 -
 .../IgniteOffheapReadWriteLockSelfTest.java     |  487 ++
 .../loadtest/GridSingleExecutionTest.java       |   14 +-
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |  252 -
 .../loadtests/GridCacheMultiNodeLoadTest.java   |    7 +-
 .../cache/GridCacheAbstractLoadTest.java        |    9 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |    2 +-
 .../loadtests/cache/GridCacheLoadTest.java      |    4 +-
 .../loadtests/cache/GridCacheSwapLoadTest.java  |  320 --
 .../GridCacheWriteBehindStoreLoadTest.java      |    1 -
 .../capacity/GridCapacityLoadTest.java          |    2 +-
 .../capacity/spring-capacity-cache.xml          |    5 +-
 .../loadtests/colocation/GridTestKey.java       |   28 +-
 .../loadtests/colocation/GridTestMain.java      |    7 +-
 .../loadtests/colocation/spring-colocation.xml  |    5 -
 .../communication/GridIoManagerBenchmark.java   |    8 +-
 .../communication/GridIoManagerBenchmark0.java  |   31 +-
 .../GridTcpCommunicationBenchmark.java          |    2 +-
 .../communication/GridTestMessage.java          |    2 +-
 .../GridContinuousOperationsLoadTest.java       |    2 +-
 .../GridCachePartitionedAtomicLongLoadTest.java |    9 +-
 .../multisplit/GridMultiSplitsLoadTest.java     |   11 +-
 .../GridMultiSplitsRedeployLoadTest.java        |    2 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   27 +-
 ...idSingleSplitsNewNodesMulticastLoadTest.java |    9 +-
 .../GridSingleSplitsRedeployLoadTest.java       |    2 +-
 .../direct/session/GridSessionLoadTest.java     |    2 +-
 .../direct/stealing/GridStealingLoadTest.java   |    4 +-
 .../loadtests/discovery/GridGcTimeoutTest.java  |    2 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |   12 +-
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |    7 +-
 .../loadtests/hashmap/GridCacheTestContext.java |   13 +-
 .../loadtests/hashmap/GridHashMapLoadTest.java  |    4 +-
 ...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 +-
 .../swap/GridSwapEvictAllBenchmark.java         |  309 --
 ...namicProxySerializationMultiJvmSelfTest.java |   19 +-
 .../marshaller/GridMarshallerAbstractTest.java  |   31 +-
 .../GridMarshallerPerformanceTest.java          |    4 +-
 .../marshaller/MarshallerContextSelfTest.java   |   96 +-
 .../marshaller/MarshallerContextTestImpl.java   |    1 +
 .../OptimizedMarshallerEnumSelfTest.java        |   87 -
 .../OptimizedMarshallerNodeFailoverTest.java    |  357 --
 .../OptimizedMarshallerPooledSelfTest.java      |   44 -
 .../optimized/OptimizedMarshallerSelfTest.java  |  283 --
 ...arshallerSerialPersistentFieldsSelfTest.java |  114 -
 .../optimized/OptimizedMarshallerTest.java      |  790 ---
 .../OptimizedObjectStreamSelfTest.java          | 2157 --------
 .../TestTcpDiscoveryIpFinderAdapter.java        |   43 -
 .../marshaller/optimized/package-info.java      |   22 -
 ...GridMessagingNoPeerClassLoadingSelfTest.java |    4 +-
 .../ignite/messaging/GridMessagingSelfTest.java |  202 +-
 .../messaging/IgniteMessagingSendAsyncTest.java |  495 ++
 .../IgniteMessagingWithClientTest.java          |   10 +-
 .../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     |  113 +-
 .../GridP2PMissedResourceCacheSizeSelfTest.java |    4 +-
 .../ignite/p2p/GridP2PNodeLeftSelfTest.java     |    4 +-
 .../p2p/GridP2PRecursionTaskSelfTest.java       |    4 +-
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |    4 +-
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |    6 +-
 .../ignite/p2p/GridP2PTimeoutSelfTest.java      |    4 +-
 .../ignite/p2p/GridP2PUndeploySelfTest.java     |    6 +-
 .../platform/PlatformCacheWriteMetricsTask.java |  159 +-
 .../platform/PlatformComputeEchoTask.java       |   32 +-
 .../platform/PlatformEventsWriteEventTask.java  |   14 +-
 .../PlatformJavaObjectFactoryProxySelfTest.java |    2 +-
 .../ignite/platform/PlatformSqlQueryTask.java   |    2 +-
 .../ignite/platform/PlatformStopIgniteTask.java |   21 +-
 .../plugin/PlatformTestPluginConfiguration.java |   63 +
 ...rmTestPluginConfigurationClosureFactory.java |   61 +
 .../plugin/PlatformTestPluginException.java     |   34 +
 .../plugin/PlatformTestPluginExtension.java     |    2 +-
 .../plugin/PlatformTestPluginProvider.java      |   14 +-
 .../plugin/PlatformTestPluginTarget.java        |  151 +-
 .../cache/PlatformGetCachePluginsTask.java      |   85 +
 .../PlatformTestCachePluginConfiguration.java   |   55 +
 ...formTestCachePluginConfigurationClosure.java |   48 +
 ...tCachePluginConfigurationClosureFactory.java |   37 +
 .../cache/PlatformTestCachePluginProvider.java  |   72 +
 .../SecurityPermissionSetBuilderTest.java       |   83 +-
 .../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  |   11 +-
 .../GridAbstractCommunicationSelfTest.java      |    4 +-
 .../communication/GridCacheMessageSelfTest.java |   60 +-
 .../spi/communication/GridTestMessage.java      |    4 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |   10 +-
 .../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   |  322 ++
 .../TcpCommunicationSpiFaultyClientTest.java    |  269 +
 .../discovery/AbstractDiscoverySelfTest.java    |   36 +-
 .../discovery/AuthenticationRestartTest.java    |   88 +
 ...gniteClientReconnectMassiveShutdownTest.java |   11 +-
 ...pClientDiscoveryMarshallerCheckSelfTest.java |   10 +-
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |  245 +-
 .../tcp/TcpClientDiscoverySpiMulticastTest.java |    4 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |  147 +-
 .../tcp/TcpDiscoveryConcurrentStartTest.java    |    4 +-
 .../TcpDiscoveryMarshallerCheckSelfTest.java    |    8 +-
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |   20 +-
 ...veryNodeAttributesUpdateOnReconnectTest.java |  110 +
 ...DiscoveryNodeConfigConsistentIdSelfTest.java |    6 +-
 .../TcpDiscoveryNodeConsistentIdSelfTest.java   |    4 +-
 .../discovery/tcp/TcpDiscoveryRestartTest.java  |    4 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |   74 +-
 .../tcp/TcpDiscoverySnapshotHistoryTest.java    |    4 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |    6 +-
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |  111 +-
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java    |    4 +-
 .../TcpDiscoverySslSecuredUnsecuredTest.java    |  185 +
 .../discovery/tcp/TcpDiscoverySslSelfTest.java  |    4 +-
 .../tcp/TestReconnectPluginProvider.java        |  118 +
 .../discovery/tcp/TestReconnectProcessor.java   |  136 +
 .../TcpDiscoveryIpFinderAbstractSelfTest.java   |    7 +
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java      |    9 +-
 .../spi/failover/GridFailoverTestContext.java   |    7 +-
 .../GridInternalTasksLoadBalancingSelfTest.java |   34 +-
 .../GridSwapSpaceSpiAbstractSelfTest.java       |  652 ---
 .../GridSwapSpaceSpiConsistencySelfTest.java    |  131 -
 .../file/GridFileSwapCompactionSelfTest.java    |  131 -
 .../file/GridFileSwapSpaceSpiSelfTest.java      |  456 --
 .../inmemory/GridTestSwapSpaceSpi.java          |  518 --
 .../noop/GridNoopSwapSpaceSpiSelfTest.java      |   61 -
 .../ignite/spi/swapspace/package-info.java      |   22 -
 .../startup/GridRandomCommandLineLoader.java    |    2 +-
 .../ignite/startup/GridVmNodesStarter.java      |    4 +-
 .../stream/socket/SocketStreamerSelfTest.java   |   10 +-
 .../testframework/GridSpiTestContext.java       |   10 +-
 .../ignite/testframework/GridStringLogger.java  |   47 +-
 .../ignite/testframework/GridTestNode.java      |   22 +-
 .../ignite/testframework/GridTestUtils.java     |  286 +-
 .../config/GridTestProperties.java              |   12 +-
 .../configvariations/ConfigFactory.java         |    8 +-
 .../configvariations/ConfigVariations.java      |   52 +-
 .../ConfigVariationsFactory.java                |    6 +-
 .../testframework/junits/GridAbstractTest.java  |  472 +-
 .../junits/GridTestKernalContext.java           |    8 +-
 ...IgniteCacheConfigVariationsAbstractTest.java |   71 +-
 .../IgniteConfigVariationsAbstractTest.java     |   12 +-
 .../ignite/testframework/junits/IgniteMock.java |   72 +-
 .../junits/IgniteTestResources.java             |   69 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |   16 +-
 .../junits/common/GridAbstractExamplesTest.java |    2 +-
 .../junits/common/GridCommonAbstractTest.java   |  727 ++-
 .../common/GridRollingRestartAbstractTest.java  |    6 +-
 .../junits/logger/GridTestLog4jLogger.java      |    4 +-
 .../multijvm/IgniteCacheProcessProxy.java       |  225 +-
 .../multijvm/IgniteClusterProcessProxy.java     |   25 +-
 .../multijvm/IgniteEventsProcessProxy.java      |   31 +
 .../junits/multijvm/IgniteNodeRunner.java       |   56 +-
 .../junits/multijvm/IgniteProcessProxy.java     |  206 +-
 .../junits/spi/GridSpiAbstractConfigTest.java   |    2 +-
 .../junits/spi/GridSpiAbstractTest.java         |    9 +-
 .../ConfigVariationsTestSuiteBuilderTest.java   |    4 +-
 .../testframework/test/ParametersTest.java      |    7 +-
 ...naryObjectsTxDeadlockDetectionTestSuite.java |   37 -
 .../ignite/testsuites/IgniteBasicTestSuite.java |   40 +-
 .../testsuites/IgniteBinaryBasicTestSuite.java  |  104 -
 .../IgniteBinaryCacheFullApiTestSuite.java      |   37 -
 .../testsuites/IgniteBinaryCacheTestSuite.java  |   26 +-
 ...ObjectsCacheDataStructuresSelfTestSuite.java |   37 -
 ...BinaryObjectsCacheExpiryPolicyTestSuite.java |   38 -
 ...gniteBinaryObjectsCacheRestartTestSuite.java |   37 -
 .../IgniteBinaryObjectsCacheTestSuite2.java     |   37 -
 .../IgniteBinaryObjectsCacheTestSuite3.java     |   15 +-
 .../IgniteBinaryObjectsCacheTestSuite4.java     |   37 -
 ...IgniteBinaryObjectsComputeGridTestSuite.java |    4 -
 .../IgniteBinaryObjectsTestSuite.java           |   29 +-
 ...iteBinarySimpleNameMapperBasicTestSuite.java |    3 +-
 .../IgniteCacheDataStructuresSelfTestSuite.java |   21 +-
 .../IgniteCacheEvictionSelfTestSuite.java       |   25 +-
 .../IgniteCacheFailoverTestSuite.java           |   10 -
 .../IgniteCacheFailoverTestSuite2.java          |    2 -
 .../IgniteCacheFailoverTestSuite3.java          |    2 -
 ...IgniteCacheFullApiMultiJvmSelfTestSuite.java |   60 +-
 .../IgniteCacheFullApiSelfTestSuite.java        |  137 +-
 .../IgniteCacheMetricsSelfTestSuite.java        |    9 +-
 .../IgniteCacheRestartTestSuite2.java           |    3 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   80 +-
 .../testsuites/IgniteCacheTestSuite2.java       |   71 +-
 .../testsuites/IgniteCacheTestSuite3.java       |   24 +-
 .../testsuites/IgniteCacheTestSuite4.java       |   65 +-
 .../testsuites/IgniteCacheTestSuite5.java       |   39 +-
 .../IgniteCacheTxRecoverySelfTestSuite.java     |    5 +
 .../IgniteCacheWriteBehindTestSuite.java        |    2 +
 .../IgniteClientReconnectTestSuite.java         |    2 +
 ...teBasicConfigVariationsFullApiTestSuite.java |    2 +-
 .../testsuites/IgniteComputeGridTestSuite.java  |   12 +-
 .../testsuites/IgniteDatabaseTestSuite.java     |   40 +
 .../testsuites/IgniteDbMemoryLeakTestSuite.java |   49 +
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |   17 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |   15 +-
 .../testsuites/IgniteLangSelfTestSuite.java     |    3 +
 .../IgniteMarshallerSelfTestSuite.java          |   14 +-
 ...essagingConfigVariationFullApiTestSuite.java |    2 +-
 .../IgnitePdsOutOfMemoryTestSuite.java          |   38 +
 .../ignite/testsuites/IgnitePdsTestSuite.java   |   76 +
 .../ignite/testsuites/IgnitePdsTestSuite2.java  |   74 +
 .../testsuites/IgniteRestHandlerTestSuite.java  |    2 +
 ...ServiceConfigVariationsFullApiTestSuite.java |    2 +-
 .../IgniteSpiCommunicationSelfTestSuite.java    |    5 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    9 +-
 .../IgniteSpiSwapSpaceSelfTestSuite.java        |   44 -
 .../ignite/testsuites/IgniteSpiTestSuite.java   |    3 -
 .../testsuites/IgniteStandByClusterSuite.java   |   72 +
 .../IgniteTopologyValidatorTestSuit.java        |   43 -
 .../IgniteTopologyValidatorTestSuite.java       |   64 +
 .../testsuites/IgniteUtilSelfTestSuite.java     |   11 +
 .../TxDeadlockDetectionTestSuite.java           |    4 +
 .../util/AttributeNodeFilterSelfTest.java       |    4 +-
 .../apache/ignite/util/GridIntListSelfTest.java |  153 +
 .../ignite/util/GridMessageCollectionTest.java  |    5 +-
 .../ignite/util/GridPartitionMapSelfTest.java   |  162 +
 .../apache/ignite/util/GridRandomSelfTest.java  |   17 -
 .../util/GridTopologyHeapSizeSelfTest.java      |    4 +-
 .../webapp/META-INF/ignite-webapp-config.xml    |   28 +-
 modules/docker/1.9.0/Dockerfile                 |   46 +
 modules/docker/1.9.0/run.sh                     |   51 +
 modules/docker/2.0.0/Dockerfile                 |   46 +
 modules/docker/2.0.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |    4 +-
 modules/extdata/p2p/pom.xml                     |    8 +-
 ...CacheDeploymentCachePluginConfiguration.java |   10 +-
 .../tests/p2p/CacheDeploymentTestTask1.java     |    2 +-
 .../tests/p2p/CacheDeploymentTestTask3.java     |    2 +-
 .../p2p/GridP2PContinuousDeploymentTask1.java   |    2 +-
 .../p2p/NoValueClassOnServerAbstractClient.java |   90 +
 .../tests/p2p/P2PTestTaskExternalPath2.java     |    4 +-
 .../CacheNoValueClassOnServerTestClient.java    |   79 +-
 .../apache/ignite/tests/p2p/cache/Person.java   |   41 +
 ...DataStructuresNoClassOnServerTestClient.java |  181 +
 .../extdata/uri/modules/uri-dependency/pom.xml  |    2 +-
 modules/extdata/uri/pom.xml                     |    2 +-
 modules/flink/pom.xml                           |    4 +-
 .../sink/flink/FlinkIgniteSinkSelfTest.java     |   15 +-
 modules/flume/pom.xml                           |    2 +-
 modules/gce/pom.xml                             |    2 +-
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java  |   33 +-
 modules/geospatial/pom.xml                      |    2 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |  101 +-
 .../h2/GridBinaryH2IndexingGeoSelfTest.java     |   35 -
 .../query/h2/GridH2IndexingGeoSelfTest.java     |  285 --
 .../query/h2/H2IndexingAbstractGeoSelfTest.java |  677 +++
 .../query/h2/H2IndexingGeoSelfTest.java         |   30 +
 .../h2/H2IndexingSegmentedGeoSelfTest.java      |   30 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |    9 +-
 modules/hadoop/pom.xml                          |   11 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |   23 +-
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |  698 +--
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |  481 +-
 .../IgniteHadoopWeightedMapReducePlanner.java   |   26 +-
 .../org/apache/ignite/hadoop/package-info.java  |   22 -
 .../ignite/hadoop/planner/package-info.java     |   22 +
 .../hadoop/igfs/HadoopIgfsEndpoint.java         |    6 +-
 ...doopIgfsSecondaryFileSystemDelegateImpl.java |   13 +-
 .../hadoop/impl/igfs/HadoopIgfsEx.java          |    8 +
 .../hadoop/impl/igfs/HadoopIgfsFuture.java      |    3 -
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |  215 +-
 .../hadoop/impl/igfs/HadoopIgfsOutProc.java     |   12 +
 .../hadoop/impl/igfs/HadoopIgfsUtils.java       |    6 +
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java     |  113 +-
 .../hadoop/impl/v1/HadoopV1ReduceTask.java      |    2 +-
 .../hadoop/impl/v2/HadoopV2Context.java         |    7 +-
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |   10 +-
 .../hadoop/jobtracker/HadoopJobTracker.java     |   20 +-
 .../hadoop/shuffle/HadoopShuffle.java           |    9 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |    7 +-
 .../shuffle/streams/HadoopOffheapBuffer.java    |    2 +-
 .../HadoopEmbeddedTaskExecutor.java             |    2 +-
 .../taskexecutor/HadoopExecutorService.java     |   10 +-
 .../external/HadoopExternalTaskExecutor.java    |    7 +-
 .../HadoopExternalCommunication.java            |   29 +-
 .../communication/HadoopIpcToNioAdapter.java    |    7 +-
 .../communication/HadoopMarshallerFilter.java   |   10 +-
 .../resources/META-INF/classnames.properties    |   17 +-
 .../test/config/hadoop-fs-open-test/grid-0.xml  |  125 +
 .../test/config/hadoop-fs-open-test/grid-1.xml  |  125 +
 .../test/config/hadoop-fs-open-test/grid-2.xml  |  125 +
 .../test/config/igfs-cli-config-dual-async.xml  |  134 +
 .../test/config/igfs-cli-config-dual-sync.xml   |  132 +
 .../src/test/config/igfs-cli-config-primary.xml |  123 +
 .../src/test/config/igfs-cli-config-proxy.xml   |  132 +
 .../impl/HadoopAbstractMapReduceTest.java       |   13 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |   36 +-
 .../hadoop/impl/HadoopGroupingTest.java         |    4 +-
 .../hadoop/impl/HadoopJobTrackerSelfTest.java   |    4 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |    4 +-
 .../impl/HadoopNoHadoopMapReduceTest.java       |    4 +-
 .../hadoop/impl/HadoopSortingExternalTest.java  |    8 +-
 .../hadoop/impl/HadoopSortingTest.java          |    4 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |   22 +-
 .../hadoop/impl/HadoopTeraSortTest.java         |    4 +-
 .../hadoop/impl/HadoopValidationSelfTest.java   |    4 +-
 .../HadoopClientProtocolEmbeddedSelfTest.java   |    4 +-
 ...opClientProtocolMultipleServersSelfTest.java |   14 +-
 .../client/HadoopClientProtocolSelfTest.java    |    9 +-
 .../impl/igfs/Hadoop1DualAbstractTest.java      |    6 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   37 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |   78 +-
 ...Igfs20FileSystemLoopbackPrimarySelfTest.java |    4 +-
 ...oopIgfs20FileSystemShmemPrimarySelfTest.java |    4 +-
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |   15 +-
 ...adoopIgfsSecondaryFileSystemTestAdapter.java |    2 +-
 ...oopSecondaryFileSystemConfigurationTest.java |   91 +-
 .../hadoop/impl/igfs/IgfsEventsTestSuite.java   |    2 +-
 .../igfs/IgfsNearOnlyMultiNodeSelfTest.java     |   14 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |  220 +-
 ...opFileSystemClientBasedAbstractSelfTest.java |  193 +
 ...pFileSystemClientBasedDualAsyncSelfTest.java |   38 +
 ...opFileSystemClientBasedDualSyncSelfTest.java |   38 +
 ...niteHadoopFileSystemClientBasedOpenTest.java |  305 ++
 ...oopFileSystemClientBasedPrimarySelfTest.java |   38 +
 ...adoopFileSystemClientBasedProxySelfTest.java |   37 +
 .../IgniteHadoopFileSystemClientSelfTest.java   |   60 +-
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |  160 +-
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java |   53 +-
 .../IgniteHadoopFileSystemLoggerSelfTest.java   |   32 +-
 ...niteHadoopFileSystemLoggerStateSelfTest.java |   24 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    4 +-
 ...oopbackExternalToClientAbstractSelfTest.java |   61 +
 ...opbackExternalToClientDualAsyncSelfTest.java |   33 +
 ...oopbackExternalToClientDualSyncSelfTest.java |   33 +
 ...LoopbackExternalToClientPrimarySelfTest.java |   33 +
 ...emLoopbackExternalToClientProxySelfTest.java |   33 +
 ...condaryFileSystemInitializationSelfTest.java |  217 -
 ...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 +
 .../collections/HadoopSkipListSelfTest.java     |   37 -
 .../taskexecutor/HadoopExecutorServiceTest.java |    3 +-
 .../HadoopExternalTaskExecutionSelfTest.java    |   16 +-
 .../testsuites/IgniteHadoopTestSuite.java       |   24 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |   17 +-
 modules/hibernate-4.2/README.txt                |   48 +
 modules/hibernate-4.2/licenses/apache-2.0.txt   |  202 +
 modules/hibernate-4.2/pom.xml                   |  159 +
 .../HibernateAbstractRegionAccessStrategy.java  |  102 +
 .../hibernate/HibernateCollectionRegion.java    |  100 +
 .../cache/hibernate/HibernateEntityRegion.java  |  112 +
 .../hibernate/HibernateGeneralDataRegion.java   |   76 +
 .../cache/hibernate/HibernateKeyWrapper.java    |   80 +
 .../hibernate/HibernateNaturalIdRegion.java     |  103 +
 .../hibernate/HibernateQueryResultsRegion.java  |   70 +
 .../ignite/cache/hibernate/HibernateRegion.java |   99 +
 .../cache/hibernate/HibernateRegionFactory.java |  179 +
 .../hibernate/HibernateTimestampsRegion.java    |   39 +
 .../HibernateTransactionalDataRegion.java       |   84 +
 .../ignite/cache/hibernate/package-info.java    |   24 +
 .../hibernate/CacheHibernateBlobStore.java      |  542 ++
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 +
 .../CacheHibernateBlobStoreFactory.java         |  235 +
 .../CacheHibernateStoreSessionListener.java     |  222 +
 .../cache/store/hibernate/package-info.java     |   22 +
 .../src/test/config/factory-cache.xml           |   59 +
 .../src/test/config/factory-cache1.xml          |   61 +
 .../config/factory-incorrect-store-cache.xml    |   56 +
 .../HibernateL2CacheConfigurationSelfTest.java  |  409 ++
 .../hibernate/HibernateL2CacheMultiJvmTest.java |  440 ++
 .../hibernate/HibernateL2CacheSelfTest.java     | 1953 +++++++
 .../HibernateL2CacheStrategySelfTest.java       |  597 +++
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 +
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 +
 .../CacheHibernateBlobStoreNodeRestartTest.java |   46 +
 .../CacheHibernateBlobStoreSelfTest.java        |  113 +
 .../CacheHibernateStoreFactorySelfTest.java     |  288 ++
 ...heHibernateStoreSessionListenerSelfTest.java |  238 +
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 +
 .../cache/store/hibernate/package-info.java     |   22 +
 .../IgniteBinaryHibernateTestSuite.java         |   37 +
 .../testsuites/IgniteHibernateTestSuite.java    |   59 +
 modules/hibernate-5.1/README.txt                |   48 +
 modules/hibernate-5.1/licenses/apache-2.0.txt   |  202 +
 modules/hibernate-5.1/pom.xml                   |  159 +
 .../HibernateAbstractRegionAccessStrategy.java  |  103 +
 .../hibernate/HibernateCollectionRegion.java    |  114 +
 .../cache/hibernate/HibernateEntityRegion.java  |  128 +
 .../hibernate/HibernateGeneralDataRegion.java   |   79 +
 .../cache/hibernate/HibernateKeyWrapper.java    |  109 +
 .../hibernate/HibernateNaturalIdRegion.java     |  113 +
 .../hibernate/HibernateQueryResultsRegion.java  |   70 +
 .../ignite/cache/hibernate/HibernateRegion.java |   99 +
 .../cache/hibernate/HibernateRegionFactory.java |  168 +
 .../hibernate/HibernateTimestampsRegion.java    |   39 +
 .../HibernateTransactionalDataRegion.java       |   84 +
 .../ignite/cache/hibernate/package-info.java    |   24 +
 .../hibernate/CacheHibernateBlobStore.java      |  543 ++
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 +
 .../CacheHibernateBlobStoreFactory.java         |  235 +
 .../CacheHibernateStoreSessionListener.java     |  224 +
 .../cache/store/hibernate/package-info.java     |   22 +
 .../src/test/config/factory-cache.xml           |   59 +
 .../src/test/config/factory-cache1.xml          |   61 +
 .../config/factory-incorrect-store-cache.xml    |   56 +
 .../HibernateL2CacheConfigurationSelfTest.java  |  407 ++
 .../hibernate/HibernateL2CacheMultiJvmTest.java |  429 ++
 .../hibernate/HibernateL2CacheSelfTest.java     | 1959 +++++++
 .../HibernateL2CacheStrategySelfTest.java       |  569 +++
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 +
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 +
 .../CacheHibernateBlobStoreNodeRestartTest.java |   46 +
 .../CacheHibernateBlobStoreSelfTest.java        |  114 +
 .../CacheHibernateStoreFactorySelfTest.java     |  256 +
 ...heHibernateStoreSessionListenerSelfTest.java |  242 +
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 +
 .../cache/store/hibernate/package-info.java     |   22 +
 .../IgniteBinaryHibernate5TestSuite.java        |   37 +
 .../testsuites/IgniteHibernate5TestSuite.java   |   59 +
 modules/hibernate-core/pom.xml                  |   76 +
 .../HibernateAccessStrategyAdapter.java         |  340 ++
 .../HibernateAccessStrategyFactory.java         |  235 +
 .../cache/hibernate/HibernateCacheProxy.java    |  776 +++
 .../hibernate/HibernateExceptionConverter.java  |   29 +
 .../hibernate/HibernateKeyTransformer.java      |   29 +
 .../HibernateNonStrictAccessStrategy.java       |  230 +
 .../HibernateReadOnlyAccessStrategy.java        |  105 +
 .../HibernateReadWriteAccessStrategy.java       |  326 ++
 .../HibernateTransactionalAccessStrategy.java   |  141 +
 .../ignite/cache/hibernate/package-info.java    |   24 +
 modules/hibernate/README.txt                    |   48 -
 modules/hibernate/licenses/apache-2.0.txt       |  202 -
 modules/hibernate/pom.xml                       |  146 -
 .../HibernateAbstractRegionAccessStrategy.java  |   98 -
 .../HibernateAccessStrategyAdapter.java         |  377 --
 .../hibernate/HibernateCollectionRegion.java    |  101 -
 .../cache/hibernate/HibernateEntityRegion.java  |  113 -
 .../hibernate/HibernateGeneralDataRegion.java   |   72 -
 .../hibernate/HibernateNaturalIdRegion.java     |  101 -
 .../HibernateNonStrictAccessStrategy.java       |  223 -
 .../hibernate/HibernateQueryResultsRegion.java  |   71 -
 .../HibernateReadOnlyAccessStrategy.java        |  108 -
 .../HibernateReadWriteAccessStrategy.java       |  329 --
 .../ignite/cache/hibernate/HibernateRegion.java |  101 -
 .../cache/hibernate/HibernateRegionFactory.java |  233 -
 .../hibernate/HibernateTimestampsRegion.java    |   40 -
 .../HibernateTransactionalAccessStrategy.java   |  141 -
 .../HibernateTransactionalDataRegion.java       |  108 -
 .../ignite/cache/hibernate/package-info.java    |   24 -
 .../hibernate/CacheHibernateBlobStore.java      |  542 --
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 -
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 -
 .../CacheHibernateBlobStoreFactory.java         |  235 -
 .../CacheHibernateStoreSessionListener.java     |  222 -
 .../cache/store/hibernate/package-info.java     |   22 -
 .../hibernate/src/test/config/factory-cache.xml |   59 -
 .../src/test/config/factory-cache1.xml          |   61 -
 .../config/factory-incorrect-store-cache.xml    |   56 -
 .../HibernateL2CacheConfigurationSelfTest.java  |  408 --
 .../hibernate/HibernateL2CacheSelfTest.java     | 1949 -------
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 -
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |   54 -
 .../CacheHibernateBlobStoreSelfTest.java        |  113 -
 .../CacheHibernateStoreFactorySelfTest.java     |  285 --
 ...heHibernateStoreSessionListenerSelfTest.java |  238 -
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 -
 .../cache/store/hibernate/package-info.java     |   22 -
 .../testsuites/IgniteHibernateTestSuite.java    |   57 -
 modules/indexing/pom.xml                        |    9 +-
 .../cache/query/CacheQueryPartitionInfo.java    |  110 +
 .../cache/query/GridCacheTwoStepQuery.java      |  108 +-
 .../processors/cache/query/QueryTable.java      |  164 +
 .../query/h2/DmlStatementsProcessor.java        |  454 +-
 .../query/h2/GridH2ResultSetIterator.java       |  191 -
 .../query/h2/H2ConnectionWrapper.java           |   67 +
 .../internal/processors/query/h2/H2Cursor.java  |  108 +
 .../processors/query/h2/H2DatabaseType.java     |  161 +
 .../processors/query/h2/H2DmlPlanKey.java       |   66 +
 .../processors/query/h2/H2FieldsIterator.java   |   50 +
 .../processors/query/h2/H2KeyValueIterator.java |   48 +
 .../query/h2/H2ResultSetIterator.java           |  189 +
 .../processors/query/h2/H2RowDescriptor.java    |  489 ++
 .../internal/processors/query/h2/H2Schema.java  |  130 +
 .../processors/query/h2/H2SqlFieldMetadata.java |  111 +
 .../processors/query/h2/H2StatementCache.java   |   73 +
 .../processors/query/h2/H2TableDescriptor.java  |  350 ++
 .../processors/query/h2/H2TableEngine.java      |   89 +
 .../query/h2/H2TwoStepCachedQuery.java          |   63 +
 .../query/h2/H2TwoStepCachedQueryKey.java       |  100 +
 .../internal/processors/query/h2/H2Utils.java   |  244 +
 .../processors/query/h2/IgniteH2Indexing.java   | 2663 ++++------
 .../query/h2/database/H2PkHashIndex.java        |  325 ++
 .../query/h2/database/H2RowFactory.java         |   80 +
 .../processors/query/h2/database/H2Tree.java    |  250 +
 .../query/h2/database/H2TreeIndex.java          |  434 ++
 .../query/h2/database/InlineIndexHelper.java    |  558 ++
 .../query/h2/database/io/H2ExtrasInnerIO.java   |  140 +
 .../query/h2/database/io/H2ExtrasLeafIO.java    |  135 +
 .../query/h2/database/io/H2InnerIO.java         |   74 +
 .../query/h2/database/io/H2LeafIO.java          |   74 +
 .../query/h2/database/io/H2RowLinkIO.java       |   30 +
 .../query/h2/database/util/CompareUtils.java    |  332 ++
 .../query/h2/ddl/DdlStatementsProcessor.java    |  316 ++
 .../query/h2/dml/FastUpdateArguments.java       |    4 +-
 .../processors/query/h2/dml/UpdatePlan.java     |   33 +-
 .../query/h2/dml/UpdatePlanBuilder.java         |   65 +-
 .../query/h2/opt/DistributedJoinMode.java       |   51 +
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |  171 +-
 .../query/h2/opt/GridH2CollocationModel.java    |   86 +-
 .../query/h2/opt/GridH2IndexBase.java           |  592 ++-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   78 +-
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |   14 +-
 .../query/h2/opt/GridH2MetaTable.java           |   13 +-
 .../query/h2/opt/GridH2PrimaryScanIndex.java    |   90 +
 .../query/h2/opt/GridH2ProxyIndex.java          |  204 +
 .../query/h2/opt/GridH2ProxySpatialIndex.java   |   70 +
 .../query/h2/opt/GridH2QueryContext.java        |   84 +-
 .../processors/query/h2/opt/GridH2Row.java      |   66 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |   89 +-
 .../query/h2/opt/GridH2RowFactory.java          |   15 +
 .../query/h2/opt/GridH2ScanIndex.java           |  280 +
 .../query/h2/opt/GridH2SystemIndexFactory.java  |   38 +
 .../processors/query/h2/opt/GridH2Table.java    | 1034 ++--
 .../query/h2/opt/GridH2TreeIndex.java           |  330 +-
 .../query/h2/opt/GridH2ValueCacheObject.java    |   32 +-
 .../query/h2/opt/GridLuceneIndex.java           |   36 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |   93 +-
 .../processors/query/h2/sql/GridSqlAlias.java   |   31 +-
 .../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 +-
 .../query/h2/sql/GridSqlCreateIndex.java        |  121 +
 .../query/h2/sql/GridSqlCreateTable.java        |  222 +
 .../query/h2/sql/GridSqlDropIndex.java          |   82 +
 .../query/h2/sql/GridSqlDropTable.java          |   79 +
 .../processors/query/h2/sql/GridSqlElement.java |   43 +-
 .../query/h2/sql/GridSqlFunction.java           |   18 +-
 .../processors/query/h2/sql/GridSqlJoin.java    |   42 +-
 .../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        |  743 ++-
 .../query/h2/sql/GridSqlQuerySplitter.java      | 2217 ++++++--
 .../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   |   57 +-
 .../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  |  475 +-
 .../query/h2/twostep/GridMergeIndex.java        |  648 ++-
 .../query/h2/twostep/GridMergeIndexSorted.java  |  385 ++
 .../h2/twostep/GridMergeIndexUnsorted.java      |  103 +-
 .../query/h2/twostep/GridMergeTable.java        |   78 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  858 ++--
 .../query/h2/twostep/GridResultPage.java        |   34 +-
 .../query/h2/twostep/GridThreadLocalTable.java  |   14 +-
 .../query/h2/twostep/ReduceQueryRun.java        |  157 +
 .../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 |   41 +-
 .../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    |    2 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |   64 +-
 .../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      |  236 +-
 .../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  |    6 +-
 .../cache/BinarySerializationQuerySelfTest.java |   35 +-
 ...CacheAbstractQueryDetailMetricsSelfTest.java |    4 +-
 .../CacheAbstractQueryMetricsSelfTest.java      |    4 +-
 .../CacheBinaryKeyConcurrentQueryTest.java      |    6 +-
 .../cache/CacheIndexStreamerTest.java           |   14 +-
 .../cache/CacheIndexingOffheapCleanupTest.java  |  178 -
 .../cache/CacheIteratorScanQueryTest.java       |  110 +
 .../CacheOffheapBatchIndexingBaseTest.java      |   12 +-
 .../CacheOffheapBatchIndexingMultiTypeTest.java |   17 +-
 ...CacheOffheapBatchIndexingSingleTypeTest.java |   20 +-
 .../CacheOperationsWithExpirationTest.java      |   73 +-
 .../cache/CacheQueryBuildValueTest.java         |    8 +-
 .../cache/CacheQueryEvictDataLostTest.java      |  120 +
 .../cache/CacheQueryFilterExpiredTest.java      |  111 +
 .../cache/CacheQueryNewClientSelfTest.java      |    4 +-
 .../CacheQueryOffheapEvictDataLostTest.java     |  138 -
 .../CacheRandomOperationsMultithreadedTest.java |   72 +-
 ...CacheScanPartitionQueryFallbackSelfTest.java |   20 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   |  230 +-
 .../ClientReconnectAfterClusterRestartTest.java |   22 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   54 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |  570 ---
 .../cache/GridCacheOffHeapSelfTest.java         |  498 +-
 .../GridCacheOffheapIndexEntryEvictTest.java    |   15 +-
 .../cache/GridCacheOffheapIndexGetSelfTest.java |   42 +-
 .../GridCacheQueryIndexDisabledSelfTest.java    |   24 +-
 .../GridCacheQuerySerializationSelfTest.java    |    4 +-
 .../cache/GridCacheQuerySimpleBenchmark.java    |   10 +-
 .../cache/GridCacheQueryTestValue.java          |    2 +-
 .../processors/cache/GridCacheSwapSelfTest.java |  724 ---
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   13 +-
 .../IgniteBinaryObjectFieldsQuerySelfTest.java  |   16 +-
 ...aryObjectQueryArgumentsOffheapLocalTest.java |   28 -
 ...teBinaryObjectQueryArgumentsOffheapTest.java |   30 -
 .../IgniteBinaryObjectQueryArgumentsTest.java   |   23 +-
 ...eBinaryWrappedObjectFieldsQuerySelfTest.java |    3 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |  542 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |  180 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |  638 ++-
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java |    6 +-
 .../IgniteCacheCollocatedQuerySelfTest.java     |   11 +-
 ...acheConfigurationPrimitiveTypesSelfTest.java |   54 +-
 .../IgniteCacheCrossCacheJoinRandomTest.java    |   10 +-
 .../IgniteCacheDeleteSqlQuerySelfTest.java      |    6 +-
 ...acheDistributedJoinCollocatedAndNotTest.java |    8 +-
 ...acheDistributedJoinCustomAffinityMapper.java |    8 +-
 .../IgniteCacheDistributedJoinNoIndexTest.java  |   12 +-
 ...ributedJoinPartitionedAndReplicatedTest.java |    8 +-
 ...CacheDistributedJoinQueryConditionsTest.java |   24 +-
 .../cache/IgniteCacheDistributedJoinTest.java   |   16 +-
 ...cheDuplicateEntityConfigurationSelfTest.java |    4 +-
 .../IgniteCacheFieldsQueryNoDataSelfTest.java   |    6 +-
 ...teCacheFullTextQueryNodeJoiningSelfTest.java |   10 +-
 .../cache/IgniteCacheGroupsSqlTest.java         |  312 ++
 .../IgniteCacheInsertSqlQuerySelfTest.java      |   71 +-
 ...PartitionedAndReplicatedCollocationTest.java |   13 +-
 ...teCacheJoinPartitionedAndReplicatedTest.java |   67 +-
 ...IgniteCacheJoinQueryWithAffinityKeyTest.java |   26 +-
 .../cache/IgniteCacheLargeResultSelfTest.java   |    9 +-
 ...eLockPartitionOnAffinityRunAbstractTest.java |    8 +-
 ...PartitionOnAffinityRunAtomicCacheOpTest.java |   50 +-
 ...niteCacheLockPartitionOnAffinityRunTest.java |   41 +-
 ...titionOnAffinityRunWithCollisionSpiTest.java |    6 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |   34 -
 .../IgniteCacheMultipleIndexedTypesTest.java    |  200 +
 .../cache/IgniteCacheNoClassQuerySelfTest.java  |   35 +-
 .../IgniteCacheObjectKeyIndexingSelfTest.java   |  124 +
 .../cache/IgniteCacheOffheapEvictQueryTest.java |   16 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java  |   11 +-
 ...CacheOffheapTieredMultithreadedSelfTest.java |  302 --
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |    4 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |    8 +-
 ...IgniteCachePrimitiveFieldsQuerySelfTest.java |    4 +-
 .../cache/IgniteCacheQueriesLoadTest1.java      |    8 +-
 .../IgniteCacheQueryH2IndexingLeakTest.java     |    8 +-
 .../cache/IgniteCacheQueryIndexSelfTest.java    |    4 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java     |   42 +-
 ...QueryMultiThreadedOffHeapTieredSelfTest.java |   38 -
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |  156 +-
 ...QueryOffheapEvictsMultiThreadedSelfTest.java |   28 -
 ...eCacheQueryOffheapMultiThreadedSelfTest.java |   28 -
 ...gniteCacheSqlQueryMultiThreadedSelfTest.java |   10 +-
 .../IgniteCacheStarvationOnRebalanceTest.java   |    6 +-
 .../cache/IgniteCacheUnionDuplicatesTest.java   |   21 +-
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |    9 +-
 ...ClientReconnectCacheQueriesFailoverTest.java |   16 +-
 .../cache/IgniteClientReconnectQueriesTest.java |    4 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |  108 +-
 ...dexingAndGroupPutGetPersistenceSelfTest.java |   42 +
 ...leNodeWithIndexingPutGetPersistenceTest.java |   55 +
 .../cache/IncorrectQueryEntityTest.java         |   82 +
 .../cache/QueryEntityCaseMismatchTest.java      |  107 +
 .../cache/SqlFieldsQuerySelfTest.java           |   37 +-
 ...lientQueryReplicatedNodeRestartSelfTest.java |   10 +-
 ...stributedPartitionQueryAbstractSelfTest.java |  652 +++
 ...utedPartitionQueryConfigurationSelfTest.java |   92 +
 ...butedPartitionQueryNodeRestartsSelfTest.java |  112 +
 ...eCacheDistributedPartitionQuerySelfTest.java |   90 +
 ...niteCacheDistributedQueryCancelSelfTest.java |   12 +-
 ...butedQueryStopOnCancelOrTimeoutSelfTest.java |   12 +-
 ...artitionedFieldsQueryP2PEnabledSelfTest.java |    4 +-
 ...niteCachePartitionedFieldsQuerySelfTest.java |   13 +-
 ...achePartitionedQueryP2PDisabledSelfTest.java |    4 +-
 .../IgniteCachePartitionedQuerySelfTest.java    |   91 +-
 ...cheQueryAbstractDistributedJoinSelfTest.java |    6 +-
 .../IgniteCacheQueryNoRebalanceSelfTest.java    |    4 +-
 .../near/IgniteCacheQueryNodeFailTest.java      |    8 +-
 ...QueryNodeRestartDistributedJoinSelfTest.java |  165 +-
 .../IgniteCacheQueryNodeRestartSelfTest.java    |    9 +-
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |   11 +-
 ...ReplicatedFieldsQueryP2PEnabledSelfTest.java |    4 +-
 ...iteCacheReplicatedFieldsQueryROSelfTest.java |   27 +
 ...gniteCacheReplicatedFieldsQuerySelfTest.java |    6 +-
 ...CacheReplicatedQueryP2PDisabledSelfTest.java |    4 +-
 .../IgniteCacheReplicatedQuerySelfTest.java     |   25 +-
 .../cache/index/AbstractSchemaSelfTest.java     |  649 +++
 .../index/DuplicateKeyValueClassesSelfTest.java |   94 +
 .../DynamicIndexAbstractBasicSelfTest.java      | 1176 +++++
 .../DynamicIndexAbstractConcurrentSelfTest.java | 1076 ++++
 .../index/DynamicIndexAbstractSelfTest.java     |  464 ++
 .../index/DynamicIndexClientBasicSelfTest.java  |   28 +
 ...ndexPartitionedAtomicConcurrentSelfTest.java |   33 +
 ...titionedTransactionalConcurrentSelfTest.java |   33 +
 ...IndexReplicatedAtomicConcurrentSelfTest.java |   33 +
 ...plicatedTransactionalConcurrentSelfTest.java |   33 +
 .../index/DynamicIndexServerBasicSelfTest.java  |   28 +
 ...amicIndexServerCoordinatorBasicSelfTest.java |   28 +
 ...namicIndexServerNodeFIlterBasicSelfTest.java |   28 +
 ...erverNodeFilterCoordinatorBasicSelfTest.java |   30 +
 .../index/H2DynamicIndexAbstractSelfTest.java   |  400 ++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...H2DynamicIndexAtomicPartitionedSelfTest.java |   39 +
 .../H2DynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 ...exingComplexClientAtomicPartitionedTest.java |   33 +
 ...dexingComplexClientAtomicReplicatedTest.java |   33 +
 ...mplexClientTransactionalPartitionedTest.java |   33 +
 ...omplexClientTransactionalReplicatedTest.java |   33 +
 ...exingComplexServerAtomicPartitionedTest.java |   33 +
 ...dexingComplexServerAtomicReplicatedTest.java |   33 +
 ...mplexServerTransactionalPartitionedTest.java |   33 +
 ...omplexServerTransactionalReplicatedTest.java |   33 +
 .../index/H2DynamicIndexingComplexTest.java     |  356 ++
 .../cache/index/H2DynamicTableSelfTest.java     |  929 ++++
 .../index/QueryEntityValidationSelfTest.java    |  162 +
 .../cache/index/SchemaExchangeSelfTest.java     |  639 +++
 .../IgniteCacheLocalFieldsQuerySelfTest.java    |    4 +-
 ...eCacheLocalQueryCancelOrTimeoutSelfTest.java |   10 +-
 .../local/IgniteCacheLocalQuerySelfTest.java    |    4 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java     |   41 +-
 .../ttl/CacheTtlAtomicAbstractSelfTest.java     |   29 +
 .../cache/ttl/CacheTtlAtomicLocalSelfTest.java  |   34 +
 .../ttl/CacheTtlAtomicPartitionedSelfTest.java  |   34 +
 .../ttl/CacheTtlOffheapAbstractSelfTest.java    |   29 -
 .../CacheTtlOffheapAtomicAbstractSelfTest.java  |   29 -
 .../ttl/CacheTtlOffheapAtomicLocalSelfTest.java |   34 -
 ...acheTtlOffheapAtomicPartitionedSelfTest.java |   34 -
 ...TtlOffheapTransactionalAbstractSelfTest.java |   29 -
 ...cheTtlOffheapTransactionalLocalSelfTest.java |   34 -
 ...OffheapTransactionalPartitionedSelfTest.java |   34 -
 .../ttl/CacheTtlOnheapAbstractSelfTest.java     |   29 -
 .../CacheTtlOnheapAtomicAbstractSelfTest.java   |   29 -
 .../ttl/CacheTtlOnheapAtomicLocalSelfTest.java  |   34 -
 ...CacheTtlOnheapAtomicPartitionedSelfTest.java |   34 -
 ...eTtlOnheapTransactionalAbstractSelfTest.java |   29 -
 ...acheTtlOnheapTransactionalLocalSelfTest.java |   34 -
 ...lOnheapTransactionalPartitionedSelfTest.java |   34 -
 .../CacheTtlTransactionalAbstractSelfTest.java  |   29 +
 .../ttl/CacheTtlTransactionalLocalSelfTest.java |   34 +
 ...acheTtlTransactionalPartitionedSelfTest.java |   34 +
 .../database/IgniteDbMemoryLeakIndexedTest.java |   33 +
 .../IgniteDbMemoryLeakSqlQueryTest.java         |   76 +
 ...IgniteDbMultiNodeWithIndexingPutGetTest.java |   28 +
 ...gniteDbSingleNodeWithIndexingPutGetTest.java |  249 +
 .../IgnitePersistentStoreSchemaLoadTest.java    |  297 ++
 .../IgniteCacheGroupsCompareQueryTest.java      |   45 +
 ...teCacheGroupsSqlDistributedJoinSelfTest.java |   30 +
 ...roupsSqlSegmentedIndexMultiNodeSelfTest.java |   28 +
 ...iteCacheGroupsSqlSegmentedIndexSelfTest.java |   37 +
 .../query/IgniteQueryDedicatedPoolTest.java     |  212 +
 .../query/IgniteSqlDistributedJoinSelfTest.java |  199 +
 .../query/IgniteSqlKeyValueFieldsTest.java      |  392 ++
 .../query/IgniteSqlQueryDedicatedPoolTest.java  |  110 -
 .../processors/query/IgniteSqlRoutingTest.java  |  552 ++
 .../query/IgniteSqlSchemaIndexingTest.java      |   42 +-
 ...gniteSqlSegmentedIndexMultiNodeSelfTest.java |   28 +
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  329 ++
 .../query/IgniteSqlSplitterSelfTest.java        | 1250 ++++-
 .../processors/query/SqlSchemaSelfTest.java     |  263 +
 .../query/h2/GridH2IndexRebuildTest.java        |  261 -
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  476 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java      |  376 ++
 .../h2/database/InlineIndexHelperTest.java      |  357 ++
 .../query/h2/opt/GridH2TableSelfTest.java       |  278 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |  104 +-
 .../query/h2/sql/BaseH2CompareQueryTest.java    |  369 +-
 .../query/h2/sql/GridQueryParsingTest.java      |  744 ++-
 .../query/h2/sql/H2CompareBigQueryTest.java     |  156 +-
 ...onnectorConfigurationValidationSelfTest.java |  240 +
 .../FetchingQueryCursorStressTest.java          |  277 +
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    4 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |    9 -
 .../IgniteBinaryCacheQueryTestSuite2.java       |    4 -
 .../IgniteBinaryCacheQueryTestSuite3.java       |   39 -
 .../IgniteBinaryCacheQueryTestSuite4.java       |   39 -
 .../IgniteCacheQuerySelfTestSuite.java          |  130 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |   32 +-
 .../IgniteCacheQuerySelfTestSuite3.java         |   23 +-
 .../IgniteCacheQuerySelfTestSuite4.java         |   12 +-
 .../IgniteCacheWithIndexingTestSuite.java       |   35 +-
 ...IgniteDbMemoryLeakWithIndexingTestSuite.java |   40 +
 .../IgniteDistributedJoinTestSuite.java         |   55 +
 .../IgniteH2IndexingSpiTestSuite.java           |   37 -
 .../IgnitePdsWithIndexingCoreTestSuite.java     |   57 +
 .../IgnitePdsWithIndexingTestSuite.java         |   46 +
 .../processors/query/h2/sql/bigQuery.sql        |   50 +-
 modules/jcl/pom.xml                             |    2 +-
 modules/jms11/pom.xml                           |    2 +-
 .../stream/jms11/IgniteJmsStreamerTest.java     |   28 +-
 modules/jta/pom.xml                             |    2 +-
 .../processors/cache/jta/CacheJtaManager.java   |    3 +-
 .../processors/cache/jta/CacheJtaResource.java  |    8 +-
 .../cache/AbstractCacheJtaSelfTest.java         |    8 +-
 ...CacheJtaConfigurationValidationSelfTest.java |    6 +-
 ...CacheJtaFactoryConfigValidationSelfTest.java |    6 +-
 .../cache/GridJtaLifecycleAwareSelfTest.java    |    4 +-
 ...titionedCacheJtaLookupClassNameSelfTest.java |    2 +-
 modules/kafka/pom.xml                           |    2 +-
 .../stream/kafka/connect/IgniteSourceTask.java  |    4 -
 .../kafka/KafkaIgniteStreamerSelfTest.java      |    8 +-
 .../ignite/stream/kafka/TestKafkaBroker.java    |    2 +-
 .../kafka/connect/IgniteSinkConnectorTest.java  |    3 +-
 .../connect/IgniteSourceConnectorTest.java      |    3 +-
 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 +
 modules/log4j/pom.xml                           |    2 +-
 .../apache/ignite/logger/log4j/Log4JLogger.java |    4 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |    8 +-
 modules/log4j2/pom.xml                          |    6 +-
 .../ignite/logger/log4j2/Log4J2Logger.java      |   23 +-
 .../log4j2/GridLog4j2CorrectFileNameTest.java   |    6 +-
 .../log4j2/GridLog4j2InitializedTest.java       |    5 +-
 .../log4j2/GridLog4j2LoggingFileTest.java       |    3 +-
 .../logger/log4j2/Log4j2LoggerSelfTest.java     |    6 +-
 .../log4j2/Log4j2LoggerVerboseModeSelfTest.java |    6 +-
 modules/mesos/pom.xml                           |    2 +-
 .../apache/ignite/mesos/IgniteFramework.java    |  111 +-
 .../org/apache/ignite/mesos/IgniteTask.java     |    3 +-
 .../ignite/mesos/IgniteSchedulerSelfTest.java   |   39 +-
 modules/ml/README.txt                           |   15 +
 modules/ml/licenses/apache-2.0.txt              |  202 +
 modules/ml/licenses/mit.txt                     |    7 +
 modules/ml/pom.xml                              |  114 +
 .../main/java/org/apache/ignite/ml/Model.java   |   39 +
 .../ml/clustering/BaseKMeansClusterer.java      |   98 +
 .../apache/ignite/ml/clustering/Clusterer.java  |   32 +
 .../ml/clustering/ClusterizationModel.java      |   29 +
 .../clustering/KMeansDistributedClusterer.java  |  298 ++
 .../ml/clustering/KMeansLocalClusterer.java     |  174 +
 .../ignite/ml/clustering/KMeansModel.java       |   79 +
 .../ignite/ml/clustering/WeightedClusterer.java |   38 +
 .../ignite/ml/clustering/package-info.java      |   22 +
 .../java/org/apache/ignite/ml/math/Algebra.java |  590 +++
 .../org/apache/ignite/ml/math/Constants.java    |   59 +
 .../org/apache/ignite/ml/math/Destroyable.java  |   30 +
 .../apache/ignite/ml/math/DistanceMeasure.java  |   39 +
 .../ignite/ml/math/EuclideanDistance.java       |   48 +
 .../ignite/ml/math/IdentityValueMapper.java     |   54 +
 .../org/apache/ignite/ml/math/KeyMapper.java    |   33 +
 .../org/apache/ignite/ml/math/MathUtils.java    |   31 +
 .../java/org/apache/ignite/ml/math/Matrix.java  |  520 ++
 .../apache/ignite/ml/math/MatrixKeyMapper.java  |   30 +
 .../apache/ignite/ml/math/MatrixStorage.java    |   58 +
 .../apache/ignite/ml/math/MetaAttributes.java   |   76 +
 .../org/apache/ignite/ml/math/MurmurHash.java   |  247 +
 .../org/apache/ignite/ml/math/Precision.java    |  588 +++
 .../apache/ignite/ml/math/StorageConstants.java |   52 +
 .../ignite/ml/math/StorageOpsMetrics.java       |   49 +
 .../java/org/apache/ignite/ml/math/Tracer.java  |  463 ++
 .../org/apache/ignite/ml/math/ValueMapper.java  |   37 +
 .../java/org/apache/ignite/ml/math/Vector.java  |  499 ++
 .../apache/ignite/ml/math/VectorKeyMapper.java  |   29 +
 .../apache/ignite/ml/math/VectorStorage.java    |   53 +
 .../org/apache/ignite/ml/math/VectorUtils.java  |   41 +
 .../decompositions/CholeskyDecomposition.java   |  310 ++
 .../decompositions/DecompositionSupport.java    |  105 +
 .../math/decompositions/EigenDecomposition.java |  936 ++++
 .../ml/math/decompositions/LUDecomposition.java |  383 ++
 .../ml/math/decompositions/QRDecomposition.java |  246 +
 .../SingularValueDecomposition.java             |  623 +++
 .../ml/math/decompositions/package-info.java    |   22 +
 .../math/exceptions/CardinalityException.java   |   36 +
 .../math/exceptions/ColumnIndexException.java   |   35 +
 .../math/exceptions/ConvergenceException.java   |   48 +
 .../ml/math/exceptions/IndexException.java      |   35 +
 .../exceptions/InsufficientDataException.java   |   44 +
 .../exceptions/MathArithmeticException.java     |   45 +
 .../MathIllegalArgumentException.java           |   37 +
 .../exceptions/MathIllegalNumberException.java  |   51 +
 .../exceptions/MathIllegalStateException.java   |   49 +
 .../math/exceptions/MathRuntimeException.java   |   47 +
 .../ml/math/exceptions/NoDataException.java     |   45 +
 .../NonPositiveDefiniteMatrixException.java     |   35 +
 .../exceptions/NonSquareMatrixException.java    |   33 +
 .../exceptions/NonSymmetricMatrixException.java |   35 +
 .../math/exceptions/NullArgumentException.java  |   27 +
 .../exceptions/NumberIsTooSmallException.java   |   79 +
 .../ml/math/exceptions/RowIndexException.java   |   35 +
 .../exceptions/SingularMatrixException.java     |   33 +
 .../exceptions/UnknownProviderException.java    |   35 +
 .../UnsupportedOperationException.java          |   44 +
 .../ignite/ml/math/exceptions/package-info.java |   22 +
 .../ignite/ml/math/functions/Functions.java     |  194 +
 .../ml/math/functions/IgniteBiConsumer.java     |   29 +
 .../ml/math/functions/IgniteBiFunction.java     |   29 +
 .../ml/math/functions/IgniteConsumer.java       |   29 +
 .../ml/math/functions/IgniteDoubleFunction.java |   29 +
 .../ml/math/functions/IgniteFunction.java       |   30 +
 .../math/functions/IntDoubleToVoidFunction.java |   25 +
 .../functions/IntIntDoubleToVoidFunction.java   |   32 +
 .../math/functions/IntIntToDoubleFunction.java  |   24 +
 .../ignite/ml/math/functions/package-info.java  |   22 +
 .../apache/ignite/ml/math/impls/CacheUtils.java |  446 ++
 .../ml/math/impls/matrix/AbstractMatrix.java    |  887 ++++
 .../ml/math/impls/matrix/CacheMatrix.java       |  159 +
 .../impls/matrix/DenseLocalOffHeapMatrix.java   |   85 +
 .../impls/matrix/DenseLocalOnHeapMatrix.java    |   86 +
 .../ml/math/impls/matrix/DiagonalMatrix.java    |  101 +
 .../ml/math/impls/matrix/FunctionMatrix.java    |   95 +
 .../ignite/ml/math/impls/matrix/MatrixView.java |   84 +
 .../ml/math/impls/matrix/PivotedMatrixView.java |  241 +
 .../ml/math/impls/matrix/RandomMatrix.java      |   97 +
 .../impls/matrix/SparseDistributedMatrix.java   |  153 +
 .../impls/matrix/SparseLocalOnHeapMatrix.java   |   72 +
 .../math/impls/matrix/TransposedMatrixView.java |   84 +
 .../ml/math/impls/matrix/package-info.java      |   22 +
 .../ignite/ml/math/impls/package-info.java      |   22 +
 .../storage/matrix/ArrayMatrixStorage.java      |  161 +
 .../storage/matrix/CacheMatrixStorage.java      |  185 +
 .../matrix/DenseOffHeapMatrixStorage.java       |  206 +
 .../storage/matrix/DiagonalMatrixStorage.java   |  136 +
 .../storage/matrix/FunctionMatrixStorage.java   |  179 +
 .../impls/storage/matrix/MapWrapperStorage.java |  110 +
 .../storage/matrix/MatrixDelegateStorage.java   |  205 +
 .../storage/matrix/PivotedMatrixStorage.java    |  256 +
 .../storage/matrix/RandomMatrixStorage.java     |  176 +
 .../matrix/SparseDistributedMatrixStorage.java  |  318 ++
 .../matrix/SparseLocalOnHeapMatrixStorage.java  |  228 +
 .../math/impls/storage/matrix/package-info.java |   22 +
 .../storage/vector/ArrayVectorStorage.java      |  135 +
 .../storage/vector/CacheVectorStorage.java      |  175 +
 .../storage/vector/ConstantVectorStorage.java   |  134 +
 .../storage/vector/DelegateVectorStorage.java   |  163 +
 .../vector/DenseLocalOffHeapVectorStorage.java  |  172 +
 .../storage/vector/FunctionVectorStorage.java   |  143 +
 .../storage/vector/MatrixVectorStorage.java     |  184 +
 .../storage/vector/PivotedVectorStorage.java    |  176 +
 .../storage/vector/RandomVectorStorage.java     |  152 +
 .../SingleElementVectorDelegateStorage.java     |  145 +
 .../vector/SingleElementVectorStorage.java      |  145 +
 .../vector/SparseLocalOffHeapVectorStorage.java |  153 +
 .../vector/SparseLocalOnHeapVectorStorage.java  |  185 +
 .../math/impls/storage/vector/package-info.java |   22 +
 .../impls/vector/AbstractReadOnlyVector.java    |  125 +
 .../ml/math/impls/vector/AbstractVector.java    |  907 ++++
 .../ml/math/impls/vector/CacheVector.java       |  140 +
 .../ml/math/impls/vector/ConstantVector.java    |   84 +
 .../ml/math/impls/vector/DelegatingVector.java  |  396 ++
 .../impls/vector/DenseLocalOffHeapVector.java   |   89 +
 .../impls/vector/DenseLocalOnHeapVector.java    |  104 +
 .../ml/math/impls/vector/FunctionVector.java    |  112 +
 .../ml/math/impls/vector/MapWrapperVector.java  |   49 +
 .../ml/math/impls/vector/MatrixVectorView.java  |  144 +
 .../ml/math/impls/vector/PivotedVectorView.java |  163 +
 .../ml/math/impls/vector/RandomVector.java      |  130 +
 .../math/impls/vector/SingleElementVector.java  |  102 +
 .../impls/vector/SingleElementVectorView.java   |   97 +
 .../impls/vector/SparseLocalOffHeapVector.java  |   47 +
 .../ml/math/impls/vector/SparseLocalVector.java |   80 +
 .../ignite/ml/math/impls/vector/VectorView.java |   86 +
 .../ml/math/impls/vector/package-info.java      |   22 +
 .../org/apache/ignite/ml/math/package-info.java |   22 +
 .../ignite/ml/math/statistics/Variance.java     |   53 +
 .../org/apache/ignite/ml/math/util/MapUtil.java |   38 +
 .../apache/ignite/ml/math/util/MatrixUtil.java  |  156 +
 .../AbstractMultipleLinearRegression.java       |  358 ++
 .../regressions/MultipleLinearRegression.java   |   71 +
 .../OLSMultipleLinearRegression.java            |  272 +
 .../regressions/RegressionsErrorMessages.java   |   28 +
 .../ignite/ml/regressions/package-info.java     |   22 +
 .../ignite/ml/math/d3-matrix-template.html      |  119 +
 .../ignite/ml/math/d3-vector-template.html      |  104 +
 .../org/apache/ignite/ml/IgniteMLTestSuite.java |   37 +
 .../java/org/apache/ignite/ml/TestUtils.java    |  248 +
 .../ml/clustering/ClusteringTesetSuite.java     |   32 +
 .../KMeansDistributedClustererTest.java         |  184 +
 .../ml/clustering/KMeansLocalClustererTest.java |   46 +
 .../apache/ignite/ml/clustering/KMeansUtil.java |   33 +
 .../apache/ignite/ml/math/ExternalizeTest.java  |   67 +
 .../ml/math/MathImplDistributedTestSuite.java   |   39 +
 .../ignite/ml/math/MathImplLocalTestSuite.java  |  124 +
 .../ignite/ml/math/MathImplMainTestSuite.java   |   34 +
 .../org/apache/ignite/ml/math/TracerTest.java   |  198 +
 .../ignite/ml/math/benchmark/MathBenchmark.java |  205 +
 .../math/benchmark/MathBenchmarkSelfTest.java   |  100 +
 .../ignite/ml/math/benchmark/ResultsWriter.java |  127 +
 .../ml/math/benchmark/VectorBenchmarkTest.java  |  138 +
 .../ignite/ml/math/benchmark/package-info.java  |   18 +
 .../CholeskyDecompositionTest.java              |  160 +
 .../decompositions/EigenDecompositionTest.java  |  193 +
 .../decompositions/LUDecompositionTest.java     |  252 +
 .../decompositions/QRDecompositionTest.java     |  141 +
 .../SingularValueDecompositionTest.java         |  122 +
 .../ignite/ml/math/impls/MathTestConstants.java |   88 +
 .../ml/math/impls/matrix/CacheMatrixTest.java   |  371 ++
 .../DenseLocalOffHeapMatrixConstructorTest.java |   65 +
 .../DenseLocalOnHeapMatrixConstructorTest.java  |   71 +
 .../math/impls/matrix/DiagonalMatrixTest.java   |  209 +
 .../matrix/FunctionMatrixConstructorTest.java   |  113 +
 .../math/impls/matrix/MatrixAttributeTest.java  |  156 +
 .../matrix/MatrixImplementationFixtures.java    |  381 ++
 .../impls/matrix/MatrixImplementationsTest.java | 1113 ++++
 .../impls/matrix/MatrixKeyMapperForTests.java   |   74 +
 .../impls/matrix/MatrixViewConstructorTest.java |  114 +
 .../PivotedMatrixViewConstructorTest.java       |  129 +
 .../matrix/RandomMatrixConstructorTest.java     |   71 +
 .../matrix/SparseDistributedMatrixTest.java     |  303 ++
 .../SparseLocalOnHeapMatrixConstructorTest.java |   53 +
 .../impls/matrix/TransposedMatrixViewTest.java  |   87 +
 .../storage/matrix/MatrixArrayStorageTest.java  |   63 +
 .../storage/matrix/MatrixBaseStorageTest.java   |   89 +
 .../matrix/MatrixOffHeapStorageTest.java        |   39 +
 .../storage/matrix/MatrixStorageFixtures.java   |  143 +
 .../matrix/MatrixStorageImplementationTest.java |   73 +
 .../SparseDistributedMatrixStorageTest.java     |  126 +
 .../RandomAccessSparseVectorStorageTest.java    |   60 +
 .../SparseLocalOffHeapVectorStorageTest.java    |   79 +
 .../storage/vector/VectorArrayStorageTest.java  |   58 +
 .../storage/vector/VectorBaseStorageTest.java   |   69 +
 .../vector/VectorOffheapStorageTest.java        |   73 +
 .../math/impls/vector/AbstractVectorTest.java   |  544 ++
 .../ml/math/impls/vector/CacheVectorTest.java   |  436 ++
 .../vector/ConstantVectorConstructorTest.java   |   52 +
 .../vector/DelegatingVectorConstructorTest.java |   62 +
 .../DenseLocalOffHeapVectorConstructorTest.java |   59 +
 .../DenseLocalOnHeapVectorConstructorTest.java  |  163 +
 .../vector/FunctionVectorConstructorTest.java   |  121 +
 .../math/impls/vector/MatrixVectorViewTest.java |  226 +
 .../PivotedVectorViewConstructorTest.java       |  211 +
 .../vector/RandomVectorConstructorTest.java     |  145 +
 .../SingleElementVectorConstructorTest.java     |  159 +
 .../SingleElementVectorViewConstructorTest.java |  137 +
 .../SparseLocalVectorConstructorTest.java       |   54 +
 .../math/impls/vector/VectorAttributesTest.java |  217 +
 .../ml/math/impls/vector/VectorFoldMapTest.java |  122 +
 .../vector/VectorImplementationsFixtures.java   |  655 +++
 .../impls/vector/VectorImplementationsTest.java |  861 ++++
 .../math/impls/vector/VectorIterableTest.java   |  376 ++
 .../ml/math/impls/vector/VectorNormTest.java    |  247 +
 .../math/impls/vector/VectorToMatrixTest.java   |  308 ++
 .../ml/math/impls/vector/VectorViewTest.java    |  162 +
 .../AbstractMultipleLinearRegressionTest.java   |  164 +
 .../OLSMultipleLinearRegressionTest.java        |  819 +++
 .../ml/regressions/RegressionsTestSuite.java    |   32 +
 modules/mqtt/pom.xml                            |    2 +-
 .../stream/mqtt/IgniteMqttStreamerTest.java     |   12 +-
 modules/osgi-karaf/pom.xml                      |    2 +-
 .../osgi-karaf/src/main/resources/features.xml  |   11 +-
 modules/osgi-paxlogging/pom.xml                 |    2 +-
 modules/osgi/README.txt                         |   30 -
 modules/osgi/pom.xml                            |    3 +-
 .../IgniteAbstractOsgiContextActivator.java     |    2 +-
 .../activators/BasicIgniteTestActivator.java    |    2 +-
 modules/platforms/.gitignore                    |   31 +
 modules/platforms/cpp/binary/Makefile.am        |   68 +-
 .../platforms/cpp/binary/include/Makefile.am    |   57 +-
 .../binary/binary_array_identity_resolver.h     |   64 -
 .../include/ignite/binary/binary_consts.h       |   86 +-
 .../include/ignite/binary/binary_containers.h   |   14 +-
 .../ignite/binary/binary_identity_resolver.h    |   61 -
 .../include/ignite/binary/binary_object.h       |   99 +-
 .../include/ignite/binary/binary_raw_reader.h   |   25 +-
 .../include/ignite/binary/binary_raw_writer.h   |   35 +-
 .../include/ignite/binary/binary_reader.h       |   27 +-
 .../binary/include/ignite/binary/binary_type.h  |  139 +-
 .../include/ignite/binary/binary_writer.h       |   34 +-
 .../include/ignite/impl/binary/binary_common.h  |   12 +
 .../ignite/impl/binary/binary_field_meta.h      |  110 +
 .../ignite/impl/binary/binary_id_resolver.h     |   93 +-
 .../ignite/impl/binary/binary_object_header.h   |   22 +-
 .../ignite/impl/binary/binary_object_impl.h     |  154 +-
 .../ignite/impl/binary/binary_reader_impl.h     |  262 +-
 .../include/ignite/impl/binary/binary_schema.h  |   29 +-
 .../ignite/impl/binary/binary_type_handler.h    |   47 +-
 .../ignite/impl/binary/binary_type_impl.h       |  136 +-
 .../ignite/impl/binary/binary_type_manager.h    |   50 +-
 .../ignite/impl/binary/binary_type_snapshot.h   |   82 +-
 .../ignite/impl/binary/binary_type_updater.h    |   19 +-
 .../include/ignite/impl/binary/binary_utils.h   |   41 +-
 .../ignite/impl/binary/binary_writer_impl.h     |  106 +-
 .../cpp/binary/project/vs/binary.vcxproj        |    7 +-
 .../binary/project/vs/binary.vcxproj.filters    |   17 +-
 .../binary/binary_array_identity_resolver.cpp   |   42 -
 .../cpp/binary/src/binary/binary_raw_reader.cpp |   12 +-
 .../cpp/binary/src/binary/binary_raw_writer.cpp |   10 +
 .../cpp/binary/src/binary/binary_reader.cpp     |   14 +-
 .../cpp/binary/src/binary/binary_writer.cpp     |   10 +
 .../src/impl/binary/binary_field_meta.cpp       |   42 +
 .../src/impl/binary/binary_object_header.cpp    |   26 +-
 .../src/impl/binary/binary_object_impl.cpp      |  182 +-
 .../src/impl/binary/binary_reader_impl.cpp      |  227 +-
 .../binary/src/impl/binary/binary_schema.cpp    |   17 +-
 .../src/impl/binary/binary_type_handler.cpp     |   45 +-
 .../binary/src/impl/binary/binary_type_impl.cpp |   61 +
 .../src/impl/binary/binary_type_manager.cpp     |  194 +-
 .../src/impl/binary/binary_type_snapshot.cpp    |   50 +-
 .../src/impl/binary/binary_type_updater.cpp     |   32 -
 .../cpp/binary/src/impl/binary/binary_utils.cpp |   12 +
 .../src/impl/binary/binary_writer_impl.cpp      |  119 +-
 modules/platforms/cpp/common/Makefile.am        |   52 +-
 modules/platforms/cpp/common/configure.ac       |   62 +
 .../platforms/cpp/common/include/Makefile.am    |    7 +-
 .../common/include/ignite/common/cancelable.h   |   65 +
 .../common/include/ignite/common/concurrent.h   |   59 +-
 .../include/ignite/common/platform_utils.h      |    6 +-
 .../cpp/common/include/ignite/common/promise.h  |  219 +
 .../common/include/ignite/common/shared_state.h |  382 ++
 .../cpp/common/include/ignite/common/utils.h    |   78 +-
 .../cpp/common/include/ignite/future.h          |  284 ++
 .../cpp/common/include/ignite/ignite_error.h    |    8 +-
 .../cpp/common/include/ignite/reference.h       |   14 +-
 .../platforms/cpp/common/include/ignite/time.h  |  138 +
 .../linux/include/ignite/common/concurrent_os.h |  234 +-
 .../include/ignite/common/dynamic_load_os.h     |  131 +
 .../os/linux/src/common/dynamic_load_os.cpp     |   90 +
 .../os/linux/src/common/platform_utils.cpp      |   18 +-
 .../win/include/ignite/common/concurrent_os.h   |  169 +-
 .../win/include/ignite/common/dynamic_load_os.h |  133 +
 .../common/os/win/src/common/concurrent_os.cpp  |   26 +-
 .../os/win/src/common/dynamic_load_os.cpp       |  115 +
 .../common/os/win/src/common/platform_utils.cpp |   26 +-
 .../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   |   33 +-
 .../platforms/cpp/common/src/ignite_error.cpp   |   68 +-
 modules/platforms/cpp/common/src/time.cpp       |   83 +
 modules/platforms/cpp/configure.ac              |    2 +-
 modules/platforms/cpp/configure.acrel           |    2 +-
 modules/platforms/cpp/core-test/Makefile.am     |   95 +-
 .../cpp/core-test/config/cache-identity-32.xml  |   53 +
 .../core-test/config/cache-identity-default.xml |  154 +
 .../cpp/core-test/config/cache-identity.xml     |   91 +-
 .../cpp/core-test/config/cache-query-32.xml     |   52 +
 .../config/cache-query-continuous-32.xml        |   48 +
 .../config/cache-query-continuous-default.xml   |   86 +
 .../core-test/config/cache-query-continuous.xml |   61 +-
 .../core-test/config/cache-query-default.xml    |  182 +
 .../cpp/core-test/config/cache-query.xml        |   91 +-
 .../cpp/core-test/config/cache-store-32.xml     |   52 +
 .../core-test/config/cache-store-default.xml    |   71 +
 .../cpp/core-test/config/cache-store.xml        |   34 +
 .../cpp/core-test/config/cache-test-32.xml      |   52 +
 .../cpp/core-test/config/cache-test-default.xml |  133 +
 .../cpp/core-test/config/cache-test.xml         |  106 +-
 modules/platforms/cpp/core-test/configure.ac    |   62 +
 .../core-test/include/ignite/binary_test_defs.h |  205 +-
 .../include/ignite/binary_test_utils.h          |   53 +
 .../cpp/core-test/include/ignite/complex_type.h |   32 +-
 .../cpp/core-test/include/ignite/test_type.h    |   55 +-
 .../cpp/core-test/include/ignite/test_utils.h   |   31 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |   25 +
 .../project/vs/core-test.vcxproj.filters        |   54 +
 .../src/binary_identity_resolver_test.cpp       |  223 +-
 .../cpp/core-test/src/binary_object_test.cpp    |  308 +-
 .../src/binary_reader_writer_raw_test.cpp       |  777 +--
 .../core-test/src/binary_reader_writer_test.cpp | 1013 +---
 .../cpp/core-test/src/binary_session_test.cpp   |   20 +-
 .../cpp/core-test/src/binary_test_defs.cpp      |    5 +
 .../cpp/core-test/src/cache_invoke_test.cpp     |  528 ++
 .../cpp/core-test/src/cache_query_test.cpp      |  451 +-
 .../cpp/core-test/src/cache_store_test.cpp      |  160 +
 .../platforms/cpp/core-test/src/cache_test.cpp  |  320 +-
 .../cpp/core-test/src/cluster_test.cpp          |   86 +
 .../cpp/core-test/src/compute_test.cpp          |  513 ++
 .../cpp/core-test/src/concurrent_test.cpp       |   47 +
 .../cpp/core-test/src/continuous_query_test.cpp |  218 +-
 .../cpp/core-test/src/date_time_test.cpp        |  287 ++
 .../platforms/cpp/core-test/src/future_test.cpp |  474 ++
 .../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         |   18 +-
 .../cpp/core-test/src/interop_memory_test.cpp   |    5 +-
 .../cpp/core-test/src/interop_test.cpp          |    4 +
 .../cpp/core-test/src/reference_test.cpp        |   14 +-
 .../platforms/cpp/core-test/src/test_utils.cpp  |   17 +
 .../cpp/core-test/src/transactions_test.cpp     |   82 +-
 modules/platforms/cpp/core/Makefile.am          |   80 +-
 modules/platforms/cpp/core/configure.ac         |   62 +
 modules/platforms/cpp/core/include/Makefile.am  |   89 +-
 .../cpp/core/include/ignite/cache/cache.h       |  466 +-
 .../cpp/core/include/ignite/cache/cache_entry.h |   15 +
 .../ignite/cache/cache_entry_processor.h        |   81 +
 .../core/include/ignite/cache/cache_peek_mode.h |   67 +-
 .../cache/event/cache_entry_event_filter.h      |  109 +
 .../include/ignite/cache/mutable_cache_entry.h  |  176 +
 .../cache/query/continuous/continuous_query.h   |   37 +-
 .../cpp/core/include/ignite/cache/query/query.h |    1 -
 .../include/ignite/cache/query/query_argument.h |  134 -
 .../include/ignite/cache/query/query_cursor.h   |   30 +-
 .../core/include/ignite/cache/query/query_sql.h |   26 +-
 .../ignite/cache/query/query_sql_fields.h       |   80 +-
 .../cpp/core/include/ignite/compute/compute.h   |  167 +
 .../core/include/ignite/compute/compute_func.h  |   65 +
 .../platforms/cpp/core/include/ignite/ignite.h  |   55 +-
 .../cpp/core/include/ignite/ignite_binding.h    |  169 +
 .../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     |  119 +
 .../impl/cache/cache_entry_processor_holder.h   |  281 +
 .../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    |  100 +
 .../ignite/impl/compute/cancelable_impl.h       |   70 +
 .../include/ignite/impl/compute/compute_impl.h  |  160 +
 .../ignite/impl/compute/compute_job_holder.h    |  212 +
 .../ignite/impl/compute/compute_job_result.h    |  273 +
 .../ignite/impl/compute/compute_task_holder.h   |  298 ++
 .../cpp/core/include/ignite/impl/helpers.h      |   57 +
 .../include/ignite/impl/ignite_binding_impl.h   |  135 +
 .../include/ignite/impl/ignite_environment.h    |  145 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |   74 +-
 .../ignite/impl/interop/interop_target.h        |   76 +-
 .../core/include/ignite/impl/module_manager.h   |  157 +
 .../cpp/core/include/ignite/impl/operations.h   |  198 +-
 .../ignite/impl/transactions/transaction_impl.h |    4 +-
 .../impl/transactions/transactions_impl.h       |   10 +-
 .../include/ignite/transactions/transaction.h   |   12 +-
 .../ignite/transactions/transaction_consts.h    |  181 +-
 .../include/ignite/transactions/transactions.h  |   16 +-
 .../platforms/cpp/core/project/vs/core.vcxproj  |   26 +-
 .../cpp/core/project/vs/core.vcxproj.filters    |   90 +-
 modules/platforms/cpp/core/src/ignite.cpp       |   17 +-
 modules/platforms/cpp/core/src/ignition.cpp     |  373 +-
 .../impl/binary/binary_type_updater_impl.cpp    |  106 +-
 .../cpp/core/src/impl/cache/cache_impl.cpp      |  204 +-
 .../continuous/continuous_query_handle_impl.cpp |   20 +-
 .../core/src/impl/cache/query/query_impl.cpp    |   47 +-
 .../src/impl/cluster/cluster_group_impl.cpp     |   78 +
 .../core/src/impl/compute/cancelable_impl.cpp   |   59 +
 .../cpp/core/src/impl/compute/compute_impl.cpp  |   35 +
 .../cpp/core/src/impl/ignite_binding_impl.cpp   |   88 +
 .../cpp/core/src/impl/ignite_environment.cpp    |  476 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |   39 +-
 .../core/src/impl/interop/interop_target.cpp    |  105 +-
 .../src/impl/transactions/transaction_impl.cpp  |   18 +-
 .../src/impl/transactions/transactions_impl.cpp |  102 +-
 .../cpp/core/src/transactions/transaction.cpp   |    8 +-
 .../cpp/core/src/transactions/transactions.cpp  |   20 +-
 modules/platforms/cpp/examples/Makefile.am      |    3 +-
 .../cpp/examples/compute-example/Makefile.am    |   59 +
 .../compute-example/config/compute-example.xml  |   52 +
 .../project/vs/compute-example.vcxproj          |  102 +
 .../project/vs/compute-example.vcxproj.filters  |   27 +
 .../compute-example/src/compute_example.cpp     |  179 +
 modules/platforms/cpp/examples/configure.ac     |    5 +-
 .../project/vs/continuous-query-example.vcxproj |    4 -
 .../src/continuous_query_example.cpp            |  132 +-
 .../examples/include/ignite/examples/address.h  |   26 +-
 .../include/ignite/examples/organization.h      |   26 +-
 .../examples/include/ignite/examples/person.h   |   17 +-
 .../cpp/examples/odbc-example/Makefile.am       |   12 +-
 .../odbc-example/config/example-odbc.xml        |    6 -
 .../examples/odbc-example/src/odbc_example.cpp  |    7 +-
 .../cpp/examples/project/vs/ignite-examples.sln |   18 +-
 .../cpp/examples/put-get-example/Makefile.am    |   58 +
 .../put-get-example/config/example-cache.xml    |   67 +
 .../project/vs/put-get-example.vcxproj          |  110 +
 .../project/vs/put-get-example.vcxproj.filters  |   38 +
 .../put-get-example/src/put_get_example.cpp     |  125 +
 .../cpp/examples/putget-example/Makefile.am     |   58 -
 .../putget-example/config/example-cache.xml     |   75 -
 .../project/vs/putget-example.vcxproj           |  107 -
 .../project/vs/putget-example.vcxproj.filters   |   30 -
 .../putget-example/src/putget_example.cpp       |  126 -
 .../cpp/examples/query-example/Makefile.am      |   12 +-
 .../project/vs/query-example.vcxproj            |    3 +
 .../project/vs/query-example.vcxproj.filters    |    8 +
 .../query-example/src/query_example.cpp         |   11 +-
 modules/platforms/cpp/ignite/configure.ac       |   62 +
 .../cpp/jni/include/ignite/jni/exports.h        |    3 +-
 .../platforms/cpp/jni/include/ignite/jni/java.h |    9 +-
 .../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 |    3 +-
 .../platforms/cpp/jni/project/vs/targetver.h    |   25 -
 modules/platforms/cpp/jni/src/exports.cpp       |    8 +-
 modules/platforms/cpp/jni/src/java.cpp          |   83 +-
 .../cpp/odbc-test/config/queries-default.xml    |    7 +-
 .../cpp/odbc-test/config/queries-test-32.xml    |   49 +
 .../odbc-test/config/queries-test-default.xml   |   39 +
 .../odbc-test/config/queries-test-noodbc-32.xml |   53 +
 .../odbc-test/config/queries-test-noodbc.xml    |    6 +-
 .../cpp/odbc-test/config/queries-test.xml       |   11 +-
 .../cpp/odbc-test/include/complex_type.h        |   53 +-
 .../odbc-test/include/sql_test_suite_fixture.h  |    7 +-
 .../platforms/cpp/odbc-test/include/test_type.h |   67 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    5 +
 .../project/vs/odbc-test.vcxproj.filters        |   15 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |   75 +-
 .../src/application_data_buffer_test.cpp        |  346 +-
 .../platforms/cpp/odbc-test/src/column_test.cpp |   63 +-
 .../cpp/odbc-test/src/configuration_test.cpp    |  120 +-
 .../cpp/odbc-test/src/connection_info_test.cpp  |   72 +-
 .../platforms/cpp/odbc-test/src/cursor_test.cpp |    6 +-
 .../cpp/odbc-test/src/queries_test.cpp          |  851 +++-
 .../platforms/cpp/odbc-test/src/row_test.cpp    |   17 +-
 .../src/sql_date_time_functions_test.cpp        |    5 +
 .../src/sql_esc_convert_function_test.cpp       |    8 +-
 .../odbc-test/src/sql_test_suite_fixture.cpp    |   37 +-
 .../cpp/odbc-test/src/sql_types_test.cpp        |   24 +-
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |    8 +
 modules/platforms/cpp/odbc/Makefile.am          |    3 +
 modules/platforms/cpp/odbc/README.txt           |   17 +-
 modules/platforms/cpp/odbc/include/Makefile.am  |    2 +
 .../ignite/odbc/app/application_data_buffer.h   |   59 +-
 .../odbc/include/ignite/odbc/app/parameter.h    |   20 +-
 .../include/ignite/odbc/app/parameter_set.h     |  268 +
 .../cpp/odbc/include/ignite/odbc/column.h       |    2 +-
 .../cpp/odbc/include/ignite/odbc/common_types.h |  350 +-
 .../include/ignite/odbc/config/configuration.h  |   76 +-
 .../ignite/odbc/config/connection_info.h        |    2 +-
 .../cpp/odbc/include/ignite/odbc/connection.h   |   26 +-
 .../ignite/odbc/diagnostic/diagnosable.h        |    8 +-
 .../odbc/diagnostic/diagnosable_adapter.h       |    8 +-
 .../ignite/odbc/diagnostic/diagnostic_record.h  |    4 +-
 .../odbc/diagnostic/diagnostic_record_storage.h |    8 +-
 .../cpp/odbc/include/ignite/odbc/environment.h  |   10 +-
 .../cpp/odbc/include/ignite/odbc/message.h      |  495 +-
 .../odbc/include/ignite/odbc/protocol_version.h |  103 +-
 .../include/ignite/odbc/query/batch_query.h     |  160 +
 .../ignite/odbc/query/column_metadata_query.h   |   10 +-
 .../odbc/include/ignite/odbc/query/data_query.h |   35 +-
 .../ignite/odbc/query/foreign_keys_query.h      |    8 +-
 .../ignite/odbc/query/primary_keys_query.h      |    8 +-
 .../cpp/odbc/include/ignite/odbc/query/query.h  |   35 +-
 .../ignite/odbc/query/special_columns_query.h   |    8 +-
 .../ignite/odbc/query/table_metadata_query.h    |   10 +-
 .../include/ignite/odbc/query/type_info_query.h |   10 +-
 .../cpp/odbc/include/ignite/odbc/row.h          |    2 +-
 .../cpp/odbc/include/ignite/odbc/statement.h    |  115 +-
 .../odbc/system/ui/dsn_configuration_window.h   |   51 +-
 .../cpp/odbc/include/ignite/odbc/type_traits.h  |   96 +-
 .../cpp/odbc/install/ignite-odbc-amd64.wxs      |    2 +-
 .../cpp/odbc/install/ignite-odbc-x86.wxs        |    2 +-
 .../cpp/odbc/install/install_amd64.cmd          |   14 +-
 .../platforms/cpp/odbc/install/install_x86.cmd  |    8 +-
 .../ignite/odbc/system/ui/custom_window.h       |   12 +-
 .../odbc/os/win/src/system/ui/custom_window.cpp |    4 +-
 .../src/system/ui/dsn_configuration_window.cpp  |  126 +-
 .../cpp/odbc/os/win/src/system_dsn.cpp          |    2 +-
 .../platforms/cpp/odbc/project/vs/odbc.vcxproj  |    5 +
 .../cpp/odbc/project/vs/odbc.vcxproj.filters    |   15 +
 .../odbc/src/app/application_data_buffer.cpp    |  614 ++-
 .../platforms/cpp/odbc/src/app/parameter.cpp    |   24 +-
 .../cpp/odbc/src/app/parameter_set.cpp          |  242 +
 modules/platforms/cpp/odbc/src/column.cpp       |   32 +-
 modules/platforms/cpp/odbc/src/common_types.cpp |   54 +-
 .../cpp/odbc/src/config/configuration.cpp       |    8 +-
 .../cpp/odbc/src/config/connection_info.cpp     |   48 +-
 modules/platforms/cpp/odbc/src/connection.cpp   |  115 +-
 .../odbc/src/diagnostic/diagnosable_adapter.cpp |    4 +-
 .../odbc/src/diagnostic/diagnostic_record.cpp   |   46 +-
 .../diagnostic/diagnostic_record_storage.cpp    |   78 +-
 modules/platforms/cpp/odbc/src/dsn_config.cpp   |   10 +-
 modules/platforms/cpp/odbc/src/environment.cpp  |   62 +-
 modules/platforms/cpp/odbc/src/message.cpp      |  378 ++
 modules/platforms/cpp/odbc/src/odbc.cpp         |   29 +-
 .../platforms/cpp/odbc/src/protocol_version.cpp |  138 +-
 .../cpp/odbc/src/query/batch_query.cpp          |  198 +
 .../odbc/src/query/column_metadata_query.cpp    |  125 +-
 .../platforms/cpp/odbc/src/query/data_query.cpp |  132 +-
 .../cpp/odbc/src/query/foreign_keys_query.cpp   |   26 +-
 .../cpp/odbc/src/query/primary_keys_query.cpp   |   71 +-
 .../odbc/src/query/special_columns_query.cpp    |   26 +-
 .../cpp/odbc/src/query/table_metadata_query.cpp |   81 +-
 .../cpp/odbc/src/query/type_info_query.cpp      |  231 +-
 modules/platforms/cpp/odbc/src/result_page.cpp  |    2 +-
 modules/platforms/cpp/odbc/src/row.cpp          |    4 +-
 modules/platforms/cpp/odbc/src/statement.cpp    |  530 +-
 modules/platforms/cpp/odbc/src/type_traits.cpp  |   59 +-
 modules/platforms/cpp/odbc/src/utility.cpp      |   17 +-
 .../Apache.Ignite.AspNet.Tests/App.config       |    6 +-
 .../ExpiryCacheHolderTest.cs                    |   22 +-
 .../IgniteOutputCacheProviderTest.cs            |    2 +-
 .../IgniteSessionStateStoreProviderTest.cs      |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.AspNet.nuspec                 |    2 +-
 .../Apache.Ignite.AspNet/Impl/ConfigUtil.cs     |    4 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Config/ignite-config.xml                    |    1 -
 .../Apache.Ignite.Core.Tests.NuGet/NuGet.config |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../SchemaTest.cs                               |    2 +-
 .../StartupTest.cs                              |   77 +
 .../Apache.Ignite.Core.Tests.NuGet/TestUtil.cs  |   30 +
 .../install-package.ps1                         |   31 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |    1 +
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../TestExtensions.cs                           |   35 +
 .../Apache.Ignite.Core.Tests.csproj             |   65 +-
 .../Binary/BinaryBuilderSelfTest.cs             |  423 +-
 .../BinaryBuilderSelfTestArrayIdentity.cs       |   34 -
 .../BinaryBuilderSelfTestDynamicRegistration.cs |   42 +
 .../Binary/BinaryBuilderSelfTestSimpleName.cs   |   35 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |   19 +-
 .../Binary/BinaryDateTimeTest.cs                |  204 +
 .../Binary/BinaryDynamicRegistrationTest.cs     |  535 ++
 .../Binary/BinaryEqualityComparerTest.cs        |  217 +-
 .../Binary/BinaryNameMapperTest.cs              |  115 +
 .../Binary/BinaryReaderWriterTest.cs            |    8 +
 .../Binary/BinarySelfTest.cs                    |  284 +-
 .../Binary/BinarySelfTestFullFooter.cs          |    5 +-
 .../Binary/BinarySelfTestSimpleName.cs          |   33 +
 .../Binary/EnumsTest.cs                         |  547 ++
 .../Binary/EnumsTestOnline.cs                   |   45 +
 .../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           |  280 +
 .../Binary/TypeNameParserTest.cs                |  291 ++
 .../Binary/TypeResolverTest.cs                  |  104 +
 .../BinaryConfigurationTest.cs                  |   49 +-
 .../Cache/AddArgCacheEntryProcessor.cs          |   91 +
 .../Cache/Affinity/AffinityFieldTest.cs         |    6 +-
 .../Affinity/AffinityFunctionSpringTest.cs      |    6 +-
 .../Cache/Affinity/AffinityFunctionTest.cs      |  148 +-
 .../Cache/Affinity/AffinityTest.cs              |   16 +-
 .../BinarizableAddArgCacheEntryProcessor.cs     |   53 +
 .../Cache/BinarizableTestException.cs           |   51 +
 .../Cache/CacheAbstractTest.cs                  |  513 +-
 .../Cache/CacheAbstractTransactionalTest.cs     |    1 +
 .../Cache/CacheConfigurationTest.cs             |  121 +-
 .../Cache/CacheDynamicStartTest.cs              |  168 +-
 .../Cache/CacheForkedTest.cs                    |    8 +-
 .../Cache/CacheMetricsTest.cs                   |  100 +-
 .../Cache/CacheNearTest.cs                      |   38 +-
 .../Cache/CacheSwapSpaceTest.cs                 |  122 -
 .../Cache/CacheTestAsyncWrapper.cs              |   34 +-
 .../Cache/CacheTestKey.cs                       |   68 +
 .../Cache/MemoryMetricsTest.cs                  |  154 +
 .../Cache/NonSerializableCacheEntryProcessor.cs |   40 +
 .../Cache/NonSerializableException.cs           |   40 +
 .../Cache/PartitionLossTest.cs                  |  260 +
 .../Cache/PersistentStoreTest.cs                |  108 +
 .../Cache/Query/CacheDmlQueriesTest.cs          |  216 +-
 .../Query/CacheDmlQueriesTestSimpleName.cs      |   35 +
 .../Cache/Query/CacheLinqTest.cs                | 1599 ------
 .../Query/CacheQueriesCodeConfigurationTest.cs  |   17 +-
 .../Cache/Query/CacheQueriesTest.cs             |  217 +-
 .../Cache/Query/CacheQueriesTestSimpleName.cs   |   35 +
 .../Continuous/ContinuousQueryAbstractTest.cs   |  153 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |   23 +-
 .../Query/Continuous/ContinuousQueryTest.cs     |  115 +
 .../Query/Linq/CacheLinqTest.Aggregates.cs      |   91 +
 .../Cache/Query/Linq/CacheLinqTest.Base.cs      |  506 ++
 .../Query/Linq/CacheLinqTest.CompiledQuery.cs   |  215 +
 .../Cache/Query/Linq/CacheLinqTest.Contains.cs  |  128 +
 .../Cache/Query/Linq/CacheLinqTest.Custom.cs    |  107 +
 .../Cache/Query/Linq/CacheLinqTest.DateTime.cs  |   89 +
 .../Cache/Query/Linq/CacheLinqTest.Functions.cs |  211 +
 .../Query/Linq/CacheLinqTest.Introspection.cs   |  145 +
 .../Linq/CacheLinqTest.Join.LocalCollection.cs  |  182 +
 .../Cache/Query/Linq/CacheLinqTest.Join.cs      |  310 ++
 .../Cache/Query/Linq/CacheLinqTest.Misc.cs      |  350 ++
 .../Cache/Query/Linq/CacheLinqTest.Numerics.cs  |  131 +
 .../Cache/Query/Linq/CacheLinqTest.Strings.cs   |   91 +
 .../Cache/Query/Linq/CacheLinqTestSimpleName.cs |   35 +
 .../Query/Linq/CacheLinqTestSqlEscapeAll.cs     |   34 +
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |    9 +-
 .../Cache/Store/CacheStoreAdapterTest.cs        |   14 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   19 +-
 .../Cache/Store/CacheStoreTest.cs               |   72 +-
 .../Cache/Store/CacheTestParallelLoadStore.cs   |   16 +-
 .../Cache/Store/CacheTestStore.cs               |   13 +-
 .../Cache/TestReferenceObject.cs                |   40 +
 .../Compute/AbstractTaskTest.cs                 |   57 +-
 .../Compute/BinarizableClosureTaskTest.cs       |   29 +-
 .../Compute/BinarizableTaskTest.cs              |   15 -
 .../Compute/CancellationTest.cs                 |    4 +-
 .../Compute/ClosureTaskTest.cs                  |    6 +-
 .../Compute/ComputeApiTest.cs                   |  201 +-
 .../Compute/ComputeApiTestFullFooter.cs         |    4 +-
 .../Compute/FailoverTaskSelfTest.cs             |   52 +-
 .../Compute/IgniteExceptionTaskSelfTest.cs      |  147 +-
 .../Compute/MixedClusterTest.cs                 |   33 +-
 .../Compute/ResourceTaskTest.cs                 |   73 +-
 .../Compute/SerializableClosureTaskTest.cs      |   36 +-
 .../Compute/TaskAdapterTest.cs                  |    6 -
 .../Compute/TaskResultTest.cs                   |   12 -
 .../Config/Cache/Affinity/affinity-function.xml |    4 +-
 .../Cache/Affinity/affinity-function2.xml       |    2 +-
 .../Config/Compute/compute-grid1.xml            |    6 +-
 .../Config/Compute/compute-grid2.xml            |   13 +-
 .../Config/Compute/compute-grid3.xml            |    2 +-
 .../Config/Compute/compute-standalone.xml       |    4 +-
 .../Config/Dynamic/dynamic-data.xml             |    2 -
 .../Config/Lifecycle/lifecycle-beans.xml        |    2 +-
 .../Config/Lifecycle/lifecycle-no-beans.xml     |    2 +-
 .../Config/Log/dotnet-log4j.xml                 |    2 +-
 .../Config/cache-binarizables.xml               |   20 +-
 .../Config/cache-query-continuous.xml           |  130 +-
 .../Config/cache-query.xml                      |    2 +-
 .../Config/marshaller-invalid.xml               |    2 +-
 .../native-client-test-cache-affinity.xml       |    1 +
 .../Config/native-client-test-cache.xml         |   17 -
 .../Config/spring-test.xml                      |   14 +
 .../Config/start-test-grid1.xml                 |    2 +-
 .../Config/start-test-grid2.xml                 |    2 +-
 .../ConsoleRedirectTest.cs                      |    9 +-
 .../DataStructures/AtomicLongTest.cs            |    1 +
 .../DataStructures/AtomicReferenceTest.cs       |    2 -
 .../Dataload/DataStreamerTest.cs                |   55 +-
 .../Dataload/DataStreamerTestTopologyChange.cs  |    2 +-
 .../Deployment/GetAddressFunc.cs                |   35 +
 .../PeerAssemblyLoadingAllApisTest.cs           |  167 +
 .../Deployment/PeerAssemblyLoadingTest.cs       |  205 +
 .../PeerAssemblyLoadingVersioningTest.cs        |  164 +
 .../Deployment/ProcessNameFunc.cs               |   50 +
 .../Deployment/ProcessNameTask.cs               |   74 +
 .../Deployment/RuntimeDependencyFunc.cs         |   34 +
 .../Deployment/peer_assembly_app.config         |   35 +
 .../Apache.Ignite.Core.Tests/DeploymentTest.cs  |   31 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |  165 +-
 .../Examples/ExamplesTest.cs                    |   40 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   43 +-
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |   93 +-
 .../Apache.Ignite.Core.Tests/FutureTest.cs      |   18 +-
 .../IgniteConfigurationSectionTest.cs           |    9 +-
 .../IgniteConfigurationSerializerTest.cs        |  319 +-
 .../IgniteConfigurationTest.cs                  |  274 +-
 .../IgniteStartStopTest.cs                      |   79 +-
 .../Apache.Ignite.Core.Tests/IgniteTestBase.cs  |   51 +-
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |   58 +-
 .../Apache.Ignite.Core.Tests/LoadDllTest.cs     |   11 +-
 .../Log/CustomLoggerTest.cs                     |   14 +-
 .../Apache.Ignite.Core.Tests/MarshallerTest.cs  |   24 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |   43 +-
 .../Cache/CacheJavaPluginConfiguration.cs       |   45 +
 .../Plugin/Cache/CacheJavaPluginTest.cs         |  113 +
 .../Plugin/Cache/CachePlugin.cs                 |  127 -
 .../Plugin/Cache/CachePluginConfiguration.cs    |   40 -
 .../Plugin/Cache/CachePluginTest.cs             |  215 -
 .../Plugin/PluginTest.cs                        |  124 +-
 .../Plugin/TestIgnitePluginConfiguration.cs     |   26 +
 .../Plugin/TestIgnitePluginException.cs         |   64 +
 .../Plugin/TestIgnitePluginProvider.cs          |   33 +-
 .../Process/IgniteProcess.cs                    |   12 +-
 .../ProjectFilesTest.cs                         |    7 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |    5 +-
 .../SerializationTest.cs                        |  240 -
 .../Services/ServiceProxyTest.cs                |   40 +-
 .../Services/ServicesTest.cs                    |    3 +
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   41 +-
 .../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                   |   69 +-
 .../Apache.Ignite.Core.nuspec                   |   14 +-
 .../Binary/BinaryArrayEqualityComparer.cs       |  149 -
 .../Binary/BinaryBasicNameMapper.cs             |  129 +
 .../Binary/BinaryConfiguration.cs               |   24 +-
 .../Binary/BinaryReflectiveSerializer.cs        |   44 +-
 .../Binary/BinaryTypeConfiguration.cs           |   17 +-
 .../dotnet/Apache.Ignite.Core/Binary/IBinary.cs |   24 +
 .../Apache.Ignite.Core/Binary/IBinaryObject.cs  |    8 +
 .../Binary/IBinaryObjectBuilder.cs              |   10 -
 .../Apache.Ignite.Core/Binary/IBinaryType.cs    |    6 +
 .../Binary/TimestampAttribute.cs                |   40 +
 .../Cache/Affinity/AffinityFunctionBase.cs      |  139 +
 .../Cache/Affinity/Fair/FairAffinityFunction.cs |   33 -
 .../Cache/Affinity/Fair/Package-Info.cs         |   26 -
 .../Cache/Affinity/IAffinityFunction.cs         |    3 +-
 .../Rendezvous/RendezvousAffinityFunction.cs    |    1 -
 .../Apache.Ignite.Core/Cache/CachePeekMode.cs   |    7 +-
 .../Configuration/CacheAtomicWriteOrderMode.cs  |   43 -
 .../Cache/Configuration/CacheConfiguration.cs   |  236 +-
 .../Cache/Configuration/CacheMemoryMode.cs      |   60 -
 .../Cache/Configuration/DataPageEvictionMode.cs |   59 +
 .../Cache/Configuration/MemoryConfiguration.cs  |  172 +
 .../Configuration/MemoryPolicyConfiguration.cs  |  196 +
 .../Configuration/NearCacheConfiguration.cs     |    2 +-
 .../Cache/Configuration/PartitionLossPolicy.cs  |   68 +
 .../Cache/Configuration/QueryEntity.cs          |   96 +-
 .../Cache/Configuration/QueryField.cs           |    2 +-
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |   49 +-
 .../Cache/ICacheEntryProcessorResult.cs         |   12 +-
 .../Apache.Ignite.Core/Cache/ICacheMetrics.cs   |   88 -
 .../Apache.Ignite.Core/Cache/IMemoryMetrics.cs  |   55 +
 .../Cache/Query/Continuous/ContinuousQuery.cs   |   59 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs |    4 +-
 .../Cache/Query/SqlFieldsQuery.cs               |   43 +-
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |   31 +
 .../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 +-
 .../Compute/ComputeTaskAdapter.cs               |    4 +-
 .../Configuration/Package-Info.cs               |   26 +
 .../Configuration/SqlConnectorConfiguration.cs  |  159 +
 .../Datastream/IDataStreamer.cs                 |   10 +-
 .../Deployment/PeerAssemblyLoadingMode.cs       |   55 +
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |   43 -
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |   10 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |    7 +-
 .../Apache.Ignite.Core/Events/EventReader.cs    |    1 -
 .../Apache.Ignite.Core/Events/EventType.cs      |   57 -
 .../Events/IEventStorageSpi.cs                  |   33 +
 .../Apache.Ignite.Core/Events/JobEvent.cs       |    4 +-
 .../Events/MemoryEventStorageSpi.cs             |  100 +
 .../Events/NoopEventStorageSpi.cs               |   27 +
 .../Apache.Ignite.Core/Events/SwapSpaceEvent.cs |   51 -
 .../Apache.Ignite.Core/Events/TaskEvent.cs      |    2 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   44 +-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  445 +-
 .../IgniteConfigurationSection.xsd              |  510 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |  153 +-
 .../Impl/Binary/BinarizableSerializer.cs        |    4 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |   78 +-
 .../Impl/Binary/BinaryArrayEqualityComparer.cs  |  161 +
 .../Impl/Binary/BinaryEnum.cs                   |   25 +-
 .../Binary/BinaryEqualityComparerSerializer.cs  |   99 -
 .../Impl/Binary/BinaryFieldEqualityComparer.cs  |  138 -
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |   59 +-
 .../Impl/Binary/BinaryObject.cs                 |   87 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |   93 +-
 .../Impl/Binary/BinaryObjectHeader.cs           |   21 +-
 .../Impl/Binary/BinaryObjectSchemaSerializer.cs |    2 +
 .../Impl/Binary/BinaryProcessor.cs              |  100 +-
 .../Impl/Binary/BinaryReader.cs                 |  124 +-
 .../Impl/Binary/BinaryReflectiveActions.cs      |  115 +-
 .../BinaryReflectiveSerializerInternal.cs       |   98 +-
 .../Binary/BinarySurrogateTypeDescriptor.cs     |   42 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |  360 +-
 .../Impl/Binary/BinarySystemTypeSerializer.cs   |    2 +-
 .../Impl/Binary/BinaryUtils.cs                  |  497 +-
 .../Impl/Binary/BinaryWriter.cs                 |  302 +-
 .../Impl/Binary/BinaryWriterExtensions.cs       |    9 +-
 .../Impl/Binary/DateTimeHolder.cs               |  101 -
 .../Impl/Binary/DateTimeSerializer.cs           |   48 -
 .../Binary/DeserializationCallbackProcessor.cs  |  113 +
 .../Impl/Binary/IBinaryEqualityComparer.cs      |   53 -
 .../Impl/Binary/IBinarySerializerInternal.cs    |    8 +-
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |   13 +-
 .../Impl/Binary/Io/BinaryHeapStream.cs          |    3 +
 .../Impl/Binary/Io/BinaryStreamAdapter.cs       |  119 -
 .../Impl/Binary/Io/IBinaryStream.cs             |    3 +-
 .../Impl/Binary/Io/IBinaryStreamProcessor.cs    |    5 +-
 .../Impl/Binary/Marshaller.cs                   |  469 +-
 .../Impl/Binary/Metadata/BinaryField.cs         |   72 +
 .../Impl/Binary/Metadata/BinaryType.cs          |  215 +-
 .../Binary/Metadata/BinaryTypeHashsetHandler.cs |   10 +-
 .../Impl/Binary/Metadata/BinaryTypeHolder.cs    |   47 +-
 .../Impl/Binary/Metadata/IBinaryTypeHandler.cs  |    4 +-
 .../Impl/Binary/ReflectionUtils.cs              |   50 +
 .../Impl/Binary/SerializableObjectHolder.cs     |   96 -
 .../Impl/Binary/SerializableSerializer.cs       |  656 ++-
 .../Impl/Binary/TypeNameParser.cs               |  407 ++
 .../Impl/Binary/TypeResolver.cs                 |  193 +-
 .../Impl/Binary/UserSerializerProxy.cs          |    4 +-
 .../Impl/Cache/Affinity/AffinityFunctionBase.cs |  140 -
 .../Affinity/AffinityFunctionSerializer.cs      |   21 +-
 .../Impl/Cache/CacheEntryFilterHolder.cs        |   13 +
 .../Impl/Cache/CacheEntryProcessorResult.cs     |   27 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   91 +-
 .../Impl/Cache/CacheMetricsImpl.cs              |   77 -
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |    6 +-
 .../Impl/Cache/IQueryEntityInternal.cs          |   31 +
 .../Impl/Cache/MemoryMetrics.cs                 |   62 +
 .../Impl/Cache/Store/CacheStore.cs              |  233 +-
 .../Impl/Cache/Store/CacheStoreInternal.cs      |  285 ++
 .../Impl/Cache/Store/ICacheStoreInternal.cs     |   43 +
 .../Impl/Cluster/ClusterGroupImpl.cs            |   89 +
 .../Impl/Collections/MultiValueDictionary.cs    |    2 +-
 .../Common/CopyOnWriteConcurrentDictionary.cs   |   27 +
 .../Impl/Common/DelegateConverter.cs            |   91 +-
 .../Impl/Common/DelegateTypeDescriptor.cs       |    3 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   16 +-
 .../Impl/Common/IFutureConverter.cs             |    4 +-
 .../Impl/Common/IFutureInternal.cs              |    3 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |  287 +-
 .../Impl/Common/IgniteHome.cs                   |   22 +-
 .../Impl/Common/LoadedAssembliesResolver.cs     |   10 +-
 .../Impl/Common/SerializableTypeDescriptor.cs   |  222 +
 .../Closure/ComputeAbstractClosureTask.cs       |    3 +-
 .../Impl/Compute/Closure/ComputeActionJob.cs    |    7 +-
 .../Impl/Compute/Closure/ComputeFuncJob.cs      |    5 +-
 .../Apache.Ignite.Core/Impl/Compute/Compute.cs  |   29 +
 .../Impl/Compute/ComputeFunc.cs                 |    7 +-
 .../Impl/Compute/ComputeImpl.cs                 |    3 +-
 .../Impl/Compute/ComputeJob.cs                  |    5 +-
 .../Impl/Compute/ComputeJobHolder.cs            |    9 +-
 .../Impl/Compute/ComputeOutFunc.cs              |    5 +-
 .../Impl/Compute/ComputeTaskHolder.cs           |    8 +-
 .../Impl/Deployment/AssemblyLoader.cs           |  105 +
 .../Impl/Deployment/AssemblyRequest.cs          |   68 +
 .../Impl/Deployment/AssemblyRequestResult.cs    |   80 +
 .../Impl/Deployment/GetAssemblyFunc.cs          |  105 +
 .../Impl/Deployment/PeerAssemblyResolver.cs     |  213 +
 .../Impl/Deployment/PeerLoadingExtensions.cs    |   65 +
 .../Impl/Deployment/PeerLoadingObjectHolder.cs  |   90 +
 .../PeerLoadingObjectHolderSerializer.cs        |   49 +
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |   97 +-
 .../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    |   99 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |  464 --
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   22 +-
 .../Impl/LifecycleBeanHolder.cs                 |   66 -
 .../Impl/LifecycleHandlerHolder.cs              |   66 +
 .../Impl/Memory/IPlatformMemory.cs              |    5 +-
 .../Impl/Memory/PlatformMemory.cs               |    3 +-
 .../Impl/Memory/PlatformMemoryManager.cs        |    4 +-
 .../Impl/Memory/PlatformMemoryPool.cs           |    3 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |    9 +-
 .../Impl/Memory/PlatformRawMemory.cs            |   96 -
 .../Apache.Ignite.Core/Impl/NativeMethods.cs    |   50 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |   46 +-
 .../Impl/Plugin/Cache/CachePluginContext.cs     |   82 -
 .../Impl/Plugin/Cache/CachePluginProcessor.cs   |   77 -
 .../Plugin/Cache/CachePluginProviderProxy.cs    |   75 -
 .../Plugin/Cache/ICachePluginProviderProxy.cs   |   52 -
 .../Impl/Plugin/PluginContext.cs                |   28 +
 .../Impl/Plugin/PluginProcessor.cs              |  128 +-
 .../Impl/Resource/ResourceProcessor.cs          |   10 -
 .../Impl/Resource/ResourceTypeDescriptor.cs     |   12 +-
 .../Impl/Services/ServiceProxySerializer.cs     |    4 +-
 .../Impl/SwapSpace/SwapSpaceSerializer.cs       |   99 -
 .../Transactions/CacheTransactionManager.cs     |   13 +
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |    3 +
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |    5 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   71 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   13 +-
 .../Interop/IPlatformTarget.cs                  |   12 +
 .../Lifecycle/ILifecycleBean.cs                 |   64 -
 .../Lifecycle/ILifecycleHandler.cs              |   64 +
 .../Lifecycle/LifecycleEventType.cs             |    2 +-
 .../NuGet/LINQPad/BinaryModeExample.linq        |    1 +
 .../NuGet/LINQPad/ComputeExample.linq           |   18 +-
 .../NuGet/LINQPad/PutGetExample.linq            |    6 +-
 .../NuGet/LINQPad/QueryExample.linq             |    6 +-
 .../PersistentStore/Package-Info.cs             |   26 +
 .../PersistentStoreConfiguration.cs             |  251 +
 .../PersistentStore/WalMode.cs                  |   45 +
 .../Cache/CachePluginProviderTypeAttribute.cs   |   52 -
 .../Plugin/Cache/ICachePluginConfiguration.cs   |   33 +-
 .../Plugin/Cache/ICachePluginContext.cs         |   47 -
 .../Plugin/Cache/ICachePluginProvider.cs        |   52 -
 .../Plugin/IPluginConfiguration.cs              |   19 +-
 .../Apache.Ignite.Core/Plugin/IPluginContext.cs |   24 +
 .../Apache.Ignite.Core/Plugin/PluginCallback.cs |   29 +
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../SwapSpace/File/FileSwapSpaceSpi.cs          |  105 -
 .../SwapSpace/ISwapSpaceSpi.cs                  |   35 -
 .../App.config                                  |    4 +-
 .../EntityFrameworkCacheInitializationTest.cs   |    2 +-
 .../EntityFrameworkCacheTest.cs                 |    2 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.EntityFramework.nuspec        |    2 +-
 .../IgniteDbConfiguration.cs                    |    4 +-
 .../Impl/DbCache.cs                             |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 modules/platforms/dotnet/Apache.Ignite.FxCop    |    3 +-
 .../Apache.Ignite.Linq.csproj                   |    6 +-
 .../Apache.Ignite.Linq.nuspec                   |    2 +-
 .../Apache.Ignite.Linq/CacheExtensions.cs       |   75 +
 .../dotnet/Apache.Ignite.Linq/CompiledQuery.cs  |  117 +-
 .../dotnet/Apache.Ignite.Linq/CompiledQuery2.cs |  257 -
 .../Apache.Ignite.Linq/Impl/AliasDictionary.cs  |   65 +-
 .../Impl/CacheFieldsQueryExecutor.cs            |   81 +-
 .../Impl/CacheFieldsQueryProvider.cs            |   39 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |  213 +-
 .../Impl/CacheQueryModelVisitor.cs              |  195 +-
 .../Apache.Ignite.Linq/Impl/CacheQueryParser.cs |   46 +-
 .../Apache.Ignite.Linq/Impl/CacheQueryable.cs   |    3 +-
 .../Impl/CacheQueryableBase.cs                  |   14 +-
 .../Impl/Dml/RemoveAllExpressionNode.cs         |   88 +
 .../Impl/Dml/RemoveAllResultOperator.cs         |   61 +
 .../Apache.Ignite.Linq/Impl/EnumerableHelper.cs |   59 +
 .../Apache.Ignite.Linq/Impl/ExpressionWalker.cs |   93 +-
 .../Impl/ICacheQueryableInternal.cs             |    6 -
 ...SequenceParameterNotNullExpressionVisitor.cs |   72 +
 .../Apache.Ignite.Linq/Impl/MethodVisitor.cs    |   79 +-
 .../dotnet/Apache.Ignite.Linq/Impl/QueryData.cs |   17 +-
 .../dotnet/Apache.Ignite.Linq/Impl/SqlTypes.cs  |   17 +-
 .../NuGet/LINQPad/QueryExample.linq             |    6 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../dotnet/Apache.Ignite.Linq/QueryOptions.cs   |   25 +-
 .../Apache.Ignite.Log4Net.nuspec                |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.NLog.nuspec                   |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../dotnet/Apache.Ignite.sln.DotSettings        |    1 +
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |    1 -
 .../platforms/dotnet/Apache.Ignite/App.config   |   11 +
 .../dotnet/Apache.Ignite/Config/Configurator.cs |    9 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    8 +-
 .../Apache.Ignite/Service/IgniteService.cs      |    6 +-
 .../Apache.Ignite/Service/ServiceDescription.cs |   32 -
 modules/platforms/dotnet/build.ps1              |   48 +-
 .../Apache.Ignite.Examples.csproj               |    1 +
 .../examples/Apache.Ignite.Examples/App.config  |   21 +-
 .../Compute/PeerAssemblyLoadingExample.cs       |   96 +
 .../Datagrid/LinqExample.cs                     |    2 +-
 .../Datagrid/MultiTieredCacheExample.cs         |   30 +-
 .../Datagrid/PutGetExample.cs                   |   13 +-
 .../Datagrid/StoreExample.cs                    |    1 +
 .../Misc/ClientReconnectExample.cs              |   40 +-
 .../Misc/LifecycleExample.cs                    |   12 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../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                  |    6 +-
 .../Services/MapService.cs                      |    1 -
 modules/rest-http/pom.xml                       |    2 +-
 .../http/jetty/GridJettyObjectMapper.java       |  165 +-
 modules/rocketmq/README.txt                     |   25 +
 modules/rocketmq/licenses/apache-2.0.txt        |  202 +
 modules/rocketmq/pom.xml                        |   81 +
 .../stream/rocketmq/RocketMQStreamer.java       |  151 +
 .../ignite/stream/rocketmq/package-info.java    |   21 +
 .../stream/rocketmq/RocketMQStreamerTest.java   |  214 +
 .../rocketmq/RocketMQStreamerTestSuite.java     |   37 +
 .../stream/rocketmq/TestRocketMQServer.java     |  148 +
 .../ignite/stream/rocketmq/package-info.java    |   21 +
 modules/scalar-2.10/pom.xml                     |    4 +-
 modules/scalar/pom.xml                          |    4 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |   24 +-
 .../scala/org/apache/ignite/scalar/scalar.scala |   34 +-
 .../scalar/src/test/resources/spring-cache.xml  |    4 +-
 .../test/resources/spring-ping-pong-partner.xml |    2 +-
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |    2 +-
 .../scalar/tests/ScalarProjectionSpec.scala     |    4 +-
 modules/schedule/pom.xml                        |    2 +-
 .../schedule/IgniteScheduleProcessor.java       |    2 +-
 .../processors/schedule/ScheduleFutureImpl.java |   73 +-
 .../schedule/GridScheduleSelfTest.java          |   84 +-
 modules/schema-import-db/README.txt             |    4 -
 modules/schema-import-db/pom.xml                |   55 -
 .../apache/ignite/schema/parser/DbColumn.java   |   88 -
 .../ignite/schema/parser/DbMetadataReader.java  |  147 -
 .../apache/ignite/schema/parser/DbTable.java    |   82 -
 .../parser/dialect/DB2MetadataDialect.java      |   33 -
 .../parser/dialect/DatabaseMetadataDialect.java |  102 -
 .../parser/dialect/JdbcMetadataDialect.java     |  199 -
 .../parser/dialect/MySQLMetadataDialect.java    |   82 -
 .../parser/dialect/OracleMetadataDialect.java   |  360 --
 modules/schema-import/README.txt                |  216 -
 modules/schema-import/pom.xml                   |  119 -
 .../main/java/media/data_connection_48x48.png   |  Bin 4443 -> 0 bytes
 .../src/main/java/media/error_48x48.png         |  Bin 4349 -> 0 bytes
 .../src/main/java/media/ignite_128x128.png      |  Bin 4917 -> 0 bytes
 .../src/main/java/media/ignite_16x16.png        |  Bin 608 -> 0 bytes
 .../src/main/java/media/ignite_24x24.png        |  Bin 930 -> 0 bytes
 .../src/main/java/media/ignite_32x32.png        |  Bin 1203 -> 0 bytes
 .../src/main/java/media/ignite_48x48.png        |  Bin 1868 -> 0 bytes
 .../src/main/java/media/ignite_64x64.png        |  Bin 2453 -> 0 bytes
 .../src/main/java/media/information_48x48.png   |  Bin 4102 -> 0 bytes
 .../src/main/java/media/question_48x48.png      |  Bin 3857 -> 0 bytes
 .../src/main/java/media/sign_warning_48x48.png  |  Bin 2988 -> 0 bytes
 .../schema-import/src/main/java/media/style.css |  134 -
 .../src/main/java/media/text_tree_48x48.png     |  Bin 2567 -> 0 bytes
 .../ignite/schema/generator/CodeGenerator.java  |  831 ---
 .../ignite/schema/generator/GeneratorUtils.java |   70 -
 .../ignite/schema/generator/XmlGenerator.java   |  446 --
 .../ignite/schema/model/PojoDescriptor.java     |  497 --
 .../apache/ignite/schema/model/PojoField.java   |  461 --
 .../ignite/schema/model/SchemaDescriptor.java   |   62 -
 .../schema/parser/DatabaseMetadataParser.java   |  115 -
 .../ignite/schema/ui/ConfirmCallable.java       |   83 -
 .../org/apache/ignite/schema/ui/Controls.java   |  697 ---
 .../org/apache/ignite/schema/ui/GridPaneEx.java |  180 -
 .../org/apache/ignite/schema/ui/MessageBox.java |  274 -
 .../apache/ignite/schema/ui/ModalDialog.java    |   50 -
 .../ignite/schema/ui/SchemaImportApp.java       | 2115 --------
 .../ignite/schema/ui/TextColumnValidator.java   |   32 -
 .../schema/test/AbstractSchemaImportTest.java   |  181 -
 .../test/generator/CodeGeneratorTest.java       |   81 -
 .../schema/test/generator/XmlGeneratorTest.java |   42 -
 .../ignite/schema/test/model/CacheConfig.txt    |  409 --
 .../apache/ignite/schema/test/model/Objects.txt |  531 --
 .../ignite/schema/test/model/ObjectsKey.txt     |   96 -
 .../ignite/schema/test/model/Primitives.txt     |  535 --
 .../ignite/schema/test/model/PrimitivesKey.txt  |   96 -
 .../org/apache/ignite/schema/test/model/Tst.txt |  535 --
 .../apache/ignite/schema/test/model/TstKey.txt  |   96 -
 .../schema/test/model/ignite-type-metadata.xml  |  666 ---
 .../test/parser/DbMetadataParserTest.java       |  134 -
 .../testsuites/IgniteSchemaImportTestSuite.java |   42 -
 modules/slf4j/pom.xml                           |    2 +-
 modules/spark-2.10/pom.xml                      |   56 +-
 modules/spark/pom.xml                           |  179 +-
 .../org/apache/ignite/spark/IgniteContext.scala |   24 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |    6 +
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |   26 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |   71 +-
 .../org/apache/ignite/spark/IgniteRDDSpec.scala |   90 +-
 modules/spring-data/README.txt                  |   32 +
 modules/spring-data/licenses/apache-2.0.txt     |  202 +
 modules/spring-data/pom.xml                     |   78 +
 .../springdata/repository/IgniteRepository.java |   58 +
 .../config/EnableIgniteRepositories.java        |  119 +
 .../config/IgniteRepositoriesRegistar.java      |   36 +
 .../IgniteRepositoryConfigurationExtension.java |   49 +
 .../springdata/repository/config/Query.java     |   37 +
 .../repository/config/RepositoryConfig.java     |   39 +
 .../repository/config/package-info.java         |   22 +
 .../springdata/repository/package-info.java     |   22 +
 .../repository/query/IgniteQuery.java           |   83 +
 .../repository/query/IgniteQueryGenerator.java  |  243 +
 .../repository/query/IgniteRepositoryQuery.java |  306 ++
 .../repository/query/package-info.java          |   22 +
 .../support/IgniteRepositoryFactory.java        |  168 +
 .../support/IgniteRepositoryFactoryBean.java    |   92 +
 .../support/IgniteRepositoryImpl.java           |  160 +
 .../repository/support/package-info.java        |   22 +
 .../IgniteSpringDataCrudSelfTest.java           |  232 +
 .../IgniteSpringDataQueriesSelfTest.java        |  291 ++
 .../misc/ApplicationConfiguration.java          |   54 +
 .../apache/ignite/springdata/misc/Person.java   |   97 +
 .../springdata/misc/PersonRepository.java       |   92 +
 .../springdata/misc/PersonSecondRepository.java |   40 +
 .../testsuites/IgniteSpringDataTestSuite.java   |   41 +
 modules/spring/pom.xml                          |   15 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   85 +-
 .../apache/ignite/cache/spring/SpringCache.java |   60 +-
 .../ignite/cache/spring/SpringCacheManager.java |   93 +-
 .../spring/SpringTransactionManager.java        |   91 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |    2 +-
 .../src/test/config/jdbc-pojo-store-obj.xml     |    2 +-
 modules/spring/src/test/config/node1.xml        |    2 +-
 modules/spring/src/test/config/store-cache1.xml |    2 +-
 .../src/test/java/config/ignite-test-config.xml |    2 +-
 .../test/java/config/spring-transactions.xml    |    2 +-
 .../GridSpringCacheManagerMultiJvmSelfTest.java |  134 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   12 +-
 .../GridSpringDynamicCacheTestService.java      |   13 +
 .../SpringCacheManagerContextInjectionTest.java |    2 +-
 .../ignite/cache/spring/SpringCacheTest.java    |  177 +
 .../ignite/cache/spring/spring-caching.xml      |    2 +-
 .../ignite/cache/spring/spring-caching1.xml     |   56 +
 .../ignite/cache/spring/spring-caching2.xml     |   56 +
 .../jdbc/CacheJdbcBlobStoreFactorySelfTest.java |    2 +-
 .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java |    6 +-
 .../store/jdbc/CachePojoStoreXmlSelfTest.java   |    4 +-
 .../ignite/internal/GridFactorySelfTest.java    |  157 +-
 .../GridSpringBeanSerializationSelfTest.java    |   17 +-
 .../internal/IgniteDynamicCacheConfigTest.java  |   10 +-
 .../java/org/apache/ignite/internal/cache.xml   |    3 -
 .../apache/ignite/internal/filtered-cache.xml   |    3 -
 .../apache/ignite/internal/invalid-cache.xml    |    6 -
 .../GridSpringResourceInjectionSelfTest.java    |   24 +-
 .../GridTransformSpringInjectionSelfTest.java   |    4 +-
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   14 +-
 .../org/apache/ignite/spring-injection-test.xml |    2 +-
 .../IgniteExcludeInConfigurationTest.java       |   14 +-
 .../IgniteStartFromStreamConfigurationTest.java |    4 +-
 .../spring/injection/spring-resource.tmpl.xml   |    2 +-
 .../org/apache/ignite/spring/sprint-exclude.xml |   23 +-
 .../testsuites/IgniteSpringTestSuite.java       |    3 +
 .../GridSpringTransactionManagerSelfTest.java   |   91 +-
 ...gTransactionManagerContextInjectionTest.java |    2 +-
 modules/ssh/pom.xml                             |    2 +-
 ...gniteProjectionStartStopRestartSelfTest.java |    6 +-
 modules/storm/pom.xml                           |    2 +-
 modules/tools/pom.xml                           |    2 +-
 .../ant/beautifier/GridJavadocAntTask.java      |   19 +-
 .../ignite/tools/classgen/ClassesGenerator.java |    4 +-
 modules/twitter/pom.xml                         |    2 +-
 .../twitter/IgniteTwitterStreamerTest.java      |    8 +-
 modules/urideploy/pom.xml                       |    2 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |   90 +-
 .../scanners/UriDeploymentScannerManager.java   |   12 +-
 .../scanners/http/UriDeploymentHttpScanner.java |    3 +-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |    6 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |    8 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |    9 +-
 modules/visor-console-2.10/pom.xml              |    2 +-
 modules/visor-console/pom.xml                   |    2 +-
 .../ignite/visor/commands/VisorConsole.scala    |    1 -
 .../visor/commands/ack/VisorAckCommand.scala    |    5 +-
 .../commands/cache/VisorCacheClearCommand.scala |    7 +-
 .../commands/cache/VisorCacheCommand.scala      |  347 +-
 .../commands/cache/VisorCacheResetCommand.scala |    4 +-
 .../commands/cache/VisorCacheScanCommand.scala  |   19 +-
 .../commands/cache/VisorCacheStopCommand.scala  |    4 +-
 .../commands/cache/VisorCacheSwapCommand.scala  |  145 -
 .../config/VisorConfigurationCommand.scala      |  185 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |   24 +-
 .../commands/events/VisorEventsCommand.scala    |   38 +-
 .../visor/commands/gc/VisorGcCommand.scala      |    4 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    6 +-
 .../commands/tasks/VisorTasksCommand.scala      |   61 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   49 +-
 .../ignite/visor/VisorRuntimeBaseSpec.scala     |    4 +-
 .../commands/alert/VisorAlertCommandSpec.scala  |    4 +-
 .../cache/VisorCacheClearCommandSpec.scala      |   28 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |   10 +-
 .../cache/VisorCacheResetCommandSpec.scala      |   12 +-
 .../config/VisorConfigurationCommandSpec.scala  |    4 +-
 .../cswap/VisorCacheSwapCommandSpec.scala       |   89 -
 .../disco/VisorDiscoveryCommandSpec.scala       |    4 +-
 .../events/VisorEventsCommandSpec.scala         |    4 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    4 +-
 .../commands/open/VisorOpenCommandSpec.scala    |    6 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |   26 +-
 .../testsuites/VisorConsoleSelfTestSuite.scala  |    2 -
 modules/visor-plugins/pom.xml                   |    2 +-
 .../src/main/java/log4j.properties              |    2 +-
 modules/web-console/backend/.gitignore          |    2 +
 modules/web-console/backend/app/agent.js        |  854 ----
 modules/web-console/backend/app/agentSocket.js  |  249 +
 .../web-console/backend/app/agentsHandler.js    |  404 ++
 modules/web-console/backend/app/apiServer.js    |   68 +
 modules/web-console/backend/app/app.js          |   63 -
 modules/web-console/backend/app/browser.js      |  469 --
 .../web-console/backend/app/browsersHandler.js  |  307 ++
 modules/web-console/backend/app/mongo.js        |  185 +-
 modules/web-console/backend/app/routes.js       |    6 +-
 modules/web-console/backend/app/settings.js     |    8 +-
 modules/web-console/backend/index.js            |   53 +-
 modules/web-console/backend/package.json        |   52 +-
 .../web-console/backend/routes/activities.js    |    7 -
 modules/web-console/backend/routes/admin.js     |   11 +-
 modules/web-console/backend/routes/agent.js     |   57 -
 modules/web-console/backend/routes/demo.js      |   14 +-
 modules/web-console/backend/routes/downloads.js |   57 +
 modules/web-console/backend/routes/profile.js   |    4 +-
 .../web-console/backend/services/activities.js  |   30 +-
 modules/web-console/backend/services/agents.js  |   83 -
 modules/web-console/backend/services/caches.js  |    2 +
 .../web-console/backend/services/downloads.js   |   80 +
 modules/web-console/backend/services/igfss.js   |    5 +
 .../backend/services/notifications.js           |   52 +
 .../web-console/backend/services/sessions.js    |    6 +-
 modules/web-console/backend/services/users.js   |   87 +-
 .../web-console/backend/test/app/httpAgent.js   |    6 +-
 .../web-console/backend/test/routes/clusters.js |    4 +-
 .../backend/test/unit/ActivitiesService.test.js |  131 +
 .../docker/compose/docker-compose.yml           |    4 +-
 .../docker/compose/frontend/DockerfileBuild     |    2 +-
 .../web-console/docker/standalone/Dockerfile    |   10 +-
 .../docker/standalone/docker-compose.yml        |    2 +-
 modules/web-console/frontend/.babelrc           |    9 +-
 modules/web-console/frontend/.eslintrc          |   11 +-
 modules/web-console/frontend/.gitignore         |    4 +-
 modules/web-console/frontend/app/app.config.js  |   21 +-
 modules/web-console/frontend/app/app.js         |   77 +-
 .../activities-user-dialog.controller.js        |   39 +-
 .../activities-user-dialog.jade                 |   36 -
 .../activities-user-dialog.tpl.pug              |   42 +
 .../components/activities-user-dialog/index.js  |    8 +-
 .../app/components/bs-select-menu/controller.js |   28 +
 .../app/components/bs-select-menu/directive.js  |   30 +
 .../app/components/bs-select-menu/index.js      |   24 +
 .../app/components/bs-select-menu/style.scss    |   78 +
 .../app/components/bs-select-menu/template.pug  |   49 +
 .../cluster-select/cluster-select.controller.js |   66 +
 .../cluster-select/cluster-select.pug           |   45 +
 .../cluster-select/cluster-select.scss          |   30 +
 .../app/components/cluster-select/index.js      |   29 +
 .../form-field-datepicker.jade                  |   55 -
 .../form-field-datepicker.scss                  |   20 -
 .../grid-column-selector/component.js           |   29 +
 .../grid-column-selector/controller.js          |  111 +
 .../grid-column-selector/controller.spec.js     |  435 ++
 .../components/grid-column-selector/index.js    |   24 +
 .../components/grid-column-selector/style.scss  |   24 +
 .../grid-column-selector/template.pug           |   28 +
 .../app/components/ignite-icon/directive.js     |   67 +
 .../app/components/ignite-icon/index.js         |   25 +
 .../app/components/ignite-icon/style.scss       |   21 +
 .../app/components/input-dialog/index.js        |   24 +
 .../input-dialog/input-dialog.controller.js     |   35 +
 .../input-dialog/input-dialog.service.js        |   87 +
 .../input-dialog/input-dialog.tpl.pug           |   39 +
 .../list-of-registered-users/index.js           |    4 +-
 .../list-of-registered-users.categories.js      |   22 +-
 .../list-of-registered-users.column-defs.js     |   52 +-
 .../list-of-registered-users.controller.js      |  356 +-
 .../list-of-registered-users.jade               |   54 -
 .../list-of-registered-users.scss               |   35 +
 .../list-of-registered-users.tpl.pug            |   67 +
 .../page-configure-advanced/component.js        |   25 +
 .../page-configure-advanced/controller.js       |   39 +
 .../components/page-configure-advanced/index.js |   25 +
 .../page-configure-advanced/service.js          |   31 +
 .../page-configure-advanced/style.scss          |   82 +
 .../page-configure-advanced/template.pug        |   26 +
 .../page-configure-basic/component.js           |   25 +
 .../components/pcbScaleNumber.js                |   45 +
 .../page-configure-basic/controller.js          |  135 +
 .../page-configure-basic/controller.spec.js     |  207 +
 .../components/page-configure-basic/index.js    |   29 +
 .../mixins/pcb-form-field-size.pug              |   70 +
 .../components/page-configure-basic/reducer.js  |  112 +
 .../page-configure-basic/reducer.spec.js        |  191 +
 .../components/page-configure-basic/service.js  |  134 +
 .../page-configure-basic/service.spec.js        |  323 ++
 .../components/page-configure-basic/style.scss  |  143 +
 .../page-configure-basic/template.pug           |  175 +
 .../app/components/page-configure/component.js  |   25 +
 .../app/components/page-configure/controller.js |   30 +
 .../page-configure/controller.spec.js           |   48 +
 .../app/components/page-configure/index.js      |   29 +
 .../app/components/page-configure/reducer.js    |   83 +
 .../components/page-configure/reducer.spec.js   |  275 +
 .../services/ConfigurationDownload.js           |   67 +
 .../services/ConfigurationDownload.spec.js      |  116 +
 .../page-configure/services/ConfigureState.js   |   92 +
 .../page-configure/services/PageConfigure.js    |   64 +
 .../app/components/page-configure/style.scss    |   23 +
 .../app/components/page-configure/template.pug  |   30 +
 .../protect-from-bs-select-render/directive.js  |   32 +
 .../protect-from-bs-select-render/index.js      |   24 +
 .../ui-grid-header/ui-grid-header.jade          |   27 -
 .../ui-grid-header/ui-grid-header.scss          |   84 -
 .../ui-grid-settings/ui-grid-settings.jade      |   33 -
 .../ui-grid-settings/ui-grid-settings.scss      |   70 -
 .../components/user-notifications/controller.js |   55 +
 .../app/components/user-notifications/index.js  |   26 +
 .../components/user-notifications/service.js    |   58 +
 .../components/user-notifications/style.scss    |   55 +
 .../user-notifications/template.tpl.pug         |   42 +
 .../app/components/version-picker/component.js  |   52 +
 .../app/components/version-picker/index.js      |   25 +
 .../app/components/version-picker/style.scss    |   41 +
 .../app/components/version-picker/template.pug  |   33 +
 .../components/web-console-footer/component.js  |   23 +
 .../app/components/web-console-footer/index.js  |   23 +
 .../components/web-console-footer/style.scss    |   55 +
 .../components/web-console-footer/template.pug  |   19 +
 .../components/web-console-header/component.js  |   47 +
 .../app/components/web-console-header/index.js  |   23 +
 .../components/web-console-header/style.scss    |  165 +
 .../components/web-console-header/template.pug  |   36 +
 .../app/core/activities/Activities.data.js      |    5 -
 .../frontend/app/core/admin/Admin.data.js       |    2 +
 .../frontend/app/core/utils/maskNull.js         |   21 +
 modules/web-console/frontend/app/data/i18n.js   |    1 +
 .../frontend/app/data/pom-dependencies.json     |    1 +
 .../frontend/app/directives/btn-ignite-link.js  |   27 +
 .../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.controller.js   |    8 +-
 .../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.controller.js       |   29 +-
 .../ui-ace-java/ui-ace-java.directive.js        |   16 +-
 .../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         |    8 +-
 .../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.controller.js   |   29 +-
 .../ui-ace-spring/ui-ace-spring.directive.js    |   16 +-
 .../directives/ui-ace-spring/ui-ace-spring.jade |   17 -
 .../directives/ui-ace-spring/ui-ace-spring.pug  |   17 +
 .../frontend/app/filters/byName.filter.js       |    4 +-
 .../app/filters/domainsValidation.filter.js     |    4 +-
 .../frontend/app/filters/duration.filter.js     |    4 +-
 .../frontend/app/filters/hasPojo.filter.js      |    4 +-
 .../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   |   39 +
 .../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   |   49 +
 .../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   |   47 +
 .../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        |  630 +++
 .../app/modules/agent/AgentManager.service.js   |  661 +++
 .../app/modules/agent/AgentModal.service.js     |   89 +
 .../frontend/app/modules/agent/agent.module.js  |  323 +-
 .../app/modules/branding/branding.provider.js   |    4 +-
 .../modules/branding/header-logo.directive.js   |    4 +-
 .../app/modules/branding/header-logo.jade       |   18 -
 .../app/modules/branding/header-logo.pug        |   18 +
 .../modules/branding/header-title.directive.js  |    6 +-
 .../branding/powered-by-apache.directive.js     |    7 +-
 .../app/modules/branding/powered-by-apache.jade |   18 -
 .../app/modules/branding/powered-by-apache.pug  |   18 +
 .../frontend/app/modules/cluster/Cache.js       |   52 +
 .../app/modules/cluster/CacheMetrics.js         |   59 +
 .../frontend/app/modules/cluster/Node.js        |   54 +
 .../frontend/app/modules/cluster/NodeMetrics.js |   19 +
 .../modules/configuration/Sidebar.provider.js   |   39 -
 .../modules/configuration/Version.service.js    |  176 +-
 .../configuration/configuration.module.js       |   10 +-
 .../generator/AbstractTransformer.js            |  118 +-
 .../modules/configuration/generator/Beans.js    |    8 +
 .../generator/ConfigurationGenerator.js         |  687 ++-
 .../configuration/generator/Docker.service.js   |   19 +-
 .../generator/JavaTransformer.service.js        |   41 +-
 .../configuration/generator/Maven.service.js    |  169 +-
 .../generator/Properties.service.js             |   63 +-
 .../generator/SpringTransformer.service.js      |   23 +-
 .../generator/defaults/Cache.service.js         |   11 +-
 .../generator/defaults/Cluster.service.js       |   75 +
 .../generator/defaults/IGFS.service.js          |    3 +-
 .../modules/configuration/sidebar.directive.js  |   30 -
 .../frontend/app/modules/demo/Demo.module.js    |   16 +-
 .../app/modules/dialog/dialog.factory.js        |    3 +-
 .../frontend/app/modules/dialog/dialog.jade     |   26 -
 .../frontend/app/modules/dialog/dialog.tpl.pug  |   26 +
 .../app/modules/form/field/down.directive.js    |    2 +-
 .../app/modules/form/field/up.directive.js      |    2 +-
 .../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 +
 .../app/modules/navbar/userbar.directive.js     |    4 +-
 .../frontend/app/modules/nodes/Nodes.service.js |    5 +-
 .../app/modules/nodes/nodes-dialog.jade         |   35 -
 .../app/modules/nodes/nodes-dialog.tpl.pug      |   35 +
 .../app/modules/sql/Notebook.service.js         |    2 +-
 .../app/modules/sql/notebook.controller.js      |    6 +-
 .../frontend/app/modules/sql/sql.controller.js  |  229 +-
 .../frontend/app/modules/sql/sql.module.js      |   19 +-
 .../frontend/app/modules/states/admin.state.js  |   27 +-
 .../app/modules/states/configuration.state.js   |  100 +-
 .../states/configuration/caches/affinity.jade   |   82 -
 .../states/configuration/caches/affinity.pug    |   89 +
 .../configuration/caches/client-near-cache.jade |   50 -
 .../configuration/caches/client-near-cache.pug  |   50 +
 .../configuration/caches/concurrency.jade       |   65 -
 .../states/configuration/caches/concurrency.pug |   68 +
 .../states/configuration/caches/general.jade    |   69 -
 .../states/configuration/caches/general.pug     |  119 +
 .../states/configuration/caches/memory.jade     |  109 -
 .../states/configuration/caches/memory.pug      |  130 +
 .../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 |   52 +
 .../states/configuration/caches/query.jade      |  114 -
 .../states/configuration/caches/query.pug       |  131 +
 .../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       |  255 +
 .../states/configuration/clusters/atomic.jade   |   54 -
 .../states/configuration/clusters/atomic.pug    |   79 +
 .../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       |  243 +
 .../configuration/clusters/discovery.jade       |   88 -
 .../states/configuration/clusters/discovery.pug |   92 +
 .../states/configuration/clusters/events.jade   |   68 -
 .../states/configuration/clusters/events.pug    |   70 +
 .../states/configuration/clusters/failover.jade |   73 -
 .../states/configuration/clusters/failover.pug  |   82 +
 .../states/configuration/clusters/general.jade  |   76 -
 .../states/configuration/clusters/general.pug   |   89 +
 .../clusters/general/discovery/cloud.jade       |  134 -
 .../clusters/general/discovery/cloud.pug        |  138 +
 .../clusters/general/discovery/google.jade      |   38 -
 .../clusters/general/discovery/google.pug       |   38 +
 .../clusters/general/discovery/jdbc.jade        |   31 -
 .../clusters/general/discovery/jdbc.pug         |   32 +
 .../clusters/general/discovery/kubernetes.pug   |   38 +
 .../clusters/general/discovery/multicast.jade   |   99 -
 .../clusters/general/discovery/multicast.pug    |  102 +
 .../clusters/general/discovery/s3.jade          |   27 -
 .../clusters/general/discovery/s3.pug           |   28 +
 .../clusters/general/discovery/shared.jade      |   23 -
 .../clusters/general/discovery/shared.pug       |   24 +
 .../clusters/general/discovery/vm.jade          |   79 -
 .../clusters/general/discovery/vm.pug           |   82 +
 .../clusters/general/discovery/zookeeper.jade   |   85 -
 .../clusters/general/discovery/zookeeper.pug    |   89 +
 .../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/hadoop.pug    |  119 +
 .../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       |   83 +
 .../states/configuration/clusters/memory.pug    |  124 +
 .../states/configuration/clusters/metrics.jade  |   51 -
 .../states/configuration/clusters/metrics.pug   |   51 +
 .../states/configuration/clusters/misc.pug      |   64 +
 .../states/configuration/clusters/odbc.jade     |   48 -
 .../states/configuration/clusters/odbc.pug      |   59 +
 .../configuration/clusters/persistence.pug      |   82 +
 .../states/configuration/clusters/service.pug   |   88 +
 .../configuration/clusters/sql-connector.pug    |   60 +
 .../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    |   92 +
 .../states/configuration/clusters/time.jade     |   47 -
 .../states/configuration/clusters/time.pug      |   50 +
 .../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      |  174 +
 .../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  |  123 +
 .../states/configuration/igfs/secondary.jade    |   45 -
 .../states/configuration/igfs/secondary.pug     |   45 +
 .../summary/summary-zipper.service.js           |    4 +-
 .../configuration/summary/summary.controller.js |   12 +-
 .../configuration/summary/summary.worker.js     |   67 +-
 .../frontend/app/modules/states/errors.state.js |    4 +-
 .../app/modules/states/password.state.js        |    6 +-
 .../app/modules/states/profile.state.js         |    6 +-
 .../frontend/app/modules/states/signin.state.js |    6 +-
 .../frontend/app/modules/user/Auth.service.js   |    8 +-
 .../frontend/app/primitives/badge/index.scss    |   41 +
 .../frontend/app/primitives/btn-group/index.pug |   39 +
 .../frontend/app/primitives/btn/index.scss      |  321 ++
 .../app/primitives/datepicker/index.pug         |   61 +
 .../app/primitives/datepicker/index.scss        |   94 +
 .../frontend/app/primitives/dropdown/index.pug  |   41 +
 .../frontend/app/primitives/dropdown/index.scss |  143 +
 .../frontend/app/primitives/file/index.pug      |   37 +
 .../frontend/app/primitives/file/index.scss     |   60 +
 .../app/primitives/form-field/index.scss        |   76 +
 .../frontend/app/primitives/grid/index.scss     |   42 +
 .../frontend/app/primitives/index.js            |   34 +
 .../frontend/app/primitives/modal/index.scss    |  215 +
 .../frontend/app/primitives/page/index.scss     |   35 +
 .../frontend/app/primitives/panel/index.scss    |   52 +
 .../frontend/app/primitives/switch/index.pug    |   34 +
 .../frontend/app/primitives/switch/index.scss   |   87 +
 .../frontend/app/primitives/switcher/index.pug  |   20 +
 .../frontend/app/primitives/switcher/index.scss |   80 +
 .../frontend/app/primitives/table/index.scss    |   91 +
 .../frontend/app/primitives/tabs/index.scss     |   88 +
 .../app/primitives/timepicker/index.pug         |   59 +
 .../app/primitives/timepicker/index.scss        |  137 +
 .../frontend/app/primitives/tooltip/index.pug   |   26 +
 .../app/primitives/typography/index.scss        |   36 +
 .../app/primitives/ui-grid-header/index.scss    |   99 +
 .../app/primitives/ui-grid-header/index.tpl.pug |   37 +
 .../app/primitives/ui-grid-settings/index.scss  |  256 +
 .../frontend/app/primitives/ui-grid/index.scss  |  521 ++
 .../web-console/frontend/app/services/Caches.js |   28 +
 .../frontend/app/services/Clone.service.js      |   64 -
 .../frontend/app/services/Clusters.js           |   95 +
 .../frontend/app/services/Clusters.spec.js      |   55 +
 .../frontend/app/services/Confirm.service.js    |    4 +-
 .../app/services/ConfirmBatch.service.js        |    5 +-
 .../frontend/controllers/caches-controller.js   |   54 +-
 .../frontend/controllers/clusters-controller.js |  209 +-
 .../frontend/controllers/domains-controller.js  |  233 +-
 .../frontend/controllers/igfs-controller.js     |   17 +-
 .../frontend/gulpfile.babel.js/index.js         |   26 -
 .../frontend/gulpfile.babel.js/paths.js         |   83 -
 .../frontend/gulpfile.babel.js/tasks/build.js   |   21 -
 .../frontend/gulpfile.babel.js/tasks/bundle.js  |   32 -
 .../frontend/gulpfile.babel.js/tasks/clean.js   |   32 -
 .../frontend/gulpfile.babel.js/tasks/copy.js    |   33 -
 .../gulpfile.babel.js/tasks/ignite-modules.js   |   55 -
 .../frontend/gulpfile.babel.js/tasks/jade.js    |   49 -
 .../frontend/gulpfile.babel.js/tasks/watch.js   |   33 -
 .../gulpfile.babel.js/webpack/common.js         |  191 -
 .../webpack/environments/development.js         |   79 -
 .../webpack/environments/production.js          |   44 -
 .../webpack/environments/test.js                |   52 -
 .../frontend/gulpfile.babel.js/webpack/index.js |   34 -
 .../frontend/ignite_modules/index.js            |    7 +-
 modules/web-console/frontend/package.json       |  184 +-
 .../frontend/public/images/icons/clock.svg      |    1 +
 .../frontend/public/images/icons/cross.svg      |    1 +
 .../frontend/public/images/icons/csv.svg        |    1 +
 .../frontend/public/images/icons/download.svg   |    2 +
 .../frontend/public/images/icons/filter.svg     |    1 +
 .../frontend/public/images/icons/gear.svg       |    1 +
 .../frontend/public/images/icons/index.js       |   25 +
 .../frontend/public/images/icons/manual.svg     |    1 +
 .../frontend/public/images/icons/search.svg     |    1 +
 .../frontend/public/images/ignite-logo.png      |  Bin 1982 -> 0 bytes
 .../frontend/public/images/ignite-logo.svg      |   17 +
 .../frontend/public/images/ignite-logo@2x.png   |  Bin 3325 -> 0 bytes
 .../stylesheets/_bootstrap-variables.scss       |   10 +-
 .../stylesheets/_font-awesome-custom.scss       |    5 +
 .../frontend/public/stylesheets/style.scss      |  373 +-
 .../frontend/public/stylesheets/variables.scss  |    8 +-
 .../frontend/test/e2e/exampe.test.js            |    4 +-
 .../frontend/test/karma.conf.babel.js           |   18 +-
 modules/web-console/frontend/test/karma.conf.js |    2 +-
 .../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          |   98 +-
 .../test/unit/defaultName.filter.test.js        |   27 +-
 modules/web-console/frontend/views/403.jade     |   22 -
 modules/web-console/frontend/views/403.tpl.pug  |   24 +
 modules/web-console/frontend/views/404.jade     |   22 -
 modules/web-console/frontend/views/404.tpl.pug  |   24 +
 modules/web-console/frontend/views/base.jade    |   22 -
 modules/web-console/frontend/views/base.pug     |   26 +
 modules/web-console/frontend/views/base2.pug    |   26 +
 .../frontend/views/configuration/caches.jade    |   55 -
 .../frontend/views/configuration/caches.tpl.pug |   55 +
 .../frontend/views/configuration/clusters.jade  |   68 -
 .../views/configuration/clusters.tpl.pug        |   85 +
 .../views/configuration/domains-import.jade     |  170 -
 .../views/configuration/domains-import.tpl.pug  |  178 +
 .../frontend/views/configuration/domains.jade   |   66 -
 .../views/configuration/domains.tpl.pug         |   65 +
 .../frontend/views/configuration/igfs.jade      |   51 -
 .../frontend/views/configuration/igfs.tpl.pug   |   54 +
 .../frontend/views/configuration/sidebar.jade   |   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/header-left.pug     |   56 +
 .../frontend/views/includes/header-right.pug    |   39 +
 .../frontend/views/includes/header.jade         |   52 -
 modules/web-console/frontend/views/index.jade   |   47 -
 modules/web-console/frontend/views/index.pug    |   48 +
 modules/web-console/frontend/views/reset.jade   |   48 -
 .../web-console/frontend/views/reset.tpl.pug    |   44 +
 .../frontend/views/settings/admin.jade          |   25 -
 .../frontend/views/settings/admin.tpl.pug       |   28 +
 .../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   |  159 +
 .../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  |  288 ++
 .../views/templates/agent-download.jade         |   50 -
 .../views/templates/agent-download.tpl.pug      |   61 +
 .../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    |   34 +
 .../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 -
 .../views/templates/validation-error.jade       |   25 -
 .../views/templates/validation-error.tpl.pug    |   25 +
 .../frontend/webpack/webpack.common.js          |  193 +
 .../frontend/webpack/webpack.dev.babel.js       |   97 +
 .../frontend/webpack/webpack.prod.babel.js      |   64 +
 .../frontend/webpack/webpack.test.js            |   33 +
 modules/web-console/licenses/cc-by-3.0.txt      |  319 ++
 modules/web-console/pom.xml                     |    2 +-
 modules/web-console/web-agent/README.txt        |    2 +-
 modules/web-console/web-agent/pom.xml           |   38 +-
 .../console/agent/AgentConfiguration.java       |   47 +-
 .../ignite/console/agent/AgentLauncher.java     |  329 +-
 .../apache/ignite/console/agent/AgentUtils.java |   74 +
 .../ignite/console/agent/db/DbColumn.java       |   95 +
 .../console/agent/db/DbMetadataReader.java      |  142 +
 .../ignite/console/agent/db/DbSchema.java       |   60 +
 .../apache/ignite/console/agent/db/DbTable.java |   87 +
 .../agent/db/dialect/DB2MetadataDialect.java    |   33 +
 .../db/dialect/DatabaseMetadataDialect.java     |  127 +
 .../agent/db/dialect/JdbcMetadataDialect.java   |  246 +
 .../agent/db/dialect/MySQLMetadataDialect.java  |   88 +
 .../agent/db/dialect/OracleMetadataDialect.java |  429 ++
 .../console/agent/handlers/AbstractHandler.java |  110 -
 .../agent/handlers/AbstractListener.java        |  104 +
 .../console/agent/handlers/ClusterListener.java |  327 ++
 .../console/agent/handlers/DatabaseHandler.java |  298 --
 .../agent/handlers/DatabaseListener.java        |  332 ++
 .../console/agent/handlers/DemoListener.java    |  131 +
 .../console/agent/handlers/RestHandler.java     |  276 -
 .../console/agent/handlers/RestListener.java    |   81 +
 .../ignite/console/agent/rest/RestExecutor.java |  224 +
 .../ignite/console/agent/rest/RestResult.java   |   81 +
 .../ignite/console/demo/AgentClusterDemo.java   |  622 +--
 .../ignite/console/demo/AgentDemoUtils.java     |   79 +
 .../demo/service/DemoCachesLoadService.java     |  480 ++
 .../demo/service/DemoComputeLoadService.java    |   79 +
 .../service/DemoRandomCacheLoadService.java     |  119 +
 .../service/DemoServiceClusterSingleton.java    |   41 +
 .../demo/service/DemoServiceKeyAffinity.java    |   41 +
 .../service/DemoServiceMultipleInstances.java   |   41 +
 .../demo/service/DemoServiceNodeSingleton.java  |   41 +
 .../console/demo/task/DemoCancellableTask.java  |   92 +
 .../console/demo/task/DemoComputeTask.java      |  105 +
 .../src/main/resources/log4j.properties         |    7 +-
 modules/web/ignite-appserver-test/pom.xml       |    2 +-
 modules/web/ignite-websphere-test/pom.xml       |    2 +-
 modules/web/pom.xml                             |    2 +-
 .../cache/websession/WebSessionFilter.java      |   34 +-
 .../servlet/ServletContextListenerStartup.java  |   12 +-
 .../ignite/startup/servlet/ServletStartup.java  |    8 +-
 .../internal/websession/WebSessionSelfTest.java |   25 +-
 .../webapp2/META-INF/ignite-webapp-config.xml   |   28 +-
 modules/yardstick/DEVNOTES-standalone.txt       |   16 +
 modules/yardstick/DEVNOTES.txt                  |   20 +-
 modules/yardstick/README.txt                    |  145 +-
 .../config/benchmark-atomic-win.properties      |   10 +-
 .../config/benchmark-atomic.properties          |   50 +-
 .../config/benchmark-bin-identity.properties    |   24 +-
 .../config/benchmark-cache-load-win.properties  |    2 +-
 .../config/benchmark-cache-load.properties      |   19 +-
 .../config/benchmark-client-mode.properties     |   67 +-
 .../config/benchmark-compute-win.properties     |    2 +-
 .../config/benchmark-compute.properties         |   51 +-
 .../config/benchmark-failover.properties        |   24 +-
 .../yardstick/config/benchmark-full.properties  |   80 +-
 .../yardstick/config/benchmark-h2.properties    |   56 +
 .../config/benchmark-multicast.properties       |  106 +-
 .../yardstick/config/benchmark-mysql.properties |   56 +
 .../yardstick/config/benchmark-pgsql.properties |   57 +
 .../config/benchmark-put-indexed-val.properties |   44 +-
 .../benchmark-query-put-separated.properties    |   11 +-
 .../config/benchmark-query-win.properties       |    7 +-
 .../yardstick/config/benchmark-query.properties |   51 +-
 .../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          |    8 +-
 .../yardstick/config/benchmark-tx.properties    |   50 +-
 .../yardstick/config/benchmark-win.properties   |    2 +-
 modules/yardstick/config/benchmark.properties   |   85 +-
 modules/yardstick/config/h2-schema.sql          |   11 +
 modules/yardstick/config/ignite-base-config.xml |   85 +-
 .../config/ignite-base-load-config.xml          |   98 +-
 .../config/ignite-cache-load-config.xml         |    5 -
 .../yardstick/config/ignite-db-base-config.xml  |  118 +
 .../config/ignite-db-localhost-config.xml       |   53 +
 .../config/ignite-failover-base-config.xml      |   43 -
 .../ignite-int-max-values-offheap-config.xml    |   89 -
 .../ignite-int-max-values-onheap-config.xml     |    5 +-
 .../ignite-int-max-values-swap-config.xml       |   93 -
 modules/yardstick/config/ignite-jdbc-config.xml |    4 +-
 .../config/ignite-localhost-config.xml          |    6 +
 .../yardstick/config/ignite-rdbms-config.xml    |   70 +
 .../yardstick/config/ignite-remote-config.xml   |   47 +
 .../yardstick/config/ignite-store-config.xml    |    2 -
 modules/yardstick/config/mysql-schema.sql       |   11 +
 modules/yardstick/config/pgsql-schema.sql       |   18 +
 .../config/sql/benchmark-jdbc-ignite.properties |   64 +
 .../sql/benchmark-mysql-ignite.properties       |   66 +
 .../config/sql/benchmark-native.properties      |   62 +
 .../sql/benchmark-pgsql-ignite.properties       |   66 +
 modules/yardstick/config/sql/db-h2-queries.sql  |    9 +
 .../yardstick/config/sql/db-mysql-queries.sql   |   14 +
 .../yardstick/config/sql/db-pgsql-queries.sql   |   14 +
 .../yardstick/config/sql/h2-insert-query.sql    |    1 +
 .../yardstick/config/sql/rdbms-mysql-schema.sql |    5 +
 .../yardstick/config/sql/rdbms-pgsql-schema.sql |   10 +
 .../test-max-int-values-offheap.properties      |   70 -
 .../test-max-int-values-onheap.properties       |   31 +-
 .../config/test-max-int-values-swap.properties  |   69 -
 modules/yardstick/pom-standalone.xml            |    2 +-
 modules/yardstick/pom.xml                       |   20 +-
 .../yardstick/IgniteAbstractBenchmark.java      |    8 +-
 .../yardstick/IgniteBenchmarkArguments.java     |  242 +-
 .../ignite/yardstick/IgniteBenchmarkUtils.java  |    9 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |   46 +-
 .../cache/IgniteBinaryIdentityBenchmark.java    |   21 -
 .../cache/IgniteCacheAbstractBenchmark.java     |  158 +
 .../yardstick/cache/IgniteGetAllBenchmark.java  |   45 +
 .../cache/IgniteGetAllOffHeapBenchmark.java     |   30 +
 .../cache/IgniteGetAllPutAllTxBenchmark.java    |    2 +
 .../cache/IgniteGetAndPutBenchmark.java         |    4 +-
 .../cache/IgniteGetAndPutTxBenchmark.java       |    4 +-
 .../yardstick/cache/IgniteGetBenchmark.java     |   19 +
 .../IgniteGetEntriesPutAllTxBenchmark.java      |    2 +
 .../cache/IgniteGetFromComputeBenchmark.java    |  167 +
 .../cache/IgniteGetOffHeapBenchmark.java        |   32 -
 .../cache/IgniteGetOffHeapValuesBenchmark.java  |   32 -
 .../yardstick/cache/IgniteInvokeBenchmark.java  |    2 +
 .../cache/IgniteInvokeTxBenchmark.java          |    2 +
 .../IgniteInvokeWithInjectionBenchmark.java     |    2 +
 .../cache/IgniteIoTestAbstractBenchmark.java    |   61 +
 .../cache/IgniteIoTestSendAllBenchmark.java     |   32 +
 .../cache/IgniteIoTestSendRandomBenchmark.java  |   35 +
 .../IgniteLegacyBinaryIdentityGetBenchmark.java |   30 -
 .../IgniteLegacyBinaryIdentityPutBenchmark.java |   30 -
 .../yardstick/cache/IgnitePutAllBenchmark.java  |   97 +-
 .../cache/IgnitePutAllOffHeapBenchmark.java     |   30 +
 .../IgnitePutAllSerializableTxBenchmark.java    |    2 +
 .../cache/IgnitePutAllTxBenchmark.java          |   43 +-
 .../cache/IgnitePutAllTxOffHeapBenchmark.java   |   30 +
 .../yardstick/cache/IgnitePutBenchmark.java     |    2 +
 .../cache/IgnitePutGetBatchBenchmark.java       |    2 +
 .../yardstick/cache/IgnitePutGetBenchmark.java  |    2 +
 .../cache/IgnitePutGetEntryBenchmark.java       |    2 +
 .../cache/IgnitePutGetEntryTxBenchmark.java     |    2 +
 .../cache/IgnitePutGetOffHeapBenchmark.java     |   32 -
 .../IgnitePutGetOffHeapValuesBenchmark.java     |   32 -
 .../cache/IgnitePutGetTxBatchBenchmark.java     |    2 +
 .../cache/IgnitePutGetTxBenchmark.java          |    2 +
 .../cache/IgnitePutGetTxOffHeapBenchmark.java   |   32 -
 .../IgnitePutGetTxOffHeapValuesBenchmark.java   |   32 -
 ...IgnitePutIfAbsentIndexedValue1Benchmark.java |    2 +
 .../cache/IgnitePutIndexedValue1Benchmark.java  |    2 +
 .../cache/IgnitePutIndexedValue2Benchmark.java  |    2 +
 .../cache/IgnitePutIndexedValue8Benchmark.java  |    2 +
 .../cache/IgnitePutOffHeapBenchmark.java        |   32 -
 .../IgnitePutOffHeapIndexedValue8Benchmark.java |   30 +
 .../cache/IgnitePutOffHeapValuesBenchmark.java  |   32 -
 .../IgnitePutRandomValueSizeBenchmark.java      |   43 +
 .../cache/IgnitePutRemoveBenchmark.java         |    2 +
 .../yardstick/cache/IgnitePutTxBenchmark.java   |    2 +
 .../cache/IgnitePutTxImplicitBenchmark.java     |    2 +
 .../cache/IgnitePutTxOffHeapBenchmark.java      |   32 -
 .../IgnitePutTxOffHeapValuesBenchmark.java      |   32 -
 .../cache/IgnitePutTxPrimaryOnlyBenchmark.java  |    2 +
 .../IgnitePutTxSkipLocalBackupBenchmark.java    |    2 +
 .../cache/IgnitePutValue8Benchmark.java         |   44 +
 .../IgniteReplaceIndexedValue1Benchmark.java    |    2 +
 .../cache/IgniteScanQueryBenchmark.java         |   88 +
 .../cache/IgniteSqlQueryBenchmark.java          |   16 +-
 .../IgniteSqlQueryDistributedJoinBenchmark.java |   24 +-
 .../cache/IgniteSqlQueryJoinBenchmark.java      |   14 +-
 .../IgniteSqlQueryJoinOffHeapBenchmark.java     |   32 -
 .../cache/IgniteSqlQueryOffHeapBenchmark.java   |   32 -
 .../cache/IgniteSqlQueryPutBenchmark.java       |    8 +-
 .../IgniteSqlQueryPutOffHeapBenchmark.java      |   32 -
 .../IgniteSqlQueryPutSeparatedBenchmark.java    |    4 +
 .../cache/WaitMapExchangeFinishCallable.java    |    4 +-
 .../dml/IgniteSqlDeleteFilteredBenchmark.java   |    5 +-
 .../dml/IgniteSqlUpdateFilteredBenchmark.java   |    5 +-
 .../IgniteAtomicInvokeRetryBenchmark.java       |   12 +-
 ...IgniteAtomicOffHeapInvokeRetryBenchmark.java |   31 -
 .../IgniteAtomicOffHeapRetriesBenchmark.java    |   31 -
 .../failover/IgniteAtomicRetriesBenchmark.java  |   12 +-
 .../IgniteFailoverAbstractBenchmark.java        |   22 +-
 ...IgniteTransactionalInvokeRetryBenchmark.java |   10 +-
 ...ransactionalOffHeapInvokeRetryBenchmark.java |   33 -
 ...ransactionalOffHeapWriteInvokeBenchmark.java |   37 -
 ...eTransactionalOffHeapWriteReadBenchmark.java |   32 -
 ...IgniteTransactionalWriteInvokeBenchmark.java |   16 +-
 .../IgniteTransactionalWriteReadBenchmark.java  |   12 +-
 .../cache/jdbc/IgniteNativeTxBenchmark.java     |  169 +
 .../cache/jdbc/JdbcAbstractBenchmark.java       |  202 +
 .../yardstick/cache/jdbc/JdbcPutBenchmark.java  |   86 +
 .../cache/jdbc/JdbcPutGetBenchmark.java         |   62 +
 .../jdbc/JdbcPutIndexedValue8Benchmark.java     |  104 +
 .../cache/jdbc/JdbcSqlQueryBenchmark.java       |   94 +
 .../cache/jdbc/JdbcSqlQueryJoinBenchmark.java   |  111 +
 .../yardstick/cache/jdbc/RdbmsBenchmark.java    |  220 +
 .../IgniteCacheRandomOperationBenchmark.java    |  127 +-
 .../yardstick/cache/load/model/ModelUtil.java   |    6 +-
 .../ignite/yardstick/cache/model/Accounts.java  |   62 +
 .../ignite/yardstick/cache/model/Branches.java  |   62 +
 .../ignite/yardstick/cache/model/History.java   |   69 +
 .../ignite/yardstick/cache/model/Tellers.java   |   62 +
 .../apache/ignite/yardstick/io/FileUtils.java   |   64 +
 modules/yarn/pom.xml                            |    2 +-
 .../apache/ignite/yarn/ClusterProperties.java   |    1 +
 .../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 +
 modules/zookeeper/pom.xml                       |    2 +-
 .../zk/TcpDiscoveryZookeeperIpFinder.java       |   37 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |   15 +-
 parent/pom.xml                                  |   43 +-
 pom.xml                                         |  438 +-
 scripts/git-remoteless-branches.sh              |   35 +
 6073 files changed, 418817 insertions(+), 181770 deletions(-)
----------------------------------------------------------------------