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:08 UTC

[11/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/DmlAstUtils.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/FastUpdateArguments.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/UpdatePlan.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/799098c6
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/799098c6
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/799098c6

Branch: refs/heads/ignite-6022-proto
Commit: 799098c6793d5351895b84fb7c5b80c2eefcc621
Parents: e66b664 e358ae2
Author: Alexander Paschenko <al...@gmail.com>
Authored: Fri Dec 15 14:38:40 2017 +0300
Committer: Alexander Paschenko <al...@gmail.com>
Committed: Fri Dec 15 14:38:40 2017 +0300

----------------------------------------------------------------------
 .gitignore                                      |     3 +
 README.md                                       |   323 +-
 README.txt                                      |     1 +
 RELEASE_NOTES.txt                               |   108 +
 assembly/dependencies-fabric-lgpl.xml           |     4 +
 assembly/dependencies-fabric.xml                |     4 +
 assembly/dependencies-sqlline.xml               |    58 +
 assembly/release-fabric-base.xml                |     3 +-
 bin/control.bat                                 |     1 +
 bin/control.sh                                  |     1 +
 examples/config/example-data-regions.xml        |   106 +
 examples/config/example-memory-policies.xml     |   108 -
 .../example-persistent-store.xml                |    37 +-
 examples/config/redis/example-redis.xml         |    74 +
 examples/pom-standalone-lgpl.xml                |    32 +-
 examples/pom-standalone.xml                     |    32 +-
 examples/pom.xml                                |    46 +-
 examples/redis/redis-example.py                 |    16 +-
 .../examples/datagrid/CacheQueryDdlExample.java |     2 +-
 .../examples/datagrid/DataRegionsExample.java   |   113 +
 .../ignite/examples/datagrid/JdbcExample.java   |     2 +-
 .../datagrid/MemoryPoliciesExample.java         |   114 -
 .../datastructures/IgniteSemaphoreExample.java  |    21 +-
 .../persistentstore/PersistentStoreExample.java |    27 +-
 .../clustering/DatasetWithObviousStructure.java |   105 +
 .../ml/clustering/FuzzyCMeansExample.java       |   125 +
 .../KMeansDistributedClustererExample.java      |    95 +
 .../clustering/KMeansLocalClustererExample.java |   106 +
 .../examples/ml/clustering/package-info.java    |    22 +
 .../KNNClassificationExample.java               |   151 +
 .../ml/knn/classification/package-info.java     |    22 +
 .../ignite/examples/ml/knn/package-info.java    |    22 +
 .../ml/knn/regression/KNNRegressionExample.java |   152 +
 .../ml/knn/regression/package-info.java         |    22 +
 .../decompositions/QRDecompositionExample.java  |    82 +
 .../ml/math/matrix/CacheMatrixExample.java      |     4 +-
 .../ml/math/matrix/ExampleMatrixStorage.java    |    12 +-
 .../DistributedRegressionExample.java           |   149 -
 .../ml/math/vector/CacheVectorExample.java      |     4 +-
 .../apache/ignite/examples/ml/package-info.java |    22 +
 .../DistributedRegressionExample.java           |   149 +
 .../DistributedRegressionModelExample.java      |   134 +
 .../examples/ml/regression/package-info.java    |    22 +
 .../ignite/examples/ml/trees/MNISTExample.java  |   261 +
 .../ignite/examples/ml/trees/package-info.java  |    22 +
 .../src/main/resources/datasets/knn/README.md   |     2 +
 .../resources/datasets/knn/cleared_machines.txt |   209 +
 .../src/main/resources/datasets/knn/iris.txt    |   150 +
 .../examples/ScalarCreditRiskExample.scala      |     4 +-
 .../ignite/examples/CacheExamplesSelfTest.java  |     6 +-
 modules/aop/pom.xml                             |     2 +-
 modules/apache-license-gen/pom.xml              |     2 +-
 modules/aws/pom.xml                             |     2 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    81 +-
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java |    12 +
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |    65 +-
 .../s3/S3CheckpointManagerSelfTest.java         |     2 +-
 .../checkpoint/s3/S3CheckpointSpiSelfTest.java  |    26 +-
 ...pointSpiStartStopBucketEndpointSelfTest.java |    50 +
 ...ckpointSpiStartStopSSEAlgorithmSelfTest.java |    49 +
 .../s3/S3CheckpointSpiStartStopSelfTest.java    |     2 +-
 .../s3/S3SessionCheckpointSelfTest.java         |     2 +-
 .../TcpDiscoveryS3IpFinderAbstractSelfTest.java |    66 +-
 ...3IpFinderAwsCredentialsProviderSelfTest.java |     1 +
 ...scoveryS3IpFinderAwsCredentialsSelfTest.java |     1 +
 ...scoveryS3IpFinderBucketEndpointSelfTest.java |    55 +
 ...DiscoveryS3IpFinderSSEAlgorithmSelfTest.java |    48 +
 .../ignite/testsuites/IgniteS3TestSuite.java    |     8 +
 modules/benchmarks/pom.xml                      |     2 +-
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java |     8 +-
 modules/camel/pom.xml                           |     2 +-
 modules/cassandra/pom.xml                       |     2 +-
 modules/cassandra/serializers/pom.xml           |     4 +-
 modules/cassandra/store/pom.xml                 |     4 +-
 modules/clients/pom.xml                         |    16 +-
 modules/clients/src/test/config/jdbc-config.xml |     1 +
 .../jdbc2/JdbcConnectionReopenTest.java         |    51 +
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |    49 +-
 .../jdbc2/JdbcDeleteStatementSelfTest.java      |    22 +
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java |    39 +-
 .../internal/jdbc2/JdbcErrorsSelfTest.java      |    67 +
 .../jdbc2/JdbcInsertStatementSelfTest.java      |   168 +-
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java |    28 +
 .../jdbc2/JdbcMergeStatementSelfTest.java       |    41 +
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |   184 +-
 .../jdbc2/JdbcStatementBatchingSelfTest.java    |   133 +
 .../internal/jdbc2/JdbcStatementSelfTest.java   |   130 +-
 .../jdbc2/JdbcUpdateStatementSelfTest.java      |    24 +
 .../JettyRestProcessorAbstractSelfTest.java     |    46 +
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java |   659 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    35 +-
 .../JdbcThinAbstractDmlStatementSelfTest.java   |    16 +-
 .../jdbc/thin/JdbcThinAbstractSelfTest.java     |    71 +-
 .../thin/JdbcThinAutoCloseServerCursorTest.java |    12 +-
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java |     2 +-
 .../thin/JdbcThinComplexDmlDdlSelfTest.java     |   493 +
 ...omplexDmlDdlSkipReducerOnUpdateSelfTest.java |    33 +
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java |     2 +-
 .../jdbc/thin/JdbcThinConnectionSelfTest.java   |  1560 ++-
 .../JdbcThinDynamicIndexAbstractSelfTest.java   |     6 +-
 .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java   |     2 +-
 .../jdbc/thin/JdbcThinErrorsSelfTest.java       |   108 +
 .../thin/JdbcThinInsertStatementSelfTest.java   |     3 +-
 ...ertStatementSkipReducerOnUpdateSelfTest.java |    33 +
 ...rgeStatementSkipReducerOnUpdateSelfTest.java |    33 +
 .../jdbc/thin/JdbcThinMetadataSelfTest.java     |   362 +-
 .../JdbcThinMissingLongArrayResultsTest.java    |   341 +
 .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java  |    85 +-
 .../thin/JdbcThinPreparedStatementSelfTest.java |   263 +-
 .../jdbc/thin/JdbcThinResultSetSelfTest.java    |  1197 +-
 .../jdbc/thin/JdbcThinSchemaCaseTest.java       |   129 +
 .../thin/JdbcThinSelectAfterAlterTable.java     |   173 +
 .../jdbc/thin/JdbcThinStatementSelfTest.java    |   916 +-
 ...ateStatementSkipReducerOnUpdateSelfTest.java |    33 +
 modules/clients/src/test/keystore/ca/node01.jks |   Bin 0 -> 3719 bytes
 modules/clients/src/test/keystore/ca/node02.jks |   Bin 0 -> 4598 bytes
 modules/clients/src/test/keystore/ca/node03.jks |   Bin 0 -> 3754 bytes
 modules/clients/src/test/keystore/ca/oneca.cnf  |    31 +
 modules/clients/src/test/keystore/ca/oneca.key  |    28 +
 .../clients/src/test/keystore/ca/oneindex.txt   |     1 +
 .../src/test/keystore/ca/oneindex.txt.attr      |     1 +
 modules/clients/src/test/keystore/ca/oneserial  |     1 +
 .../clients/src/test/keystore/ca/trust-both.jks |   Bin 0 -> 1718 bytes
 .../clients/src/test/keystore/ca/trust-one.jks  |   Bin 0 -> 877 bytes
 .../clients/src/test/keystore/ca/trust-two.jks  |   Bin 0 -> 891 bytes
 modules/clients/src/test/keystore/ca/twoca.cnf  |    31 +
 modules/clients/src/test/keystore/ca/twoca.key  |    28 +
 .../clients/src/test/keystore/ca/twoindex.txt   |     2 +
 .../src/test/keystore/ca/twoindex.txt.attr      |     1 +
 modules/clients/src/test/keystore/ca/twoserial  |     1 +
 modules/cloud/pom.xml                           |     2 +-
 modules/codegen/pom.xml                         |     2 +-
 .../ignite/codegen/MessageCodeGenerator.java    |     2 +
 modules/compatibility/README.txt                |     5 +
 modules/compatibility/licenses/apache-2.0.txt   |   202 +
 modules/compatibility/pom.xml                   |   126 +
 .../ignite/compatibility/package-info.java      |    22 +
 .../DummyPersistenceCompatibilityTest.java      |   361 +
 .../FoldersReuseCompatibilityTest.java          |   262 +
 ...itePersistenceCompatibilityAbstractTest.java |    94 +
 ...tingToWalV2SerializerWithCompactionTest.java |   250 +
 .../compatibility/persistence/package-info.java |    22 +
 .../junits/CompatibilityTestsFacade.java        |    46 +
 .../testframework/junits/Dependency.java        |   117 +
 .../junits/IgniteCompatibilityAbstractTest.java |   329 +
 .../junits/IgniteCompatibilityNodeRunner.java   |   221 +
 .../logger/ListenedGridTestLog4jLogger.java     |    91 +
 .../junits/logger/package-info.java             |    22 +
 .../testframework/junits/package-info.java      |    22 +
 .../testframework/package-info.java             |    22 +
 .../plugins/DisabledValidationProcessor.java    |    42 +
 .../TestCompatibilityPluginProvider.java        |   119 +
 .../testframework/plugins/package-info.java     |    22 +
 .../testframework/util/MavenUtils.java          |   196 +
 .../testframework/util/package-info.java        |    22 +
 .../IgniteCompatibilityBasicTestSuite.java      |    44 +
 .../compatibility/testsuites/package-info.java  |    22 +
 .../org.apache.ignite.plugin.PluginProvider     |     1 +
 modules/core/pom.xml                            |     2 +-
 .../org/apache/ignite/DataRegionMetrics.java    |   130 +
 .../apache/ignite/DataRegionMetricsAdapter.java |   106 +
 .../org/apache/ignite/DataStorageMetrics.java   |   114 +
 .../ignite/DataStorageMetricsAdapter.java       |   101 +
 .../src/main/java/org/apache/ignite/Ignite.java |    49 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |    46 +-
 .../org/apache/ignite/IgniteJdbcThinDriver.java |    53 +-
 .../java/org/apache/ignite/IgniteServices.java  |   106 +-
 .../apache/ignite/IgniteSystemProperties.java   |    47 +
 .../java/org/apache/ignite/MemoryMetrics.java   |    11 +-
 .../org/apache/ignite/PersistenceMetrics.java   |     4 +-
 .../org/apache/ignite/cache/CacheMetrics.java   |    46 +-
 .../java/org/apache/ignite/cache/CacheMode.java |     2 +-
 .../org/apache/ignite/cache/QueryEntity.java    |    59 +-
 .../org/apache/ignite/cache/QueryIndex.java     |    41 +-
 .../eviction/AbstractEvictionPolicyFactory.java |   106 +
 .../fifo/FifoEvictionPolicyFactory.java         |    72 +
 .../eviction/lru/LruEvictionPolicyFactory.java  |    72 +
 .../sorted/SortedEvictionPolicyFactory.java     |    98 +
 .../ignite/cache/query/SqlFieldsQuery.java      |    63 +-
 .../query/annotations/QueryGroupIndex.java      |    20 +
 .../cache/query/annotations/QuerySqlField.java  |    30 +
 .../apache/ignite/cluster/ClusterMetrics.java   |    12 +-
 .../configuration/CacheConfiguration.java       |    95 +-
 .../configuration/CheckpointWriteOrder.java     |    51 +
 .../ClientConnectorConfiguration.java           |   275 +
 .../configuration/DataPageEvictionMode.java     |     8 +-
 .../configuration/DataRegionConfiguration.java  |   434 +
 .../configuration/DataStorageConfiguration.java |   880 ++
 .../configuration/IgniteConfiguration.java      |    91 +-
 .../configuration/MemoryConfiguration.java      |    19 +-
 .../MemoryPolicyConfiguration.java              |     9 +-
 .../configuration/NearCacheConfiguration.java   |    37 +
 .../ignite/configuration/OdbcConfiguration.java |     4 +-
 .../PersistentStoreConfiguration.java           |    67 +-
 .../SqlConnectorConfiguration.java              |     7 +-
 .../apache/ignite/configuration/WALMode.java    |    15 +-
 .../org/apache/ignite/igfs/IgfsMetrics.java     |     4 +-
 .../ClusterLocalNodeMetricsMXBeanImpl.java      |    69 +-
 .../internal/ClusterMetricsMXBeanImpl.java      |   438 +
 .../ignite/internal/ClusterMetricsSnapshot.java |    41 +-
 .../internal/DuplicateTypeIdException.java      |    74 +
 .../internal/GridEventConsumeHandler.java       |     9 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   133 +-
 .../ignite/internal/GridKernalContext.java      |    11 +-
 .../ignite/internal/GridKernalContextImpl.java  |    28 +-
 .../apache/ignite/internal/GridLoggerProxy.java |     9 +
 .../ignite/internal/GridTaskSessionImpl.java    |    18 +
 .../ignite/internal/IgniteComputeImpl.java      |     8 +-
 .../internal/IgniteDiagnosticMessage.java       |     2 +-
 .../IgniteDiagnosticPrepareContext.java         |     4 +-
 .../org/apache/ignite/internal/IgniteEx.java    |    14 +
 .../apache/ignite/internal/IgniteKernal.java    |   191 +-
 .../ignite/internal/IgniteNodeAttributes.java   |    10 +
 .../ignite/internal/IgniteServicesImpl.java     |    63 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   169 +-
 .../ignite/internal/MarshallerContextImpl.java  |    60 +-
 .../internal/MarshallerMappingFileStore.java    |   115 +-
 .../internal/binary/BinaryClassDescriptor.java  |     7 +-
 .../ignite/internal/binary/BinaryContext.java   |    67 +-
 .../ignite/internal/binary/BinaryMetadata.java  |     8 +-
 .../ignite/internal/binary/BinaryUtils.java     |    26 +
 .../binary/builder/BinaryObjectBuilderImpl.java |    19 +-
 .../GridClientConnectionManagerAdapter.java     |     1 -
 .../connection/GridClientNioTcpConnection.java  |     4 +-
 .../internal/commandline/CommandHandler.java    |     2 +-
 .../internal/jdbc/JdbcDatabaseMetadata.java     |     2 +-
 .../jdbc/thin/ConnectionProperties.java         |   148 +
 .../jdbc/thin/ConnectionPropertiesImpl.java     |   637 +
 .../internal/jdbc/thin/JdbcThinConnection.java  |   296 +-
 .../jdbc/thin/JdbcThinDatabaseMetadata.java     |  1545 +++
 .../jdbc/thin/JdbcThinParameterMetadata.java    |   115 +
 .../jdbc/thin/JdbcThinPreparedStatement.java    |    75 +-
 .../internal/jdbc/thin/JdbcThinResultSet.java   |   707 +-
 .../internal/jdbc/thin/JdbcThinStatement.java   |   305 +-
 .../internal/jdbc/thin/JdbcThinTcpIo.java       |   407 +-
 .../internal/jdbc/thin/JdbcThinUtils.java       |    67 +-
 .../internal/jdbc2/JdbcBatchUpdateTask.java     |   224 +
 .../ignite/internal/jdbc2/JdbcConnection.java   |   129 +-
 .../internal/jdbc2/JdbcDatabaseMetadata.java    |   724 +-
 .../internal/jdbc2/JdbcPreparedStatement.java   |    25 +-
 .../jdbc2/JdbcQueryMultipleStatementsTask.java  |   168 +
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |   180 +-
 .../internal/jdbc2/JdbcQueryTaskResult.java     |   120 +
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java  |   107 +
 .../ignite/internal/jdbc2/JdbcQueryTaskV3.java  |   105 +
 .../ignite/internal/jdbc2/JdbcResultSet.java    |   193 +-
 .../internal/jdbc2/JdbcSqlFieldsQuery.java      |   105 -
 .../ignite/internal/jdbc2/JdbcStatement.java    |   340 +-
 .../internal/jdbc2/JdbcStatementResultInfo.java |    73 +
 .../jdbc2/JdbcStreamedPreparedStatement.java    |    19 +-
 .../apache/ignite/internal/jdbc2/JdbcUtils.java |    42 +
 .../logger/platform/PlatformLogger.java         |    15 +
 .../managers/communication/GridIoManager.java   |    11 +-
 .../communication/GridIoMessageFactory.java     |    23 +-
 .../managers/deployment/GridDeploymentInfo.java |     1 +
 .../deployment/GridDeploymentInfoBean.java      |    21 +-
 .../GridDeploymentPerVersionStore.java          |    44 +-
 .../managers/discovery/ConsistentIdMapper.java  |   101 +
 .../internal/managers/discovery/DiscoCache.java |   160 +-
 .../discovery/DiscoveryCustomMessage.java       |    13 +-
 .../discovery/GridDiscoveryManager.java         |   410 +-
 .../optimized/OptimizedObjectInputStream.java   |    22 +
 .../optimized/OptimizedObjectOutputStream.java  |    17 +-
 .../ignite/internal/pagemem/PageIdUtils.java    |    32 +
 .../ignite/internal/pagemem/PageUtils.java      |    26 +
 .../pagemem/impl/PageMemoryNoStoreImpl.java     |    34 +-
 .../pagemem/store/IgnitePageStoreManager.java   |     4 +-
 .../internal/pagemem/store/PageStore.java       |     5 +-
 .../pagemem/wal/IgniteWriteAheadLogManager.java |     8 +
 .../ignite/internal/pagemem/wal/WALPointer.java |     4 +-
 .../pagemem/wal/record/CheckpointRecord.java    |     6 +
 .../internal/pagemem/wal/record/DataEntry.java  |    28 +-
 .../internal/pagemem/wal/record/DataRecord.java |    26 +-
 .../pagemem/wal/record/FilteredRecord.java      |    31 +
 .../pagemem/wal/record/LazyDataEntry.java       |    38 +-
 .../pagemem/wal/record/MarshalledRecord.java    |    61 +
 .../wal/record/MemoryRecoveryRecord.java        |     7 +
 .../pagemem/wal/record/PageSnapshot.java        |    23 +-
 .../pagemem/wal/record/SnapshotRecord.java      |    58 +
 .../pagemem/wal/record/SwitchSegmentRecord.java |    28 +
 .../pagemem/wal/record/TimeStampRecord.java     |    57 +
 .../internal/pagemem/wal/record/TxRecord.java   |   163 +-
 .../pagemem/wal/record/UnwrapDataEntry.java     |   126 +
 .../internal/pagemem/wal/record/WALRecord.java  |     6 +-
 .../delta/DataPageInsertFragmentRecord.java     |    13 +-
 .../wal/record/delta/DataPageInsertRecord.java  |     6 +
 .../wal/record/delta/DataPageRemoveRecord.java  |     2 +-
 .../delta/DataPageSetFreeListPageRecord.java    |     6 +
 .../wal/record/delta/DataPageUpdateRecord.java  |     6 +
 .../wal/record/delta/FixCountRecord.java        |     9 +
 .../record/delta/FixLeftmostChildRecord.java    |     9 +
 .../pagemem/wal/record/delta/FixRemoveId.java   |     6 +
 .../wal/record/delta/InitNewPageRecord.java     |     2 -
 .../wal/record/delta/InnerReplaceRecord.java    |     6 +
 .../pagemem/wal/record/delta/InsertRecord.java  |     2 +-
 .../pagemem/wal/record/delta/MergeRecord.java   |     2 +-
 .../wal/record/delta/MetaPageAddRootRecord.java |     9 +
 .../wal/record/delta/MetaPageCutRootRecord.java |     6 +
 .../wal/record/delta/MetaPageInitRecord.java    |     6 +
 .../delta/MetaPageInitRootInlineRecord.java     |     7 +-
 .../record/delta/MetaPageInitRootRecord.java    |     6 +
 .../delta/MetaPageUpdateLastAllocatedIndex.java |     6 +
 ...aPageUpdateLastSuccessfulFullSnapshotId.java |     6 +
 .../MetaPageUpdateLastSuccessfulSnapshotId.java |     6 +
 .../delta/MetaPageUpdateNextSnapshotId.java     |     6 +
 .../MetaPageUpdatePartitionDataRecord.java      |     2 +-
 .../wal/record/delta/NewRootInitRecord.java     |     6 +
 .../delta/PageListMetaResetCountRecord.java     |     6 +
 .../delta/PagesListInitNewPageRecord.java       |     4 +-
 .../record/delta/PagesListRemovePageRecord.java |     3 +-
 .../record/delta/PagesListSetNextRecord.java    |     6 +
 .../delta/PagesListSetPreviousRecord.java       |     6 +
 .../record/delta/PartitionDestroyRecord.java    |     6 +
 .../record/delta/PartitionMetaStateRecord.java  |     6 +
 .../pagemem/wal/record/delta/RecycleRecord.java |    15 +
 .../pagemem/wal/record/delta/RemoveRecord.java  |     2 +-
 .../pagemem/wal/record/delta/ReplaceRecord.java |     6 +
 .../record/delta/SplitExistingPageRecord.java   |     2 +-
 .../record/delta/SplitForwardPageRecord.java    |    24 +
 .../record/delta/TrackingPageDeltaRecord.java   |    14 +-
 .../processors/affinity/AffinityAssignment.java |     5 +
 .../affinity/AffinityTopologyVersion.java       |     7 +
 .../affinity/GridAffinityAssignment.java        |    45 +-
 .../affinity/GridAffinityAssignmentCache.java   |    60 +-
 .../affinity/GridAffinityProcessor.java         |     8 +-
 .../affinity/HistoryAffinityAssignment.java     |    15 +
 .../cache/CacheAffinityChangeMessage.java       |     8 +
 .../cache/CacheAffinitySharedManager.java       |   789 +-
 .../cache/CacheClusterMetricsMXBeanImpl.java    |    32 +-
 .../processors/cache/CacheGroupContext.java     |    64 +-
 .../processors/cache/CacheGroupData.java        |    17 +-
 .../processors/cache/CacheGroupDescriptor.java  |    19 +-
 .../cache/CacheGroupMetricsMXBeanImpl.java      |   255 +
 .../cache/CacheLocalMetricsMXBeanImpl.java      |    32 +-
 .../processors/cache/CacheMetricsImpl.java      |    81 +-
 .../processors/cache/CacheMetricsSnapshot.java  |    48 +
 .../processors/cache/CacheObjectUtils.java      |    65 +-
 .../cache/CachePartitionExchangeWorkerTask.java |     5 +-
 .../ClientCacheChangeDiscoveryMessage.java      |     9 +
 .../ClientCacheChangeDummyDiscoveryMessage.java |    14 +
 .../cache/ClientCacheUpdateTimeout.java         |     5 +
 .../processors/cache/ClusterCachesInfo.java     |    55 +-
 .../cache/DynamicCacheChangeBatch.java          |     9 +
 .../cache/DynamicCacheChangeRequest.java        |    29 +-
 .../processors/cache/ExchangeContext.java       |   131 +
 .../cache/ExchangeDiscoveryEvents.java          |   262 +
 .../cache/GatewayProtectedCacheProxy.java       |     5 -
 .../processors/cache/GridCacheAdapter.java      |   299 +-
 .../cache/GridCacheAffinityManager.java         |     9 +-
 .../processors/cache/GridCacheAttributes.java   |    19 +
 .../processors/cache/GridCacheContext.java      |    38 +-
 .../cache/GridCacheDeploymentManager.java       |    54 +-
 .../processors/cache/GridCacheEntryEx.java      |    18 +-
 .../cache/GridCacheEvictionManager.java         |    15 +-
 .../processors/cache/GridCacheIoManager.java    |    66 +-
 .../processors/cache/GridCacheLockCallback.java |    51 +
 .../processors/cache/GridCacheMapEntry.java     |    98 +-
 .../processors/cache/GridCacheMvccCallback.java |    51 -
 .../processors/cache/GridCacheMvccFuture.java   |    37 -
 .../processors/cache/GridCacheMvccManager.java  |    51 +-
 .../GridCachePartitionExchangeManager.java      |   517 +-
 .../processors/cache/GridCacheProcessor.java    |   408 +-
 .../processors/cache/GridCacheProxyImpl.java    |    12 -
 .../cache/GridCacheSharedContext.java           |    22 +-
 .../processors/cache/GridCacheTtlManager.java   |     3 +-
 .../processors/cache/GridCacheUtils.java        |   343 +-
 .../cache/GridCacheVersionedFuture.java         |    37 +
 .../cache/IgniteCacheOffheapManager.java        |    23 +-
 .../cache/IgniteCacheOffheapManagerImpl.java    |  1305 +-
 .../processors/cache/IgniteCacheProxy.java      |     8 -
 .../processors/cache/IgniteCacheProxyImpl.java  |    50 +-
 .../processors/cache/IgniteInternalCache.java   |     9 -
 .../processors/cache/StoredCacheData.java       |     9 +
 .../cache/binary/BinaryMetadataFileStore.java   |    81 +-
 .../cache/binary/BinaryMetadataTransport.java   |    38 +-
 .../binary/CacheObjectBinaryProcessor.java      |    20 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |    59 +-
 .../binary/MetadataUpdateAcceptedMessage.java   |     9 +
 .../binary/MetadataUpdateProposedMessage.java   |     9 +
 .../CacheDataStructuresManager.java             |    12 +
 .../GridDistributedTxRemoteAdapter.java         |     7 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |     5 +-
 .../dht/ClientCacheDhtTopologyFuture.java       |    12 +-
 .../dht/GridClientPartitionTopology.java        |   225 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |    24 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |     2 -
 .../distributed/dht/GridDhtGetSingleFuture.java |     2 -
 .../distributed/dht/GridDhtLocalPartition.java  |   111 +-
 .../distributed/dht/GridDhtLockFuture.java      |     6 +-
 .../dht/GridDhtPartitionTopology.java           |    67 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  1377 +-
 .../dht/GridDhtPartitionsReservation.java       |     2 +-
 .../distributed/dht/GridDhtTopologyFuture.java  |    36 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |    97 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |     2 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |    54 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |     4 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   462 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |     5 +
 .../dht/GridPartitionedGetFuture.java           |    62 +-
 .../dht/GridPartitionedSingleGetFuture.java     |    43 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |     2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   181 +-
 .../GridNearAtomicSingleUpdateFuture.java       |    10 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |     9 +-
 .../dht/colocated/GridDhtColocatedCache.java    |    30 +-
 .../colocated/GridDhtColocatedLockFuture.java   |    87 +-
 .../colocated/GridDhtDetachedCacheEntry.java    |     4 +-
 .../preloader/CacheGroupAffinityMessage.java    |   339 +
 .../CachePartitionFullCountersMap.java          |   135 +
 .../CachePartitionPartialCountersMap.java       |   184 +
 .../preloader/ForceRebalanceExchangeTask.java   |     5 +
 .../dht/preloader/GridDhtPartitionDemander.java |    42 +-
 .../preloader/GridDhtPartitionExchangeId.java   |    11 +
 .../dht/preloader/GridDhtPartitionMap.java      |    30 +-
 .../dht/preloader/GridDhtPartitionSupplier.java |     6 +-
 .../GridDhtPartitionsAbstractMessage.java       |    39 +-
 .../GridDhtPartitionsExchangeFuture.java        |  2138 +++-
 .../preloader/GridDhtPartitionsFullMessage.java |   228 +-
 .../GridDhtPartitionsSingleMessage.java         |   108 +-
 .../GridDhtPartitionsSingleRequest.java         |    55 +-
 .../dht/preloader/GridDhtPreloader.java         |    46 +-
 .../IgniteDhtPartitionCountersMap.java          |     7 +
 .../IgniteDhtPartitionCountersMap2.java         |    69 +
 .../dht/preloader/InitNewCoordinatorFuture.java |   346 +
 .../RebalanceReassignExchangeTask.java          |     5 +
 .../distributed/near/GridNearAtomicCache.java   |     2 -
 .../distributed/near/GridNearCacheAdapter.java  |     5 +-
 .../distributed/near/GridNearCacheEntry.java    |     7 +-
 .../distributed/near/GridNearGetFuture.java     |    47 +-
 .../distributed/near/GridNearGetRequest.java    |     2 +-
 .../distributed/near/GridNearLockFuture.java    |   124 +-
 .../distributed/near/GridNearLockRequest.java   |     2 +-
 ...arOptimisticSerializableTxPrepareFuture.java |     5 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |    22 +-
 .../GridNearPessimisticTxPrepareFuture.java     |     3 +-
 .../near/GridNearTransactionalCache.java        |    12 +-
 .../near/GridNearTxFastFinishFuture.java        |    82 +
 .../near/GridNearTxFinishFuture.java            |    23 +-
 .../cache/distributed/near/GridNearTxLocal.java |   344 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |     4 +-
 .../near/GridNearTxPrepareRequest.java          |    16 +-
 .../distributed/near/GridNearTxRemote.java      |     5 +
 .../distributed/near/NearTxFinishFuture.java    |    31 +
 .../processors/cache/local/GridLocalCache.java  |     5 +-
 .../cache/local/GridLocalLockFuture.java        |     4 +-
 .../local/atomic/GridLocalAtomicCache.java      |   196 +-
 .../cache/persistence/CacheDataRowAdapter.java  |     7 +-
 .../cache/persistence/DataRegion.java           |    84 +
 .../persistence/DataRegionMetricsImpl.java      |   307 +
 .../DataRegionMetricsMXBeanImpl.java            |   136 +
 .../persistence/DataRegionMetricsSnapshot.java  |   121 +
 .../persistence/DataStorageMetricsImpl.java     |   297 +
 .../persistence/DataStorageMetricsSnapshot.java |   144 +
 .../GridCacheDatabaseSharedManager.java         |   714 +-
 .../persistence/GridCacheOffheapManager.java    |    67 +-
 .../IgniteCacheDatabaseSharedManager.java       |   599 +-
 .../cache/persistence/MemoryMetricsImpl.java    |   284 -
 .../persistence/MemoryMetricsMXBeanImpl.java    |   131 -
 .../persistence/MemoryMetricsSnapshot.java      |   112 -
 .../cache/persistence/MemoryPolicy.java         |    83 -
 .../cache/persistence/MetadataStorage.java      |    21 +-
 .../persistence/PersistenceMetricsImpl.java     |   297 -
 .../persistence/PersistenceMetricsSnapshot.java |   144 -
 .../processors/cache/persistence/RowStore.java  |    40 +-
 .../evict/FairFifoPageEvictionTracker.java      |     6 +-
 .../evict/PageAbstractEvictionTracker.java      |     6 +-
 .../evict/Random2LruPageEvictionTracker.java    |     8 +-
 .../evict/RandomLruPageEvictionTracker.java     |     8 +-
 .../cache/persistence/file/AsyncFileIO.java     |   218 +
 .../persistence/file/AsyncFileIOFactory.java    |    66 +
 .../cache/persistence/file/FileIODecorator.java |     1 -
 .../cache/persistence/file/FileIOFactory.java   |    25 +-
 .../cache/persistence/file/FilePageStore.java   |    47 +-
 .../persistence/file/FilePageStoreManager.java  |   124 +-
 .../cache/persistence/file/FilePageStoreV2.java |     4 +-
 .../file/FileVersionCheckingFactory.java        |     8 +-
 .../persistence/file/RandomAccessFileIO.java    |    48 +-
 .../file/RandomAccessFileIOFactory.java         |    14 +-
 .../filename/PdsConsistentIdProcessor.java      |   569 +
 .../persistence/filename/PdsFolderSettings.java |   138 +
 .../filename/PdsFoldersResolver.java            |    33 +
 .../persistence/freelist/FreeListImpl.java      |    37 +-
 .../cache/persistence/freelist/PagesList.java   |    42 +-
 .../freelist/io/PagesListMetaIO.java            |    21 +
 .../freelist/io/PagesListNodeIO.java            |    19 +-
 .../persistence/pagemem/PageMemoryImpl.java     |   272 +-
 .../persistence/pagemem/PagesWriteThrottle.java |   105 +
 .../snapshot/IgniteCacheSnapshotManager.java    |     9 +-
 .../persistence/snapshot/SnapshotOperation.java |    13 +-
 .../cache/persistence/tree/BPlusTree.java       |   179 +-
 .../cache/persistence/tree/io/BPlusIO.java      |    12 +
 .../cache/persistence/tree/io/BPlusMetaIO.java  |    12 +
 .../cache/persistence/tree/io/DataPageIO.java   |    46 +-
 .../cache/persistence/tree/io/IOVersions.java   |     3 +
 .../cache/persistence/tree/io/PageIO.java       |    52 +-
 .../cache/persistence/tree/io/PageMetaIO.java   |    14 +
 .../tree/io/PagePartitionCountersIO.java        |    27 +
 .../tree/io/PagePartitionMetaIO.java            |    19 +
 .../persistence/tree/io/TrackingPageIO.java     |    31 +
 .../wal/AbstractWalRecordsIterator.java         |   147 +-
 .../persistence/wal/ByteBufferExpander.java     |    27 +-
 .../cache/persistence/wal/FileInput.java        |    15 +-
 .../cache/persistence/wal/FileWALPointer.java   |     3 +
 .../wal/FileWriteAheadLogManager.java           |   961 +-
 .../cache/persistence/wal/RecordSerializer.java |    57 -
 .../SingleSegmentLogicalRecordsIterator.java    |   141 +
 .../wal/WalSegmentTailReachedException.java     |    37 +
 .../wal/reader/IgniteWalIteratorFactory.java    |   130 +-
 .../wal/reader/StandaloneGridKernalContext.java |   145 +-
 .../reader/StandaloneIgnitePluginProcessor.java |     6 +-
 .../reader/StandaloneNoopCommunicationSpi.java  |    83 +
 .../wal/reader/StandaloneNoopDiscoverySpi.java  |   127 +
 .../reader/StandaloneWalRecordsIterator.java    |   171 +-
 .../persistence/wal/record/HeaderRecord.java    |    13 +-
 .../persistence/wal/record/RecordTypes.java     |    69 +
 .../wal/serializer/RecordDataSerializer.java    |    59 +
 .../wal/serializer/RecordDataV1Serializer.java  |  1571 +++
 .../wal/serializer/RecordDataV2Serializer.java  |   122 +
 .../wal/serializer/RecordSerializer.java        |    63 +
 .../wal/serializer/RecordSerializerFactory.java |    71 +
 .../serializer/RecordSerializerFactoryImpl.java |   133 +
 .../wal/serializer/RecordV1Serializer.java      |  1670 +--
 .../wal/serializer/RecordV2Serializer.java      |   248 +
 .../wal/serializer/TxRecordSerializer.java      |   227 +
 .../persistence/wal/serializer/io/RecordIO.java |    60 +
 .../processors/cache/query/CacheQueryEntry.java |    58 +
 .../query/GridCacheDistributedQueryManager.java |    16 +-
 .../cache/query/GridCacheQueryAdapter.java      |    59 +-
 .../cache/query/GridCacheQueryManager.java      |   635 +-
 .../query/GridCacheQuerySqlMetadataJobV2.java   |   154 +
 .../query/GridCacheQuerySqlMetadataV2.java      |   101 +
 .../cache/query/GridCacheSqlMetadata.java       |     8 +
 .../cache/query/GridCacheSqlQuery.java          |    24 +
 .../cache/query/IgniteQueryErrorCode.java       |    50 +-
 .../cache/query/QueryEntityIndexDescriptor.java |     2 +
 .../cache/query/QueryEntityTypeDescriptor.java  |    36 +-
 .../cache/query/SqlFieldsQueryEx.java           |   158 +
 .../continuous/CacheContinuousQueryHandler.java |     9 +-
 .../cache/ratemetrics/HitRateMetrics.java       |     2 +-
 .../cache/store/CacheStoreManager.java          |    12 +-
 .../store/GridCacheStoreManagerAdapter.java     |   101 +-
 .../cache/store/GridCacheWriteBehindStore.java  |    10 +-
 .../cache/transactions/IgniteInternalTx.java    |     2 +-
 .../cache/transactions/IgniteTxAdapter.java     |    60 +-
 .../cache/transactions/IgniteTxHandler.java     |   241 +-
 .../IgniteTxImplicitSingleStateImpl.java        |     5 +-
 .../transactions/IgniteTxLocalAdapter.java      |    14 +-
 .../cache/transactions/IgniteTxLocalEx.java     |     7 +-
 .../cache/transactions/IgniteTxManager.java     |   100 +-
 .../cache/tree/AbstractDataInnerIO.java         |   109 +
 .../cache/tree/AbstractDataLeafIO.java          |   108 +
 .../cache/tree/AbstractPendingEntryInnerIO.java |    99 +
 .../cache/tree/AbstractPendingEntryLeafIO.java  |    98 +
 .../cache/tree/CacheDataRowStore.java           |    80 +
 .../processors/cache/tree/CacheDataTree.java    |   258 +
 .../cache/tree/CacheIdAwareDataInnerIO.java     |    48 +
 .../cache/tree/CacheIdAwareDataLeafIO.java      |    48 +
 .../tree/CacheIdAwarePendingEntryInnerIO.java   |    48 +
 .../tree/CacheIdAwarePendingEntryLeafIO.java    |    48 +
 .../processors/cache/tree/DataInnerIO.java      |    48 +
 .../processors/cache/tree/DataLeafIO.java       |    48 +
 .../internal/processors/cache/tree/DataRow.java |   105 +
 .../cache/tree/PendingEntriesTree.java          |   120 +
 .../cache/tree/PendingEntryInnerIO.java         |    48 +
 .../cache/tree/PendingEntryLeafIO.java          |    48 +
 .../processors/cache/tree/PendingRow.java       |    83 +
 .../processors/cache/tree/PendingRowIO.java     |    44 +
 .../processors/cache/tree/RowLinkIO.java        |    44 +
 .../processors/cache/tree/SearchRow.java        |    76 +
 .../IgniteCacheObjectProcessorImpl.java         |   164 -
 .../UserCacheObjectByteArrayImpl.java           |    59 +
 .../cacheobject/UserCacheObjectImpl.java        |    82 +
 .../cacheobject/UserKeyCacheObjectImpl.java     |   101 +
 .../closure/GridClosureProcessor.java           |    36 +-
 .../cluster/ChangeGlobalStateFinishMessage.java |     9 +
 .../cluster/ChangeGlobalStateMessage.java       |    11 +-
 .../processors/cluster/ClusterProcessor.java    |    39 +-
 .../cluster/GridClusterStateProcessor.java      |    69 +-
 .../processors/cluster/GridUpdateNotifier.java  |   224 +-
 .../cluster/HttpIgniteUpdatesChecker.java       |    29 +-
 .../continuous/AbstractContinuousMessage.java   |    10 +
 .../continuous/GridContinuousProcessor.java     |   135 +-
 .../StartRoutineAckDiscoveryMessage.java        |     2 +-
 .../StartRoutineDiscoveryMessage.java           |     2 +-
 .../StopRoutineAckDiscoveryMessage.java         |     2 +-
 .../continuous/StopRoutineDiscoveryMessage.java |     2 +-
 .../datastreamer/DataStreamProcessor.java       |    57 +-
 .../datastreamer/DataStreamerImpl.java          |   171 +-
 .../AtomicDataStructureProxy.java               |   195 +
 .../datastructures/DataStructuresProcessor.java |    38 +-
 .../datastructures/GridCacheAtomicLongImpl.java |   120 +-
 .../GridCacheAtomicReferenceImpl.java           |   114 +-
 .../GridCacheAtomicSequenceImpl.java            |   113 +-
 .../GridCacheAtomicStampedImpl.java             |   115 +-
 .../GridCacheCountDownLatchImpl.java            |    73 +-
 .../datastructures/GridCacheLockImpl.java       |    91 +-
 .../datastructures/GridCacheQueueAdapter.java   |     5 +
 .../datastructures/GridCacheRemovable.java      |     6 +
 .../datastructures/GridCacheSemaphoreImpl.java  |    85 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java |    15 +-
 .../processors/hadoop/HadoopJobInfo.java        |     7 +
 .../processors/igfs/IgfsDataManager.java        |     4 +-
 .../processors/igfs/IgfsHelperImpl.java         |     8 +-
 .../internal/processors/igfs/IgfsImpl.java      |     4 +-
 .../processors/job/GridJobProcessor.java        |     8 +
 .../internal/processors/job/GridJobWorker.java  |    19 -
 .../processors/jobmetrics/GridJobMetrics.java   |    21 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |     9 +-
 .../marshaller/MappingAcceptedMessage.java      |     9 +
 .../marshaller/MappingProposedMessage.java      |     9 +
 .../odbc/ClientConnectorConfigurationEx.java    |    27 +
 .../odbc/ClientListenerBufferedParser.java      |    81 +
 .../odbc/ClientListenerConnectionContext.java   |    62 +
 .../odbc/ClientListenerMessageParser.java       |    39 +
 .../odbc/ClientListenerNioListener.java         |   245 +
 .../odbc/ClientListenerNioServerBuffer.java     |   114 +
 .../odbc/ClientListenerProcessor.java           |   320 +
 .../odbc/ClientListenerProtocolVersion.java     |   116 +
 .../processors/odbc/ClientListenerRequest.java  |    31 +
 .../odbc/ClientListenerRequestHandler.java      |    49 +
 .../odbc/ClientListenerRequestNoId.java         |    28 +
 .../processors/odbc/ClientListenerResponse.java |    76 +
 .../odbc/SqlListenerBufferedParser.java         |    81 -
 .../odbc/SqlListenerConnectionContext.java      |    56 -
 .../odbc/SqlListenerMessageParser.java          |    39 -
 .../processors/odbc/SqlListenerNioListener.java |   269 -
 .../odbc/SqlListenerNioServerBuffer.java        |   114 -
 .../processors/odbc/SqlListenerProcessor.java   |   278 -
 .../odbc/SqlListenerProtocolVersion.java        |   116 -
 .../processors/odbc/SqlListenerRequest.java     |    43 -
 .../odbc/SqlListenerRequestHandler.java         |    39 -
 .../processors/odbc/SqlListenerResponse.java    |    76 -
 .../processors/odbc/SqlListenerUtils.java       |     6 +
 .../internal/processors/odbc/SqlStateCode.java  |    69 +
 .../odbc/jdbc/JdbcBatchExecuteRequest.java      |    20 +-
 .../odbc/jdbc/JdbcBatchExecuteResult.java       |     6 +
 .../processors/odbc/jdbc/JdbcColumnMeta.java    |    85 +-
 .../processors/odbc/jdbc/JdbcColumnMetaV2.java  |    74 +
 .../odbc/jdbc/JdbcConnectionContext.java        |   132 +
 .../processors/odbc/jdbc/JdbcIndexMeta.java     |   192 +
 .../processors/odbc/jdbc/JdbcMessageParser.java |    12 +-
 .../odbc/jdbc/JdbcMetaColumnsRequest.java       |   102 +
 .../odbc/jdbc/JdbcMetaColumnsResult.java        |   125 +
 .../odbc/jdbc/JdbcMetaColumnsResultV2.java      |    50 +
 .../odbc/jdbc/JdbcMetaIndexesRequest.java       |    88 +
 .../odbc/jdbc/JdbcMetaIndexesResult.java        |    98 +
 .../odbc/jdbc/JdbcMetaParamsRequest.java        |    87 +
 .../odbc/jdbc/JdbcMetaParamsResult.java         |    97 +
 .../odbc/jdbc/JdbcMetaPrimaryKeysRequest.java   |    88 +
 .../odbc/jdbc/JdbcMetaPrimaryKeysResult.java    |    99 +
 .../odbc/jdbc/JdbcMetaSchemasRequest.java       |    73 +
 .../odbc/jdbc/JdbcMetaSchemasResult.java        |    73 +
 .../odbc/jdbc/JdbcMetaTablesRequest.java        |    87 +
 .../odbc/jdbc/JdbcMetaTablesResult.java         |    97 +
 .../processors/odbc/jdbc/JdbcParameterMeta.java |   163 +
 .../odbc/jdbc/JdbcPrimaryKeyMeta.java           |   131 +
 .../odbc/jdbc/JdbcQueryCloseRequest.java        |     4 +-
 ...dbcQueryExecuteMultipleStatementsResult.java |   134 +
 .../odbc/jdbc/JdbcQueryExecuteRequest.java      |    37 +-
 .../odbc/jdbc/JdbcQueryExecuteResult.java       |    12 +-
 .../odbc/jdbc/JdbcQueryFetchRequest.java        |     4 +-
 .../odbc/jdbc/JdbcQueryFetchResult.java         |    12 +-
 .../odbc/jdbc/JdbcQueryMetadataRequest.java     |    18 +-
 .../odbc/jdbc/JdbcQueryMetadataResult.java      |    14 +-
 .../processors/odbc/jdbc/JdbcRequest.java       |    71 +-
 .../odbc/jdbc/JdbcRequestHandler.java           |   519 +-
 .../processors/odbc/jdbc/JdbcResponse.java      |     4 +-
 .../processors/odbc/jdbc/JdbcResult.java        |    74 +-
 .../processors/odbc/jdbc/JdbcResultInfo.java    |    95 +
 .../processors/odbc/jdbc/JdbcStatementType.java |    45 +
 .../processors/odbc/jdbc/JdbcTableMeta.java     |    82 +
 .../processors/odbc/jdbc/JdbcUtils.java         |    37 +-
 .../odbc/odbc/OdbcConnectionContext.java        |   134 +
 .../processors/odbc/odbc/OdbcMessageParser.java |   109 +-
 .../odbc/odbc/OdbcQueryExecuteBatchRequest.java |    16 +-
 .../odbc/odbc/OdbcQueryExecuteBatchResult.java  |    34 +-
 .../odbc/odbc/OdbcQueryExecuteRequest.java      |    16 +-
 .../odbc/odbc/OdbcQueryExecuteResult.java       |    25 +-
 .../odbc/odbc/OdbcQueryMoreResultsRequest.java  |    61 +
 .../odbc/odbc/OdbcQueryMoreResultsResult.java   |    66 +
 .../processors/odbc/odbc/OdbcQueryResults.java  |   106 +
 .../processors/odbc/odbc/OdbcRequest.java       |     7 +-
 .../odbc/odbc/OdbcRequestHandler.java           |   342 +-
 .../processors/odbc/odbc/OdbcResponse.java      |     4 +-
 .../processors/odbc/odbc/OdbcResultSet.java     |   101 +
 .../processors/odbc/odbc/OdbcUtils.java         |    73 +
 .../platform/PlatformAbstractBootstrap.java     |    18 +-
 .../processors/platform/PlatformBootstrap.java  |     7 +-
 .../platform/PlatformContextImpl.java           |   125 +-
 .../processors/platform/PlatformIgnition.java   |     4 +-
 .../platform/cache/PlatformCache.java           |     4 +-
 .../query/PlatformAbstractQueryCursor.java      |     9 +-
 .../callback/PlatformCallbackGateway.java       |    15 +
 .../platform/callback/PlatformCallbackOp.java   |     3 +
 .../platform/client/ClientBooleanResponse.java  |    46 +
 .../client/ClientCloseableResource.java         |    28 +
 .../client/ClientConnectionContext.java         |   140 +
 .../platform/client/ClientIntResponse.java      |    46 +
 .../platform/client/ClientLongResponse.java     |    46 +
 .../platform/client/ClientMessageParser.java    |   367 +
 .../platform/client/ClientObjectResponse.java   |    46 +
 .../platform/client/ClientRawRequest.java       |    45 +
 .../platform/client/ClientRequest.java          |    61 +
 .../platform/client/ClientRequestHandler.java   |    63 +
 .../client/ClientResourceCloseRequest.java      |    46 +
 .../platform/client/ClientResourceRegistry.java |    98 +
 .../platform/client/ClientResponse.java         |    86 +
 .../platform/client/ClientStatus.java           |    48 +
 .../platform/client/ClientStringResponse.java   |    47 +
 .../platform/client/IgniteClientException.java  |    65 +
 .../binary/ClientBinaryTypeGetRequest.java      |    50 +
 .../binary/ClientBinaryTypeGetResponse.java     |    55 +
 .../binary/ClientBinaryTypeNameGetRequest.java  |    61 +
 .../binary/ClientBinaryTypeNamePutRequest.java  |    65 +
 .../binary/ClientBinaryTypePutRequest.java      |    56 +
 .../cache/ClientCacheClearKeyRequest.java       |    44 +
 .../cache/ClientCacheClearKeysRequest.java      |    44 +
 .../client/cache/ClientCacheClearRequest.java   |    44 +
 .../ClientCacheConfigurationSerializer.java     |   180 +
 .../cache/ClientCacheContainsKeyRequest.java    |    45 +
 .../cache/ClientCacheContainsKeysRequest.java   |    45 +
 ...ientCacheCreateWithConfigurationRequest.java |    58 +
 .../cache/ClientCacheCreateWithNameRequest.java |    56 +
 .../client/cache/ClientCacheDestroyRequest.java |    51 +
 .../cache/ClientCacheEntryQueryCursor.java      |    46 +
 .../cache/ClientCacheFieldsQueryCursor.java     |    53 +
 .../client/cache/ClientCacheGetAllRequest.java  |    46 +
 .../client/cache/ClientCacheGetAllResponse.java |    57 +
 .../ClientCacheGetAndPutIfAbsentRequest.java    |    45 +
 .../cache/ClientCacheGetAndPutRequest.java      |    45 +
 .../cache/ClientCacheGetAndRemoveRequest.java   |    45 +
 .../cache/ClientCacheGetAndReplaceRequest.java  |    45 +
 .../ClientCacheGetConfigurationRequest.java     |    47 +
 .../ClientCacheGetConfigurationResponse.java    |    51 +
 .../cache/ClientCacheGetNamesRequest.java       |    46 +
 .../cache/ClientCacheGetNamesResponse.java      |    56 +
 ...acheGetOrCreateWithConfigurationRequest.java |    58 +
 .../ClientCacheGetOrCreateWithNameRequest.java  |    49 +
 .../client/cache/ClientCacheGetRequest.java     |    45 +
 .../client/cache/ClientCacheGetSizeRequest.java |    57 +
 .../client/cache/ClientCacheKeyRequest.java     |    48 +
 .../cache/ClientCacheKeyValueRequest.java       |    48 +
 .../client/cache/ClientCacheKeysRequest.java    |    68 +
 .../client/cache/ClientCachePutAllRequest.java  |    57 +
 .../cache/ClientCachePutIfAbsentRequest.java    |    45 +
 .../client/cache/ClientCachePutRequest.java     |    44 +
 .../client/cache/ClientCacheQueryCursor.java    |   141 +
 .../cache/ClientCacheQueryNextPageRequest.java  |    49 +
 .../cache/ClientCacheQueryNextPageResponse.java |    50 +
 .../client/cache/ClientCacheQueryResponse.java  |    52 +
 .../cache/ClientCacheRemoveAllRequest.java      |    44 +
 .../cache/ClientCacheRemoveIfEqualsRequest.java |    45 +
 .../cache/ClientCacheRemoveKeyRequest.java      |    45 +
 .../cache/ClientCacheRemoveKeysRequest.java     |    44 +
 .../ClientCacheReplaceIfEqualsRequest.java      |    50 +
 .../client/cache/ClientCacheReplaceRequest.java |    45 +
 .../client/cache/ClientCacheRequest.java        |   122 +
 .../cache/ClientCacheScanQueryRequest.java      |   142 +
 .../cache/ClientCacheSqlFieldsQueryRequest.java |   126 +
 .../ClientCacheSqlFieldsQueryResponse.java      |    75 +
 .../cache/ClientCacheSqlQueryRequest.java       |    79 +
 .../platform/cluster/PlatformClusterGroup.java  |    90 +
 .../cluster/PlatformClusterNodeFilterImpl.java  |     7 +
 .../datastreamer/PlatformDataStreamer.java      |    17 +-
 .../dotnet/PlatformDotNetBootstrap.java         |    26 +-
 .../PlatformDotNetConfigurationClosure.java     |    22 +-
 .../dotnet/PlatformDotNetServiceImpl.java       |     7 +
 .../platform/events/PlatformEvents.java         |    17 +-
 .../events/PlatformLocalEventListener.java      |    88 +
 .../services/PlatformAbstractService.java       |     8 +
 .../platform/services/PlatformServices.java     |   178 +-
 .../utils/PlatformConfigurationUtils.java       |   358 +-
 .../platform/utils/PlatformUtils.java           |   206 +-
 .../processors/query/GridQueryIndexing.java     |    74 +-
 .../processors/query/GridQueryProcessor.java    |   461 +-
 .../processors/query/GridQueryProperty.java     |     7 +
 .../query/GridQueryTypeDescriptor.java          |    17 +
 .../processors/query/IgniteSQLException.java    |    84 +-
 .../processors/query/QueryEntityEx.java         |    98 +
 .../internal/processors/query/QueryField.java   |    76 +
 .../internal/processors/query/QuerySchema.java  |    74 +-
 .../query/QueryTypeDescriptorImpl.java          |    88 +-
 .../internal/processors/query/QueryUtils.java   |   138 +-
 .../messages/GridQueryNextPageResponse.java     |    36 +-
 .../query/property/QueryBinaryProperty.java     |    13 +-
 .../query/property/QueryClassProperty.java      |    16 +-
 .../query/schema/SchemaExchangeWorkerTask.java  |     5 +
 .../query/schema/SchemaIndexCacheFilter.java    |    33 +
 .../schema/SchemaIndexCacheVisitorClosure.java  |    14 +-
 .../schema/SchemaIndexCacheVisitorImpl.java     |   221 +-
 .../SchemaNodeLeaveExchangeWorkerTask.java      |     5 +
 .../query/schema/SchemaOperationWorker.java     |     2 +-
 .../message/SchemaAbstractDiscoveryMessage.java |    10 +
 .../message/SchemaProposeDiscoveryMessage.java  |     3 +-
 .../SchemaAbstractAlterTableOperation.java      |    39 +
 .../SchemaAlterTableAddColumnOperation.java     |    96 +
 .../operation/SchemaIndexCreateOperation.java   |    16 +-
 .../processors/rest/GridRestCommand.java        |     2 +-
 .../processors/rest/GridRestProcessor.java      |     5 +-
 .../handlers/cache/GridCacheCommandHandler.java |    12 +-
 .../GridServiceDeploymentCompoundFuture.java    |    94 +
 .../service/GridServiceProcessor.java           |   582 +-
 .../service/PreparedConfigurations.java         |    47 +
 .../session/GridTaskSessionProcessor.java       |     6 +
 .../processors/task/GridTaskProcessor.java      |    15 +-
 .../task/GridTaskThreadContextKey.java          |     3 +
 .../processors/task/GridTaskWorker.java         |    32 +-
 .../timeout/GridTimeoutProcessor.java           |    23 +-
 .../apache/ignite/internal/sql/SqlKeyword.java  |   243 +
 .../apache/ignite/internal/sql/SqlLexer.java    |   219 +
 .../internal/sql/SqlLexerLookAheadToken.java    |    75 +
 .../ignite/internal/sql/SqlLexerToken.java      |    48 +
 .../ignite/internal/sql/SqlLexerTokenType.java  |   112 +
 .../ignite/internal/sql/SqlParseException.java  |    99 +
 .../apache/ignite/internal/sql/SqlParser.java   |   181 +
 .../ignite/internal/sql/SqlParserUtils.java     |   369 +
 .../ignite/internal/sql/command/SqlCommand.java |    43 +
 .../sql/command/SqlCreateIndexCommand.java      |   304 +
 .../sql/command/SqlDropIndexCommand.java        |    80 +
 .../internal/sql/command/SqlIndexColumn.java    |    61 +
 .../internal/sql/command/SqlQualifiedName.java  |    70 +
 .../internal/util/GridSpinReadWriteLock.java    |     2 +-
 .../apache/ignite/internal/util/GridUnsafe.java |    14 +
 .../apache/ignite/internal/util/IgniteTree.java |    12 +
 .../ignite/internal/util/IgniteUtils.java       |   211 +-
 .../util/Jsr310Java8DateTimeApiUtils.java       |    80 +
 .../apache/ignite/internal/util/MpscQueue.java  |   240 +
 .../internal/util/OffheapReadWriteLock.java     |     8 +-
 .../ignite/internal/util/StripedExecutor.java   |   304 +-
 .../util/future/GridCompoundFuture.java         |    55 +-
 .../internal/util/future/GridFutureAdapter.java |    16 +
 .../ignite/internal/util/lang/GridFunc.java     |     3 +-
 .../internal/util/lang/GridTreePrinter.java     |    19 +-
 .../nio/GridAbstractCommunicationClient.java    |     2 +-
 .../internal/util/nio/GridNioKeyAttachment.java |    33 +
 .../util/nio/GridNioRecoveryDescriptor.java     |     3 +-
 .../ignite/internal/util/nio/GridNioServer.java |   256 +-
 .../util/nio/GridSelectorNioSessionImpl.java    |    28 +-
 .../internal/util/nio/ssl/GridNioSslFilter.java |    12 +-
 .../offheap/unsafe/GridOffHeapSmartPointer.java |    38 -
 .../unsafe/GridOffHeapSmartPointerFactory.java  |    29 -
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |  4525 -------
 .../unsafe/GridUnsafeCompoundMemory.java        |    35 -
 .../util/offheap/unsafe/GridUnsafeGuard.java    |   376 -
 .../apache/ignite/internal/util/typedef/X.java  |     4 +-
 .../internal/visor/VisorDataTransferObject.java |     6 +
 .../ignite/internal/visor/cache/VisorCache.java |    94 +-
 .../cache/VisorCacheAggregatedMetrics.java      |    24 +-
 .../visor/cache/VisorCacheConfiguration.java    |    17 +-
 .../cache/VisorCacheEvictionConfiguration.java  |     4 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |     5 +-
 .../visor/cache/VisorCacheModifyTask.java       |   113 +
 .../visor/cache/VisorCacheModifyTaskArg.java    |   114 +
 .../visor/cache/VisorCacheModifyTaskResult.java |   101 +
 .../cache/VisorCacheNearConfiguration.java      |     7 +-
 .../visor/cache/VisorCacheStopTask.java         |    22 +-
 .../visor/cache/VisorCacheStopTaskArg.java      |    27 +
 .../visor/cache/VisorMemoryMetrics.java         |     6 +-
 .../visor/cache/VisorModifyCacheMode.java       |    47 +
 .../visor/file/VisorLatestTextFilesTask.java    |    13 +-
 .../internal/visor/log/VisorLogSearchTask.java  |    25 +-
 .../node/VisorClientConnectorConfiguration.java |   166 +
 .../node/VisorDataRegionConfiguration.java      |   238 +
 .../node/VisorDataStorageConfiguration.java     |   452 +
 .../node/VisorExecutorServiceConfiguration.java |    18 +-
 .../visor/node/VisorGridConfiguration.java      |    57 +-
 .../visor/node/VisorMemoryConfiguration.java    |    26 +-
 .../node/VisorMemoryPolicyConfiguration.java    |    10 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    13 +-
 .../node/VisorNodeDataCollectorJobResult.java   |     4 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |     2 +-
 .../node/VisorNodeDataCollectorTaskArg.java     |    47 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |    35 +-
 .../visor/node/VisorPersistenceMetrics.java     |     8 +-
 .../node/VisorPersistentStoreConfiguration.java |    21 +-
 .../node/VisorSqlConnectorConfiguration.java    |     3 +
 .../internal/visor/query/VisorQueryTask.java    |    21 +-
 .../internal/visor/query/VisorQueryTaskArg.java |    41 +-
 .../internal/visor/query/VisorQueryUtils.java   |    25 +-
 .../internal/visor/util/VisorTaskUtils.java     |   196 +-
 .../org/apache/ignite/logger/NullLogger.java    |     6 +
 .../apache/ignite/logger/java/JavaLogger.java   |    17 +
 .../ignite/mxbean/CacheGroupMetricsMXBean.java  |   142 +
 .../ignite/mxbean/CacheMetricsMXBean.java       |    10 +-
 .../mxbean/ClusterLocalNodeMetricsMXBean.java   |   253 -
 .../ignite/mxbean/ClusterMetricsMXBean.java     |   317 +
 .../ignite/mxbean/DataRegionMetricsMXBean.java  |   143 +
 .../ignite/mxbean/DataStorageMetricsMXBean.java |   121 +
 .../org/apache/ignite/mxbean/IgniteMXBean.java  |    21 +
 .../ignite/mxbean/MemoryMetricsMXBean.java      |     2 +
 .../ignite/mxbean/PersistenceMetricsMXBean.java |     2 +
 .../services/ServiceDeploymentException.java    |    77 +
 .../tcp/TcpCommunicationMetricsListener.java    |   224 +
 .../communication/tcp/TcpCommunicationSpi.java  |  1008 +-
 .../tcp/TcpCommunicationSpiMBean.java           |    34 +
 .../tcp/messages/HandshakeMessage.java          |   157 +
 .../tcp/messages/HandshakeMessage2.java         |    95 +
 .../tcp/messages/NodeIdMessage.java             |   128 +
 .../messages/RecoveryLastReceivedMessage.java   |   114 +
 .../tcp/messages/package-info.java              |    22 +
 .../spi/discovery/IgniteDiscoveryThread.java    |    23 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    66 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   439 +-
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |     4 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    54 +-
 .../tcp/internal/TcpDiscoveryNode.java          |    35 +
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |    34 +-
 .../spi/indexing/IndexingQueryCacheFilter.java  |    82 +
 .../spi/indexing/IndexingQueryFilter.java       |    12 +-
 .../spi/indexing/IndexingQueryFilterImpl.java   |    79 +
 .../org/apache/ignite/thread/IgniteThread.java  |    11 +-
 .../resources/META-INF/classnames.properties    |   156 +-
 .../core/src/main/resources/ignite.properties   |     2 +-
 .../core/src/test/config/examples.properties    |     2 +-
 .../core/src/test/config/spark/spark-config.xml |     8 +-
 modules/core/src/test/config/tests.properties   |     9 +
 .../org.apache.ignite.plugin.PluginProvider     |     1 -
 ...atformCachePluginConfigurationClosureFactory |     1 -
 ...rm.PlatformPluginConfigurationClosureFactory |     1 -
 .../ignite/cache/LargeEntryUpdateTest.java      |     6 +-
 ...istenerRWThroughDisabledAtomicCacheTest.java |    33 +
 ...RWThroughDisabledTransactionalCacheTest.java |   138 +
 .../store/CacheStoreReadFromBackupTest.java     |   238 +
 ...ionListenerReadWriteThroughDisabledTest.java |   291 +
 ...reSessionListenerWriteBehindEnabledTest.java |   405 +
 ...cheTransactionalStoreReadFromBackupTest.java |    32 +
 .../cache/store/GridStoreLoadCacheTest.java     |   120 +
 .../internal/ClusterNodeMetricsSelfTest.java    |   188 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    30 -
 .../internal/GridJobStealingSelfTest.java       |     7 +-
 .../GridMultithreadedJobStealingSelfTest.java   |   176 +-
 ...entConnectAfterCommunicationFailureTest.java |   156 +
 .../IgniteClientReconnectBinaryContexTest.java  |   115 +
 .../IgniteClientReconnectCacheTest.java         |    13 +-
 .../IgniteClientReconnectCollectionsTest.java   |   131 +-
 .../IgniteSlowClientDetectionSelfTest.java      |     6 +-
 .../internal/TestDelayingCommunicationSpi.java  |    63 +
 .../internal/TestRecordingCommunicationSpi.java |    12 +
 .../binary/BinaryMarshallerSelfTest.java        |   154 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |    48 +
 .../IgniteCommunicationBalanceTest.java         |    13 +
 .../IgniteCommunicationSslBalanceTest.java      |    28 +
 .../OptimizedObjectStreamSelfTest.java          |   108 +-
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java  |    18 +-
 .../AtomicCacheAffinityConfigurationTest.java   |     7 +-
 .../cache/CacheClientStoreSelfTest.java         |     4 +-
 .../processors/cache/CacheComparatorTest.java   |    48 +
 .../cache/CacheConfigurationLeakTest.java       |    15 +-
 .../cache/CacheDataRegionConfigurationTest.java |   172 +
 ...CacheExchangeMessageDuplicatedStateTest.java |    36 +-
 .../cache/CacheGroupMetricsMBeanTest.java       |   266 +
 .../cache/CacheGroupsMetricsRebalanceTest.java  |   167 +-
 .../CacheMemoryPolicyConfigurationTest.java     |   172 -
 .../CacheMetricsForClusterGroupSelfTest.java    |   119 +-
 .../cache/CacheRebalancingSelfTest.java         |    91 +-
 .../cache/CacheStopAndDestroySelfTest.java      |    10 +-
 .../processors/cache/CacheTxFastFinishTest.java |     9 +-
 .../cache/CacheValidatorMetricsTest.java        |   121 +
 .../cache/ClusterStateAbstractTest.java         |   129 +-
 .../cache/ConcurrentCacheStartTest.java         |    67 +
 .../cache/GridCacheAbstractFullApiSelfTest.java |    45 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    |    17 +-
 ...idCacheConfigurationConsistencySelfTest.java |    52 +
 ...ridCacheQuerySqlFieldInlineSizeSelfTest.java |   160 +
 .../processors/cache/GridCacheTestEntryEx.java  |    14 +-
 ...StorageConfigurationConsistencySelfTest.java |    79 +
 .../cache/IgniteCacheDynamicStopSelfTest.java   |     2 +-
 .../IgniteCacheTopologySafeGetSelfTest.java     |   222 -
 ...IgniteClientCacheInitializationFailTest.java |    43 +-
 .../IgniteClientCacheStartFailoverTest.java     |     4 +-
 .../IgniteClusterActivateDeactivateTest.java    |    36 +-
 ...erActivateDeactivateTestWithPersistence.java |    30 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java  |    26 +-
 .../IgniteMarshallerCacheFSRestoreTest.java     |    71 +-
 .../cache/IgniteOutOfMemoryPropagationTest.java |   251 +
 ...niteTopologyValidatorGridSplitCacheTest.java |   547 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |    14 +
 .../cache/MemoryPolicyConfigValidationTest.java |    24 +-
 ...AffinityCoordinatorDynamicStartStopTest.java |    17 +-
 ...heapCacheMetricsForClusterGroupSelfTest.java |    19 +-
 .../binary/BinaryMetadataUpdatesFlowTest.java   |    48 +
 ...eAbstractDataStructuresFailoverSelfTest.java |     7 +-
 .../GridCacheQueueClientDisconnectTest.java     |   117 +
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |     4 -
 ...PartitionedQueueCreateMultiNodeSelfTest.java |     2 -
 ...eplicatedDataStructuresFailoverSelfTest.java |    14 +
 .../distributed/Cache64kPartitionsTest.java     |    94 +
 .../distributed/CacheExchangeMergeTest.java     |  1528 +++
 .../CacheLateAffinityAssignmentTest.java        |   609 +-
 ...CacheLoadingConcurrentGridStartSelfTest.java |    11 +
 .../CacheLockReleaseNodeLeaveTest.java          |    13 +-
 .../distributed/CachePartitionStateTest.java    |    18 +-
 .../cache/distributed/CacheStartOnJoinTest.java |     9 +-
 ...ncurrentGridStartSelfTestAllowOverwrite.java |    33 +
 ...titionEvictionDuringReadThroughSelfTest.java |     2 +
 .../distributed/IgniteCache150ClientsTest.java  |     4 +-
 ...niteCacheClientNodeChangingTopologyTest.java |     5 +-
 ...teCacheClientNodePartitionsExchangeTest.java |    52 +-
 .../IgniteCacheMessageWriteTimeoutTest.java     |     4 +-
 .../IgniteCacheSystemTransactionsSelfTest.java  |    18 +
 .../IgniteCacheThreadLocalTxTest.java           |   223 +
 .../IgniteOptimisticTxSuspendResumeTest.java    |    17 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |   111 +-
 .../IgniteCacheTopologySplitAbstractTest.java   |   266 +
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    36 +-
 ...ionedMultiNodeLongTxTimeout2FullApiTest.java |    34 +
 .../near/GridCacheNearClientHitTest.java        |   154 +
 .../GridCacheNearEvictionEventSelfTest.java     |     5 -
 .../EvictionPolicyFactoryAbstractTest.java      |  1073 ++
 .../fifo/FifoEvictionPolicyFactorySelfTest.java |   261 +
 .../lru/LruEvictionPolicyFactorySelfTest.java   |   352 +
 .../paged/PageEvictionAbstractTest.java         |    25 +-
 .../paged/PageEvictionDataStreamerTest.java     |    65 +
 .../PageEvictionMultinodeMixedRegionsTest.java  |    59 +
 .../paged/PageEvictionMultinodeTest.java        |     6 +-
 .../SortedEvictionPolicyFactorySelfTest.java    |   264 +
 .../expiry/IgniteCacheLargeValueExpireTest.java |     6 +-
 .../local/GridCacheLocalFullApiSelfTest.java    |    76 +-
 .../cache/persistence/DummyPageIO.java          |    41 +
 .../IgniteDataStorageMetricsSelfTest.java       |   237 +
 ...tePdsBinaryMetadataOnClusterRestartTest.java |    10 +-
 .../IgnitePdsBinarySortObjectFieldsTest.java    |   150 +
 ...gnitePdsCacheAssignmentNodeRestartsTest.java |   257 +
 .../IgnitePdsCacheRebalancingAbstractTest.java  |   167 +-
 .../IgnitePdsClientNearCachePutGetTest.java     |    12 +-
 .../IgnitePdsContinuousRestartTest.java         |    70 +-
 ...ousRestartTestWithSharedGroupAndIndexes.java |    67 +
 .../persistence/IgnitePdsDynamicCacheTest.java  |    75 +-
 .../IgnitePdsExchangeDuringCheckpointTest.java  |   136 +
 ...MarshallerMappingRestoreOnNodeStartTest.java |   116 +
 .../IgnitePdsMultiNodePutGetRestartTest.java    |    30 +-
 .../persistence/IgnitePdsPageSizesTest.java     |    35 +-
 ...gnitePdsRecoveryAfterFileCorruptionTest.java |   126 +-
 .../IgnitePdsRemoveDuringRebalancingTest.java   |    45 +-
 ...gnitePdsSingleNodePutGetPersistenceTest.java |    12 +-
 .../IgnitePersistenceMetricsSelfTest.java       |   225 -
 ...nitePersistenceSequentialCheckpointTest.java |    44 +
 .../IgnitePersistentStoreCacheGroupsTest.java   |    49 +-
 ...IgnitePersistentStoreDataStructuresTest.java |    23 +-
 .../MemoryPolicyInitializationTest.java         |    24 +-
 .../db/IgnitePdsCacheRestoreTest.java           |    45 +-
 .../db/IgnitePdsMultiNodePutGetRestartTest.java |    29 +-
 ...PdsPageEvictionDuringPartitionClearTest.java |    35 +-
 .../db/IgnitePdsPageEvictionTest.java           |    36 +-
 ...tePdsRebalancingOnNotStableTopologyTest.java |    34 +-
 .../db/IgnitePdsTransactionsHangTest.java       |    31 +-
 .../db/IgnitePdsWholeClusterRestartTest.java    |    32 +-
 ...faultPageSizeBackwardsCompatibilityTest.java |   146 +
 .../db/file/IgnitePdsCacheIntegrationTest.java  |    35 +-
 ...ckpointSimulationWithRealCpDisabledTest.java |    86 +-
 .../db/file/IgnitePdsEvictionTest.java          |    62 +-
 .../file/IgnitePdsNoActualWalHistoryTest.java   |    28 +-
 .../file/IgnitePdsThreadInterruptionTest.java   |   186 +
 .../IgniteUidAsConsistentIdMigrationTest.java   |   708 ++
 .../persistence/db/wal/IgnitePdsWalTlbTest.java |    42 +-
 .../wal/IgniteWalFlushBackgroundSelfTest.java   |    35 +
 .../db/wal/IgniteWalFlushDefaultSelfTest.java   |    35 +
 .../db/wal/IgniteWalFlushFailoverTest.java      |    68 +-
 .../db/wal/IgniteWalFlushLogOnlySelfTest.java   |    35 +
 ...lFlushMultiNodeFailoverAbstractSelfTest.java |   246 +
 .../wal/IgniteWalHistoryReservationsTest.java   |    83 +-
 .../db/wal/IgniteWalRecoveryPPCTest.java        |   321 +
 .../IgniteWalRecoverySeveralRestartsTest.java   |    35 +-
 .../db/wal/IgniteWalRecoveryTest.java           |   310 +-
 .../IgniteWalRecoveryWithCompactionTest.java    |    33 +
 .../db/wal/IgniteWalSerializerVersionTest.java  |   318 +
 .../persistence/db/wal/WalCompactionTest.java   |   312 +
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java |    24 +-
 .../db/wal/crc/IgniteDataIntegrityTests.java    |    97 +-
 .../db/wal/reader/IgniteWalReaderTest.java      |  1167 +-
 .../db/wal/reader/IndexedObject.java            |    79 +
 .../db/wal/reader/MockWalIteratorFactory.java   |    50 +-
 .../pagemem/BPlusTreePageMemoryImplTest.java    |     8 +-
 .../BPlusTreeReuseListPageMemoryImplTest.java   |     7 +-
 .../MetadataStoragePageMemoryImplTest.java      |     8 +-
 .../pagemem/NoOpPageStoreManager.java           |     2 +-
 .../persistence/pagemem/NoOpWALManager.java     |     5 +
 .../pagemem/PageMemoryImplNoLoadTest.java       |     8 +-
 .../persistence/pagemem/PageMemoryImplTest.java |     8 +-
 .../pagemem/PagesWriteThrottleSandboxTest.java  |   260 +
 .../pagemem/PagesWriteThrottleSmokeTest.java    |   322 +
 .../AbstractNodeJoinTemplate.java               |    13 +-
 .../IgniteChangeGlobalStateAbstractTest.java    |    31 +-
 .../IgniteChangeGlobalStateServiceTest.java     |     2 +
 .../IgniteChangeGlobalStateTest.java            |    11 +-
 .../IgniteStandByClusterTest.java               |    66 +-
 .../extended/GridActivateExtensionTest.java     |    34 +-
 .../join/JoinInActiveNodeToActiveCluster.java   |     4 +-
 ...gniteAbstractStandByClientReconnectTest.java |    14 +-
 .../GridCacheQueryTransformerSelfTest.java      |    41 +
 ...ContinuousQueryFailoverAbstractSelfTest.java |    11 +-
 ...niteCacheContinuousQueryBackupQueueTest.java |     6 +-
 .../AbstractDeadlockDetectionTest.java          |   246 +
 .../cache/transactions/TxDeadlockCauseTest.java |    15 +-
 .../TxOptimisticDeadlockDetectionTest.java      |   322 +-
 .../TxPessimisticDeadlockDetectionTest.java     |   244 +-
 .../TxRollbackOnTimeoutNearCacheTest.java       |    28 +
 ...ollbackOnTimeoutNoDeadlockDetectionTest.java |    47 +
 .../transactions/TxRollbackOnTimeoutTest.java   |   839 ++
 .../closure/GridClosureProcessorRemoteTest.java |    97 +-
 .../cluster/GridUpdateNotifierSelfTest.java     |    50 +-
 .../processors/database/BPlusTreeSelfTest.java  |   866 +-
 .../database/DataRegionMetricsSelfTest.java     |   348 +
 .../database/FreeListImplSelfTest.java          |    16 +-
 .../database/IgniteDbAbstractTest.java          |    21 +-
 .../database/IgniteDbDynamicCacheSelfTest.java  |    18 +-
 .../IgniteDbMemoryLeakAbstractTest.java         |    14 +-
 .../database/MemoryMetricsSelfTest.java         |   348 -
 .../database/MetadataStorageSelfTest.java       |     8 +-
 .../database/SwapPathConstructionSelfTest.java  |    28 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |   203 +-
 .../processors/igfs/IgfsIgniteMock.java         |    35 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |    12 +-
 .../OdbcConfigurationValidationSelfTest.java    |     1 -
 ...ServiceDeploymentCompoundFutureSelfTest.java |   127 +
 ...GridServiceProcessorBatchDeploySelfTest.java |   671 +
 .../GridServiceProcessorMultiNodeSelfTest.java  |    71 +-
 .../internal/sql/SqlParserAbstractSelfTest.java |    46 +
 .../sql/SqlParserCreateIndexSelfTest.java       |   261 +
 .../sql/SqlParserDropIndexSelfTest.java         |    99 +
 .../internal/util/nio/GridNioSelfTest.java      |     2 +-
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |   326 -
 .../unsafe/GridUnsafeMemoryPerformanceTest.java |    65 -
 .../unsafe/GridUnsafeMemorySelfTest.java        |   192 -
 .../ignite/logger/java/JavaLoggerTest.java      |     5 +
 .../p2p/DeploymentClassLoaderCallableTest.java  |   144 +
 .../apache/ignite/p2p/SharedDeploymentTest.java |   128 +
 .../platform/PlatformCacheWriteMetricsTask.java |    31 +-
 .../ignite/platform/PlatformExceptionTask.java  |     8 +
 .../platform/plugin/PlatformTestPlugin.java     |    27 -
 .../plugin/PlatformTestPluginConfiguration.java |    63 -
 ...rmTestPluginConfigurationClosureFactory.java |    61 -
 .../plugin/PlatformTestPluginException.java     |    34 -
 .../plugin/PlatformTestPluginExtension.java     |    51 -
 .../plugin/PlatformTestPluginProvider.java      |   103 -
 .../plugin/PlatformTestPluginTarget.java        |   236 -
 .../cache/PlatformGetCachePluginsTask.java      |    85 -
 .../PlatformTestCachePluginConfiguration.java   |    55 -
 ...formTestCachePluginConfigurationClosure.java |    48 -
 ...tCachePluginConfigurationClosureFactory.java |    37 -
 .../cache/PlatformTestCachePluginProvider.java  |    72 -
 .../spi/GridTcpSpiForwardingSelfTest.java       |     1 +
 .../GridAbstractCommunicationSelfTest.java      |    27 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |    28 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    39 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |    47 +-
 ...CommunicationRecoveryAckClosureSelfTest.java |    36 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |     3 +-
 ...ommunicationSpiHalfOpenedConnectionTest.java |   142 +
 .../tcp/TcpCommunicationStatisticsTest.java     |   191 +
 ...ClusterMetricsSnapshotSerializeSelfTest.java |     8 +-
 .../IgniteDiscoveryCacheReuseSelfTest.java      |    96 +
 .../discovery/tcp/IgniteClientConnectTest.java  |   163 +
 ...pClientDiscoveryMarshallerCheckSelfTest.java |    84 +-
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |    20 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |   275 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |   110 +
 .../tcp/TcpDiscoverySslTrustedSelfTest.java     |    42 +
 .../TcpDiscoverySslTrustedUntrustedTest.java    |   140 +
 .../tcp/TcpDiscoveryWithWrongServerTest.java    |   336 +
 .../ignite/testframework/GridTestUtils.java     |    64 +-
 .../ignite/testframework/junits/IgniteMock.java |    25 +-
 .../junits/common/GridCommonAbstractTest.java   |    22 +-
 .../junits/logger/GridTestLog4jLogger.java      |    21 +-
 .../junits/multijvm/IgniteNodeRunner.java       |     2 +-
 .../junits/multijvm/IgniteProcessProxy.java     |   125 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |     9 +-
 .../IgniteCacheDataStructuresSelfTestSuite.java |     6 +-
 .../IgniteCacheEvictionSelfTestSuite.java       |    11 +
 .../IgniteCacheFailoverTestSuite.java           |     2 -
 .../IgniteCacheFullApiSelfTestSuite.java        |     2 +
 .../IgniteCacheMetricsSelfTestSuite.java        |     5 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |    13 +-
 .../testsuites/IgniteCacheTestSuite2.java       |    17 +-
 .../testsuites/IgniteCacheTestSuite4.java       |     8 +-
 .../testsuites/IgniteCacheTestSuite5.java       |     7 +-
 .../testsuites/IgniteCacheTestSuite6.java       |    19 +
 .../IgniteClientReconnectTestSuite.java         |     6 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |     4 +
 .../testsuites/IgniteP2PSelfTestSuite.java      |     4 +
 .../ignite/testsuites/IgnitePdsTestSuite.java   |     7 +
 .../ignite/testsuites/IgnitePdsTestSuite2.java  |    30 +-
 .../testsuites/IgniteReproducingSuite.java      |    42 +
 .../IgniteSpiCommunicationSelfTestSuite.java    |     5 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    17 +
 .../IgniteSpiIndexingSelfTestSuite.java         |    38 -
 .../ignite/testsuites/IgniteSpiTestSuite.java   |     3 -
 modules/dev-utils/pom.xml                       |    63 +
 .../development/utils/IgniteWalConverter.java   |    85 +
 .../ignite/development/utils/package-info.java  |    22 +
 modules/docker/2.2.0/Dockerfile                 |    46 +
 modules/docker/2.2.0/run.sh                     |    51 +
 modules/docker/2.3.0/Dockerfile                 |    46 +
 modules/docker/2.3.0/run.sh                     |    51 +
 modules/docker/Dockerfile                       |     4 +-
 modules/extdata/p2p/pom.xml                     |     2 +-
 .../tests/p2p/compute/ExternalCallable.java     |    59 +
 .../tests/p2p/compute/ExternalCallable1.java    |    59 +
 .../tests/p2p/compute/ExternalCallable2.java    |    59 +
 modules/extdata/platform/README.txt             |     4 +
 .../extdata/platform/licenses/apache-2.0.txt    |   202 +
 modules/extdata/platform/pom.xml                |    46 +
 .../platform/plugin/PlatformTestPlugin.java     |    27 +
 .../plugin/PlatformTestPluginConfiguration.java |    63 +
 ...rmTestPluginConfigurationClosureFactory.java |    61 +
 .../plugin/PlatformTestPluginException.java     |    34 +
 .../plugin/PlatformTestPluginExtension.java     |    51 +
 .../plugin/PlatformTestPluginProvider.java      |   103 +
 .../plugin/PlatformTestPluginTarget.java        |   236 +
 .../cache/PlatformGetCachePluginsTask.java      |    85 +
 .../PlatformTestCachePluginConfiguration.java   |    55 +
 ...formTestCachePluginConfigurationClosure.java |    48 +
 ...tCachePluginConfigurationClosureFactory.java |    37 +
 .../cache/PlatformTestCachePluginProvider.java  |    72 +
 .../platform/plugin/cache/package-info.java     |    22 +
 .../ignite/platform/plugin/package-info.java    |    22 +
 .../org.apache.ignite.plugin.PluginProvider     |     1 +
 ...atformCachePluginConfigurationClosureFactory |     1 +
 ...rm.PlatformPluginConfigurationClosureFactory |     1 +
 .../extdata/uri/modules/uri-dependency/pom.xml  |     2 +-
 modules/extdata/uri/pom.xml                     |     2 +-
 .../tests/p2p/compute/ExternalCallable.java     |    59 +
 .../tests/p2p/compute/ExternalCallable1.java    |    59 +
 .../tests/p2p/compute/ExternalCallable2.java    |    59 +
 modules/flink/pom.xml                           |     2 +-
 modules/flume/pom.xml                           |     2 +-
 modules/gce/pom.xml                             |     2 +-
 modules/geospatial/pom.xml                      |     2 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |    45 +-
 modules/hadoop/pom.xml                          |     2 +-
 .../processors/hadoop/impl/HadoopUtils.java     |    45 +-
 .../impl/fs/HadoopFileSystemCacheUtils.java     |    34 +-
 .../hadoop/impl/proto/HadoopClientProtocol.java |     8 +-
 .../hadoop/impl/v1/HadoopV1MapTask.java         |     6 +-
 .../hadoop/impl/v1/HadoopV1Reporter.java        |     8 +-
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |    32 +-
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |    62 +-
 .../HadoopExternalCommunication.java            |     5 +-
 .../impl/HadoopAbstractMapReduceTest.java       |     2 +-
 .../hadoop/impl/HadoopGroupingTest.java         |     2 +-
 .../hadoop/impl/HadoopJobTrackerSelfTest.java   |     4 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |     2 +-
 .../hadoop/impl/HadoopPlannerMockJob.java       |     6 +
 .../hadoop/impl/HadoopSortingTest.java          |     4 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |    10 +-
 .../hadoop/impl/HadoopTasksV1Test.java          |     2 +-
 .../hadoop/impl/HadoopTasksV2Test.java          |     2 +-
 .../hadoop/impl/HadoopTeraSortTest.java         |     2 +-
 .../hadoop/impl/HadoopTxConfigCacheTest.java    |     4 +-
 .../hadoop/impl/HadoopV2JobSelfTest.java        |     2 +-
 .../collections/HadoopAbstractMapTest.java      |     6 +
 .../HadoopExternalTaskExecutionSelfTest.java    |     4 +-
 modules/hibernate-4.2/pom.xml                   |     2 +-
 modules/hibernate-5.1/pom.xml                   |     2 +-
 modules/hibernate-core/pom.xml                  |     2 +-
 .../cache/hibernate/HibernateCacheProxy.java    |     5 -
 modules/ignored-tests/pom.xml                   |    10 +-
 modules/indexing/pom.xml                        |    50 +-
 .../cache/query/CacheQueryPartitionInfo.java    |     1 +
 .../query/h2/DmlStatementsProcessor.java        |   644 +-
 .../internal/processors/query/h2/H2Cursor.java  |    42 +-
 .../processors/query/h2/H2DatabaseType.java     |     2 +-
 .../processors/query/h2/H2DmlPlanKey.java       |    21 +-
 .../query/h2/H2ResultSetIterator.java           |     3 +-
 .../processors/query/h2/H2RowDescriptor.java    |   491 -
 .../internal/processors/query/h2/H2Schema.java  |    41 +-
 .../processors/query/h2/H2TableDescriptor.java  |    23 +-
 .../processors/query/h2/H2TableEngine.java      |     8 +-
 .../query/h2/H2TwoStepCachedQueryKey.java       |     1 +
 .../internal/processors/query/h2/H2TypeKey.java |    64 +
 .../internal/processors/query/h2/H2Utils.java   |     3 +-
 .../processors/query/h2/IgniteH2Indexing.java   |   841 +-
 .../processors/query/h2/UpdateResult.java       |    63 +
 .../query/h2/database/H2PkHashIndex.java        |    64 +-
 .../query/h2/database/H2RowFactory.java         |     8 +-
 .../processors/query/h2/database/H2Tree.java    |    41 +-
 .../query/h2/database/H2TreeIndex.java          |   225 +-
 .../query/h2/database/InlineIndexHelper.java    |     6 +-
 .../query/h2/database/io/H2ExtrasInnerIO.java   |    20 +-
 .../query/h2/database/io/H2ExtrasLeafIO.java    |    16 +-
 .../query/h2/database/io/H2InnerIO.java         |     4 +-
 .../query/h2/database/io/H2LeafIO.java          |     4 +-
 .../query/h2/database/util/CompareUtils.java    |   332 -
 .../query/h2/ddl/DdlStatementsProcessor.java    |   239 +-
 .../processors/query/h2/dml/DmlAstUtils.java    |   639 +
 .../processors/query/h2/dml/DmlBatchSender.java |   232 +
 .../query/h2/dml/DmlDistributedPlanInfo.java    |    56 +
 .../h2/dml/DmlPageProcessingErrorResult.java    |    76 +
 .../query/h2/dml/DmlPageProcessingResult.java   |    68 +
 .../processors/query/h2/dml/DmlUtils.java       |   118 +
 .../processors/query/h2/dml/FastUpdate.java     |   175 +
 .../processors/query/h2/dml/UpdatePlan.java     |   372 +-
 .../query/h2/dml/UpdatePlanBuilder.java         |   233 +-
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   454 -
 .../query/h2/opt/GridH2CollocationModel.java    |    18 +-
 .../query/h2/opt/GridH2IndexBase.java           |   213 +-
 .../query/h2/opt/GridH2KeyRowOnheap.java        |    63 +
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   328 -
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |   199 +-
 .../query/h2/opt/GridH2MetaTable.java           |    13 +-
 .../query/h2/opt/GridH2PlainRowFactory.java     |   181 +
 .../query/h2/opt/GridH2QueryContext.java        |     4 +
 .../processors/query/h2/opt/GridH2Row.java      |   134 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |   433 +-
 .../query/h2/opt/GridH2RowFactory.java          |   194 -
 .../query/h2/opt/GridH2SearchRowAdapter.java    |   103 +
 .../processors/query/h2/opt/GridH2Table.java    |   411 +-
 .../query/h2/opt/GridLuceneDirectory.java       |    15 +-
 .../query/h2/opt/GridLuceneIndex.java           |    53 +-
 .../query/h2/opt/GridSearchRowPointer.java      |    28 -
 .../processors/query/h2/sql/DmlAstUtils.java    |   602 -
 .../h2/sql/GridSqlAlterTableAddColumn.java      |   113 +
 .../processors/query/h2/sql/GridSqlArray.java   |     8 -
 .../processors/query/h2/sql/GridSqlColumn.java  |     7 -
 .../query/h2/sql/GridSqlCreateTable.java        |   120 +
 .../query/h2/sql/GridSqlFunction.java           |     2 +-
 .../processors/query/h2/sql/GridSqlMerge.java   |     5 +-
 .../query/h2/sql/GridSqlQueryParser.java        |   442 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |    64 +-
 .../query/h2/twostep/DistributedUpdateRun.java  |   133 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |   379 +-
 .../query/h2/twostep/GridMergeIndex.java        |     8 +-
 .../h2/twostep/GridMergeIndexIterator.java      |   165 +
 .../query/h2/twostep/GridMergeIndexSorted.java  |     4 +-
 .../h2/twostep/GridMergeIndexUnsorted.java      |     4 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |   415 +-
 .../query/h2/twostep/MapNodeResults.java        |    52 +-
 .../query/h2/twostep/MapQueryLazyWorker.java    |   176 +
 .../query/h2/twostep/MapQueryLazyWorkerKey.java |    97 +
 .../query/h2/twostep/MapQueryResult.java        |    46 +-
 .../query/h2/twostep/MapQueryResults.java       |    26 +-
 .../query/h2/twostep/MapRequestKey.java         |    23 +-
 .../query/h2/twostep/msg/GridH2DmlRequest.java  |   516 +
 .../query/h2/twostep/msg/GridH2DmlResponse.java |   250 +
 .../query/h2/twostep/msg/GridH2Geometry.java    |     2 +-
 .../query/h2/twostep/msg/GridH2Null.java        |     1 +
 .../h2/twostep/msg/GridH2QueryRequest.java      |     9 +
 .../twostep/msg/GridH2ValueMessageFactory.java  |     6 +
 .../cache/GridCacheFullTextQuerySelfTest.java   |    30 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |    43 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |    15 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |    13 +-
 ...ributedJoinPartitionedAndReplicatedTest.java |     2 +
 .../IgniteCacheInsertSqlQuerySelfTest.java      |    18 +
 ...titionOnAffinityRunWithCollisionSpiTest.java |     3 +-
 ...CheckClusterStateBeforeExecuteQueryTest.java |    89 +
 ...leNodeWithIndexingPutGetPersistenceTest.java |    12 +-
 ...stributedPartitionQueryAbstractSelfTest.java |     8 +-
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |    83 +-
 .../IgniteCacheQueryNodeRestartTxSelfTest.java  |    36 +
 ...ldsQueryJoinNoPrimaryPartitionsSelfTest.java |   151 +
 .../cache/index/AbstractSchemaSelfTest.java     |   247 +-
 ...ynamicColumnsAbstractConcurrentSelfTest.java |  1060 ++
 .../cache/index/DynamicColumnsAbstractTest.java |   206 +
 ...umnsConcurrentAtomicPartitionedSelfTest.java |    33 +
 ...lumnsConcurrentAtomicReplicatedSelfTest.java |    33 +
 ...currentTransactionalPartitionedSelfTest.java |    33 +
 ...ncurrentTransactionalReplicatedSelfTest.java |    34 +
 .../DynamicIndexAbstractBasicSelfTest.java      |   369 +-
 .../DynamicIndexAbstractConcurrentSelfTest.java |   192 +-
 .../index/DynamicIndexAbstractSelfTest.java     |    16 +-
 .../cache/index/H2ConnectionLeaksSelfTest.java  |   169 +
 .../H2DynamicColumnsAbstractBasicSelfTest.java  |   431 +
 .../H2DynamicColumnsClientBasicSelfTest.java    |    28 +
 .../H2DynamicColumnsServerBasicSelfTest.java    |    28 +
 ...icColumnsServerCoordinatorBasicSelfTest.java |    28 +
 ...lexClientAtomicPartitionedNoBackupsTest.java |    34 +
 ...exingComplexClientAtomicPartitionedTest.java |     2 +-
 ...dexingComplexClientAtomicReplicatedTest.java |     2 +-
 ...ntTransactionalPartitionedNoBackupsTest.java |    34 +
 ...mplexClientTransactionalPartitionedTest.java |     2 +-
 ...omplexClientTransactionalReplicatedTest.java |     2 +-
 ...lexServerAtomicPartitionedNoBackupsTest.java |    34 +
 ...exingComplexServerAtomicPartitionedTest.java |     2 +-
 ...dexingComplexServerAtomicReplicatedTest.java |     2 +-
 ...erTransactionalPartitionedNoBackupsTest.java |    34 +
 ...mplexServerTransactionalPartitionedTest.java |     2 +-
 ...omplexServerTransactionalReplicatedTest.java |     2 +-
 .../index/H2DynamicIndexingComplexTest.java     |    22 +-
 .../cache/index/H2DynamicTableSelfTest.java     |   721 +-
 .../cache/index/LongIndexNameTest.java          |   214 +
 .../cache/index/SchemaExchangeSelfTest.java     |     4 +-
 ...onnectorConfigurationValidationSelfTest.java |   392 +
 ...eDbSingleNodeWithIndexingWalRestoreTest.java |    18 +-
 ...oreQueryWithMultipleClassesPerCacheTest.java |    11 +-
 .../IgnitePersistentStoreSchemaLoadTest.java    |   253 +-
 .../query/IgniteSqlNotNullConstraintTest.java   |  1240 ++
 .../query/IgniteSqlParameterizedQueryTest.java  |   392 +
 .../query/IgniteSqlSchemaIndexingTest.java      |    30 +-
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |   124 +-
 ...teSqlSkipReducerOnUpdateDmlFlagSelfTest.java |   800 ++
 ...IgniteSqlSkipReducerOnUpdateDmlSelfTest.java |   755 ++
 .../processors/query/LazyQuerySelfTest.java     |   389 +
 .../MultipleStatementsSqlQuerySelfTest.java     |   154 +
 .../processors/query/SqlSchemaSelfTest.java     |   104 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |    75 +-
 .../query/h2/IgniteSqlBigIntegerKeyTest.java    |   163 +
 .../h2/database/InlineIndexHelperTest.java      |    32 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |   369 -
 .../query/h2/sql/GridQueryParsingTest.java      |   305 +-
 ...onnectorConfigurationValidationSelfTest.java |     3 +-
 .../IgniteCacheQuerySelfTestSuite.java          |    55 +
 .../IgniteCacheQuerySelfTestSuite2.java         |    17 +
 .../IgniteCacheQuerySelfTestSuite3.java         |     3 -
 .../IgniteDistributedJoinTestSuite.java         |    55 -
 .../IgnitePdsWithIndexingCoreTestSuite.java     |    11 +
 ...ityWithJsr310Java8DateTimeApiFieldsTest.java |   351 +
 ...acheQueryJsr310Java8DateTimeApiBaseTest.java |    88 +
 ...yJsr310Java8DateTimeApiSupportTestSuite.java |    38 +
 modules/jcl/pom.xml                             |     2 +-
 modules/jms11/pom.xml                           |     2 +-
 modules/jta/pom.xml                             |     2 +-
 modules/kafka/pom.xml                           |     2 +-
 modules/kubernetes/config/example-kube.xml      |     2 +-
 modules/kubernetes/pom.xml                      |     2 +-
 modules/log4j/pom.xml                           |     2 +-
 .../apache/ignite/logger/log4j/Log4JLogger.java |    40 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |    13 +
 .../logger/log4j/GridLog4jInitializedTest.java  |     7 +-
 .../logger/log4j/GridLog4jLoggingFileTest.java  |    13 +-
 .../logger/log4j/GridLog4jLoggingPathTest.java  |    12 +-
 .../logger/log4j/GridLog4jLoggingUrlTest.java   |    15 +-
 .../log4j/GridLog4jNotInitializedTest.java      |     5 +
 .../ignite/testsuites/IgniteLog4jTestSuite.java |     6 +
 modules/log4j2/pom.xml                          |     2 +-
 .../ignite/logger/log4j2/Log4J2Logger.java      |   138 +-
 .../log4j2/GridLog4j2CorrectFileNameTest.java   |    94 -
 .../log4j2/GridLog4j2InitializedTest.java       |    77 -
 .../log4j2/GridLog4j2LoggingFileTest.java       |    68 -
 .../logger/log4j2/Log4j2LoggerSelfTest.java     |    26 +-
 .../log4j2/Log4j2LoggerVerboseModeSelfTest.java |    71 +-
 .../testsuites/IgniteLog4j2TestSuite.java       |     2 +
 modules/mesos/pom.xml                           |     2 +-
 modules/ml/licenses/netlib-java-bsd3.txt        |    51 +
 modules/ml/pom.xml                              |    15 +-
 .../java/org/apache/ignite/ml/Exportable.java   |    33 +
 .../java/org/apache/ignite/ml/Exporter.java     |    38 +
 .../java/org/apache/ignite/ml/FileExporter.java |    75 +
 .../ignite/ml/FuzzyCMeansModelFormat.java       |    76 +
 .../org/apache/ignite/ml/KMeansModelFormat.java |    77 +
 .../main/java/org/apache/ignite/ml/Model.java   |     7 +-
 .../main/java/org/apache/ignite/ml/Trainer.java |    37 +
 .../ml/clustering/BaseFuzzyCMeansClusterer.java |    90 +
 .../ml/clustering/BaseKMeansClusterer.java      |     2 +-
 .../FuzzyCMeansDistributedClusterer.java        |   512 +
 .../clustering/FuzzyCMeansLocalClusterer.java   |   254 +
 .../ignite/ml/clustering/FuzzyCMeansModel.java  |    88 +
 .../clustering/KMeansDistributedClusterer.java  |    76 +-
 .../ml/clustering/KMeansLocalClusterer.java     |     2 +-
 .../ignite/ml/clustering/KMeansModel.java       |    44 +-
 .../ignite/ml/clustering/WeightedClusterer.java |     2 +-
 .../apache/ignite/ml/estimators/Estimators.java |    50 +
 .../ignite/ml/estimators/package-info.java      |    22 +
 .../apache/ignite/ml/knn/models/KNNModel.java   |   233 +
 .../ignite/ml/knn/models/KNNModelFormat.java    |    92 +
 .../ignite/ml/knn/models/KNNStrategy.java       |    27 +
 .../ignite/ml/knn/models/Normalization.java     |    32 +
 .../ignite/ml/knn/models/package-info.java      |    22 +
 .../org/apache/ignite/ml/knn/package-info.java  |    22 +
 .../regression/KNNMultipleLinearRegression.java |    83 +
 .../ignite/ml/knn/regression/package-info.java  |    22 +
 .../java/org/apache/ignite/ml/math/Blas.java    |    32 +-
 .../apache/ignite/ml/math/DistanceMeasure.java  |    38 -
 .../ignite/ml/math/EuclideanDistance.java       |    47 -
 .../ignite/ml/math/IdentityValueMapper.java     |     2 +
 .../java/org/apache/ignite/ml/math/Matrix.java  |    17 +
 .../apache/ignite/ml/math/MatrixKeyMapper.java  |    30 -
 .../apache/ignite/ml/math/MatrixStorage.java    |     7 +-
 .../org/apache/ignite/ml/math/ValueMapper.java  |    37 -
 .../java/org/apache/ignite/ml/math/Vector.java  |     1 +
 .../apache/ignite/ml/math/VectorKeyMapper.java  |    29 -
 .../ml/math/decompositions/LUDecomposition.java |     2 +-
 .../ml/math/decompositions/QRDSolver.java       |   197 +
 .../ml/math/decompositions/QRDecomposition.java |    54 +-
 .../ml/math/distances/DistanceMeasure.java      |    39 +
 .../ml/math/distances/EuclideanDistance.java    |    59 +
 .../ml/math/distances/HammingDistance.java      |    65 +
 .../ml/math/distances/ManhattanDistance.java    |    59 +
 .../ignite/ml/math/distances/package-info.java  |    22 +
 .../ignite/ml/math/distributed/CacheUtils.java  |   734 ++
 .../ml/math/distributed/DistributedStorage.java |    35 +
 .../ml/math/distributed/MatrixKeyMapper.java    |    33 +
 .../ignite/ml/math/distributed/ValueMapper.java |    37 +
 .../ml/math/distributed/VectorKeyMapper.java    |    32 +
 .../distributed/keys/DataStructureCacheKey.java |    35 +
 .../math/distributed/keys/MatrixBlockKey.java   |    38 +
 .../math/distributed/keys/RowColMatrixKey.java  |    30 +
 .../math/distributed/keys/VectorBlockKey.java   |    34 +
 .../distributed/keys/impl/MatrixBlockKey.java   |   166 +
 .../distributed/keys/impl/SparseMatrixKey.java  |   119 +
 .../distributed/keys/impl/VectorBlockKey.java   |   152 +
 .../distributed/keys/impl/package-info.java     |    22 +
 .../ml/math/distributed/keys/package-info.java  |    22 +
 .../ml/math/distributed/package-info.java       |    22 +
 .../math/exceptions/knn/EmptyFileException.java |    37 +
 .../exceptions/knn/FileParsingException.java    |    39 +
 .../exceptions/knn/NoLabelVectorException.java  |    37 +
 .../knn/SmallTrainingDatasetSizeException.java  |    38 +
 .../ml/math/exceptions/knn/package-info.java    |    22 +
 .../ignite/ml/math/functions/Functions.java     |    41 +
 .../ml/math/functions/IgniteBinaryOperator.java |    29 +
 .../math/functions/IgniteCurriedBiFunction.java |    29 +
 .../ml/math/functions/IgniteSupplier.java       |    30 +
 .../math/functions/IgniteToDoubleFunction.java  |    30 +
 .../ml/math/functions/IgniteTriFunction.java    |     5 +-
 .../apache/ignite/ml/math/impls/CacheUtils.java |   559 -
 .../ml/math/impls/matrix/AbstractMatrix.java    |    57 +-
 .../ignite/ml/math/impls/matrix/BlockEntry.java |    50 -
 .../ml/math/impls/matrix/CacheMatrix.java       |     6 +-
 .../impls/matrix/DenseLocalOnHeapMatrix.java    |     4 +-
 .../ml/math/impls/matrix/MatrixBlockEntry.java  |    50 +
 .../matrix/SparseBlockDistributedMatrix.java    |   161 +-
 .../impls/matrix/SparseDistributedMatrix.java   |   165 +-
 .../storage/matrix/BaseBlockMatrixKey.java      |    41 -
 .../impls/storage/matrix/BlockMatrixKey.java    |   144 -
 .../storage/matrix/BlockMatrixStorage.java      |   302 +-
 .../storage/matrix/BlockVectorStorage.java      |   368 +
 .../storage/matrix/CacheMatrixStorage.java      |     9 +-
 .../matrix/DenseOffHeapMatrixStorage.java       |     7 +-
 .../storage/matrix/DiagonalMatrixStorage.java   |     5 +
 .../storage/matrix/FunctionMatrixStorage.java   |     5 +
 .../impls/storage/matrix/MapWrapperStorage.java |    16 +-
 .../storage/matrix/MatrixDelegateStorage.java   |     5 +
 .../storage/matrix/PivotedMatrixStorage.java    |     5 +
 .../storage/matrix/RandomMatrixStorage.java     |     5 +
 .../matrix/SparseDistributedMatrixStorage.java  |    72 +-
 .../matrix/SparseLocalOnHeapMatrixStorage.java  |     9 +-
 .../storage/vector/CacheVectorStorage.java      |     4 +-
 .../vector/SparseDistributedVectorStorage.java  |   281 +
 .../vector/SparseLocalOnHeapVectorStorage.java  |     2 +-
 .../ml/math/impls/vector/CacheVector.java       |     6 +-
 .../ml/math/impls/vector/MapWrapperVector.java  |     7 +
 .../vector/SparseBlockDistributedVector.java    |   135 +
 .../impls/vector/SparseDistributedVector.java   |   147 +
 .../ml/math/impls/vector/VectorBlockEntry.java  |    47 +
 .../apache/ignite/ml/math/util/MatrixUtil.java  |    17 +-
 .../AbstractMultipleLinearRegression.java       |    20 +
 .../OLSMultipleLinearRegression.java            |    41 +-
 .../OLSMultipleLinearRegressionModel.java       |    77 +
 .../OLSMultipleLinearRegressionModelFormat.java |    46 +
 .../OLSMultipleLinearRegressionTrainer.java     |    62 +
 .../ignite/ml/structures/LabeledDataset.java    |   475 +
 .../structures/LabeledDatasetTestTrainPair.java |   116 +
 .../ignite/ml/structures/LabeledVector.java     |    94 +
 .../ml/structures/LabeledVectorDouble.java      |    46 +
 .../ignite/ml/structures/package-info.java      |    22 +
 .../ignite/ml/trees/CategoricalRegionInfo.java  |    72 +
 .../ignite/ml/trees/CategoricalSplitInfo.java   |    68 +
 .../ignite/ml/trees/ContinuousRegionInfo.java   |    74 +
 .../ml/trees/ContinuousSplitCalculator.java     |    51 +
 .../org/apache/ignite/ml/trees/RegionInfo.java  |    62 +
 .../ml/trees/models/DecisionTreeModel.java      |    44 +
 .../ignite/ml/trees/models/package-info.java    |    22 +
 .../ml/trees/nodes/CategoricalSplitNode.java    |    50 +
 .../ml/trees/nodes/ContinuousSplitNode.java     |    56 +
 .../ignite/ml/trees/nodes/DecisionTreeNode.java |    33 +
 .../org/apache/ignite/ml/trees/nodes/Leaf.java  |    49 +
 .../apache/ignite/ml/trees/nodes/SplitNode.java |   100 +
 .../ignite/ml/trees/nodes/package-info.java     |    22 +
 .../apache/ignite/ml/trees/package-info.java    |    22 +
 .../ml/trees/trainers/columnbased/BiIndex.java  |   113 +
 ...exedCacheColumnDecisionTreeTrainerInput.java |    57 +
 .../CacheColumnDecisionTreeTrainerInput.java    |   141 +
 .../columnbased/ColumnDecisionTreeTrainer.java  |   568 +
 .../ColumnDecisionTreeTrainerInput.java         |    55 +
 .../MatrixColumnDecisionTreeTrainerInput.java   |    83 +
 .../trainers/columnbased/RegionProjection.java  |   109 +
 .../trainers/columnbased/TrainingContext.java   |   166 +
 .../columnbased/caches/ContextCache.java        |    68 +
 .../columnbased/caches/FeaturesCache.java       |   151 +
 .../columnbased/caches/ProjectionsCache.java    |   286 +
 .../trainers/columnbased/caches/SplitCache.java |   206 +
 .../columnbased/caches/package-info.java        |    22 +
 .../ContinuousSplitCalculators.java             |    34 +
 .../contsplitcalcs/GiniSplitCalculator.java     |   234 +
 .../contsplitcalcs/VarianceSplitCalculator.java |   179 +
 .../contsplitcalcs/package-info.java            |    22 +
 .../trainers/columnbased/package-info.java      |    22 +
 .../columnbased/regcalcs/RegionCalculators.java |    85 +
 .../columnbased/regcalcs/package-info.java      |    22 +
 .../vectors/CategoricalFeatureProcessor.java    |   212 +
 .../vectors/ContinuousFeatureProcessor.java     |   111 +
 .../vectors/ContinuousSplitInfo.java            |    71 +
 .../columnbased/vectors/FeatureProcessor.java   |    82 +
 .../vectors/FeatureVectorProcessorUtils.java    |    57 +
 .../columnbased/vectors/SampleInfo.java         |    80 +
 .../trainers/columnbased/vectors/SplitInfo.java |   106 +
 .../columnbased/vectors/package-info.java       |    22 +
 .../org/apache/ignite/ml/util/MnistUtils.java   |   124 +
 .../java/org/apache/ignite/ml/util/Utils.java   |    60 +
 .../org/apache/ignite/ml/util/package-info.java |    22 +
 .../org/apache/ignite/ml/IgniteMLTestSuite.java |     7 +-
 .../org/apache/ignite/ml/LocalModelsTest.java   |   166 +
 .../java/org/apache/ignite/ml/TestUtils.java    |    15 +
 .../ml/clustering/ClusteringTestSuite.java      |     7 +-
 .../FuzzyCMeansDistributedClustererTest.java    |   177 +
 .../FuzzyCMeansLocalClustererTest.java          |   203 +
 .../KMeansDistributedClustererTest.java         |   197 -
 ...KMeansDistributedClustererTestMultiNode.java |   138 +
 ...MeansDistributedClustererTestSingleNode.java |   198 +
 .../ml/clustering/KMeansLocalClustererTest.java |     2 +-
 .../apache/ignite/ml/clustering/KMeansUtil.java |     6 +-
 .../org/apache/ignite/ml/knn/BaseKNNTest.java   |    91 +
 .../ignite/ml/knn/KNNClassificationTest.java    |   153 +
 .../ml/knn/KNNMultipleLinearRegressionTest.java |   157 +
 .../org/apache/ignite/ml/knn/KNNTestSuite.java  |    33 +
 .../ignite/ml/knn/LabeledDatasetTest.java       |   266 +
 .../org/apache/ignite/ml/math/BlasTest.java     |    11 +-
 .../ml/math/MathImplDistributedTestSuite.java   |     8 +-
 .../ignite/ml/math/MathImplLocalTestSuite.java  |     6 +-
 .../ml/math/decompositions/QRDSolverTest.java   |    87 +
 .../ignite/ml/math/distances/DistanceTest.java  |    75 +
 .../ml/math/impls/matrix/CacheMatrixTest.java   |     2 +-
 .../impls/matrix/MatrixImplementationsTest.java |    17 +
 .../impls/matrix/MatrixKeyMapperForTests.java   |     2 +-
 .../SparseDistributedBlockMatrixTest.java       |   149 +-
 .../matrix/SparseDistributedMatrixTest.java     |    75 +-
 .../SparseDistributedVectorStorageTest.java     |   123 +
 .../ml/math/impls/vector/CacheVectorTest.java   |    12 +-
 .../SparseBlockDistributedVectorTest.java       |   186 +
 .../vector/SparseDistributedVectorTest.java     |   191 +
 .../math/impls/vector/VectorToMatrixTest.java   |     3 -
 ...tedBlockOLSMultipleLinearRegressionTest.java |   901 ++
 ...tributedOLSMultipleLinearRegressionTest.java |   903 ++
 .../OLSMultipleLinearRegressionModelTest.java   |    53 +
 .../OLSMultipleLinearRegressionTest.java        |     1 +
 .../ml/regressions/RegressionsTestSuite.java    |     5 +-
 .../ignite/ml/trees/BaseDecisionTreeTest.java   |    70 +
 .../ml/trees/ColumnDecisionTreeTrainerTest.java |   191 +
 .../ignite/ml/trees/DecisionTreesTestSuite.java |    33 +
 .../ml/trees/GiniSplitCalculatorTest.java       |   141 +
 .../ignite/ml/trees/SplitDataGenerator.java     |   390 +
 .../ml/trees/VarianceSplitCalculatorTest.java   |    84 +
 .../ColumnDecisionTreeTrainerBenchmark.java     |   456 +
 .../ml/src/test/resources/datasets/README.md    |     2 +
 .../resources/datasets/knn/cleared_machines.txt |   209 +
 .../src/test/resources/datasets/knn/empty.txt   |     0
 .../ml/src/test/resources/datasets/knn/iris.txt |   150 +
 .../resources/datasets/knn/iris_incorrect.txt   |   150 +
 .../resources/datasets/knn/machine.data.txt     |   209 +
 .../test/resources/datasets/knn/missed_data.txt |     3 +
 .../src/test/resources/datasets/knn/no_data.txt |     6 +
 .../trees/columntrees.manualrun.properties      |    21 +
 modules/mqtt/pom.xml                            |     2 +-
 modules/osgi-karaf/pom.xml                      |     2 +-
 modules/osgi-paxlogging/pom.xml                 |     2 +-
 modules/osgi/pom.xml                            |     2 +-
 modules/platforms/.gitignore                    |     3 +-
 modules/platforms/cpp/README.md                 |   220 +
 .../platforms/cpp/common/include/Makefile.am    |     1 +
 .../cpp/common/include/ignite/common/lazy.h     |   172 +
 .../include/ignite/common/platform_utils.h      |    20 +-
 .../cpp/common/include/ignite/common/utils.h    |    51 +
 .../os/linux/src/common/platform_utils.cpp      |    34 +-
 .../common/os/win/src/common/platform_utils.cpp |    29 +-
 .../cpp/common/project/vs/common.vcxproj        |     1 +
 .../common/project/vs/common.vcxproj.filters    |     3 +
 modules/platforms/cpp/configure.ac              |     2 +-
 modules/platforms/cpp/configure.acrel           |     2 +-
 .../platforms/cpp/core-test/config/invalid.xml  |    39 +
 .../cpp/core-test/config/isolated-32.xml        |    51 +
 .../cpp/core-test/config/isolated-default.xml   |    59 +
 .../platforms/cpp/core-test/config/isolated.xml |    32 +
 .../core-test/config/persistence-store-32.xml   |    51 +
 .../config/persistence-store-default.xml        |    36 +
 .../cpp/core-test/config/persistence-store.xml  |    32 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |    10 +
 .../project/vs/core-test.vcxproj.filters        |    19 +
 .../cpp/core-test/src/cluster_test.cpp          |    33 +
 .../cpp/core-test/src/ignition_test.cpp         |    37 +-
 .../cpp/core-test/src/interop_test.cpp          |    11 -
 .../platforms/cpp/core-test/src/test_utils.cpp  |     8 +-
 .../ignite/cache/query/query_sql_fields.h       |    71 +-
 .../impl/cache/query/query_fields_row_impl.h    |     2 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |    25 +-
 modules/platforms/cpp/core/src/ignition.cpp     |    12 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |    45 +-
 .../examples/odbc-example/src/odbc_example.cpp  |     8 +-
 modules/platforms/cpp/ignite/src/ignite.cpp     |    23 +-
 .../cpp/jni/include/ignite/jni/utils.h          |    17 +-
 .../platforms/cpp/jni/os/linux/src/utils.cpp    |   120 +-
 modules/platforms/cpp/jni/os/win/src/utils.cpp  |   133 +-
 modules/platforms/cpp/odbc-test/Makefile.am     |     6 +-
 .../odbc-test/config/queries-test-default.xml   |     4 +-
 .../odbc-test/config/queries-test-noodbc-32.xml |     2 +-
 .../odbc-test/config/queries-test-noodbc.xml    |     2 +-
 .../cpp/odbc-test/include/test_utils.h          |    16 +
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    11 +-
 .../project/vs/odbc-test.vcxproj.filters        |    11 +-
 .../cpp/odbc-test/src/api_robustness_test.cpp   |    25 +-
 .../cpp/odbc-test/src/attributes_test.cpp       |   252 +
 .../cpp/odbc-test/src/configuration_test.cpp    |    36 +-
 .../cpp/odbc-test/src/connection_info_test.cpp  |     3 +-
 .../platforms/cpp/odbc-test/src/errors_test.cpp |   289 +
 .../cpp/odbc-test/src/meta_queries_test.cpp     |   113 +
 .../platforms/cpp/odbc-test/src/parser_test.cpp |     6 +-
 .../cpp/odbc-test/src/queries_test.cpp          |   544 +-
 .../cpp/odbc-test/src/sql_get_info_test.cpp     |   485 +
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |    21 +-
 modules/platforms/cpp/odbc/include/Makefile.am  |     1 +
 .../platforms/cpp/odbc/include/ignite/odbc.h    |    22 +-
 .../cpp/odbc/include/ignite/odbc/common_types.h |   134 +-
 .../include/ignite/odbc/config/configuration.h  |    56 +-
 .../ignite/odbc/config/connection_info.h        |     8 +-
 .../cpp/odbc/include/ignite/odbc/connection.h   |   131 +-
 .../cpp/odbc/include/ignite/odbc/cursor.h       |     7 +
 .../ignite/odbc/diagnostic/diagnosable.h        |     9 +
 .../odbc/diagnostic/diagnosable_adapter.h       |     8 +
 .../cpp/odbc/include/ignite/odbc/message.h      |   190 +-
 .../cpp/odbc/include/ignite/odbc/odbc_error.h   |    94 +
 .../cpp/odbc/include/ignite/odbc/parser.h       |    37 +-
 .../odbc/include/ignite/odbc/protocol_version.h |    11 +-
 .../include/ignite/odbc/query/batch_query.h     |    22 +-
 .../ignite/odbc/query/column_metadata_query.h   |    10 +
 .../odbc/include/ignite/odbc/query/data_query.h |    31 +-
 .../ignite/odbc/query/foreign_keys_query.h      |     7 +
 .../ignite/odbc/query/primary_keys_query.h      |     7 +
 .../cpp/odbc/include/ignite/odbc/query/query.h  |     7 +
 .../ignite/odbc/query/special_columns_query.h   |     7 +
 .../ignite/odbc/query/table_metadata_query.h    |    10 +
 .../include/ignite/odbc/query/type_info_query.h |    10 +
 .../cpp/odbc/include/ignite/odbc/statement.h    |    10 +-
 .../include/ignite/odbc/system/socket_client.h  |    75 +-
 .../odbc/system/ui/dsn_configuration_window.h   |     8 +
 .../cpp/odbc/install/ignite-odbc-amd64.wxs      |     2 +-
 .../cpp/odbc/install/ignite-odbc-x86.wxs        |     2 +-
 .../odbc/os/linux/src/system/socket_client.cpp  |   265 +-
 .../odbc/os/win/src/system/socket_client.cpp    |   312 +-
 .../src/system/ui/dsn_configuration_window.cpp  |    54 +-
 .../platforms/cpp/odbc/project/vs/odbc.vcxproj  |     1 +
 .../cpp/odbc/project/vs/odbc.vcxproj.filters    |     3 +
 modules/platforms/cpp/odbc/src/common_types.cpp |    51 +
 .../cpp/odbc/src/config/configuration.cpp       |    48 +-
 .../cpp/odbc/src/config/connection_info.cpp     |  2250 +++-
 modules/platforms/cpp/odbc/src/connection.cpp   |   259 +-
 modules/platforms/cpp/odbc/src/cursor.cpp       |     5 +
 .../odbc/src/diagnostic/diagnosable_adapter.cpp |     8 +
 .../odbc/src/diagnostic/diagnostic_record.cpp   |   111 +-
 modules/platforms/cpp/odbc/src/dsn_config.cpp   |     7 +
 modules/platforms/cpp/odbc/src/entry_points.cpp |    65 +-
 modules/platforms/cpp/odbc/src/message.cpp      |   153 +-
 .../platforms/cpp/odbc/src/meta/column_meta.cpp |     3 +
 modules/platforms/cpp/odbc/src/odbc.cpp         |    77 +-
 .../platforms/cpp/odbc/src/protocol_version.cpp |    12 +-
 .../cpp/odbc/src/query/batch_query.cpp          |   105 +-
 .../odbc/src/query/column_metadata_query.cpp    |    32 +-
 .../platforms/cpp/odbc/src/query/data_query.cpp |   159 +-
 .../cpp/odbc/src/query/foreign_keys_query.cpp   |     5 +
 .../cpp/odbc/src/query/primary_keys_query.cpp   |     5 +
 .../odbc/src/query/special_columns_query.cpp    |     5 +
 .../cpp/odbc/src/query/table_metadata_query.cpp |    32 +-
 .../cpp/odbc/src/query/type_info_query.cpp      |    21 +-
 modules/platforms/cpp/odbc/src/statement.cpp    |   100 +-
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Apache.Ignite.AspNet.csproj                 |     3 +-
 .../Apache.Ignite.AspNet.nuspec                 |     4 +
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Apache.Ignite.Benchmarks.csproj             |     2 +
 .../Apache.Ignite.Benchmarks/BenchmarkRunner.cs |     1 -
 .../Interop/PlatformBenchmarkBase.cs            |    21 +
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../ThinClient/ThinClientGetBenchmark.cs        |    63 +
 .../ThinClient/ThinClientPutBenchmark.cs        |    59 +
 .../Apache.Ignite.Core.Tests.DotNetCore.csproj  |   144 +
 .../Apache.Ignite.Core.Tests.DotNetCore.sln     |    25 +
 ...Ignite.Core.Tests.DotNetCore.sln.DotSettings |    13 +
 .../Cache/CacheTest.cs                          |    56 +
 .../Common/IgnitionStartTest.cs                 |   114 +
 .../Common/Person.cs                            |    44 +
 .../Common/TestBase.cs                          |    44 +
 .../Common/TestFixtureSetUp.cs                  |    30 +
 .../Common/TestFixtureTearDown.cs               |    30 +
 .../Common/TestLogger.cs                        |    74 +
 .../Common/TestRunner.cs                        |    33 +
 .../Common/TestUtils.DotNetCore.cs              |    93 +
 .../README.txt                                  |    17 +
 .../app.config                                  |    44 +
 .../dotnet-test-windows.bat                     |    32 +
 .../dotnet-test-wsl.bat                         |    34 +
 .../nuget.config                                |    41 +
 .../Apache.Ignite.Core.Tests.NuGet.csproj       |     4 +-
 ...ache.Ignite.Core.Tests.NuGet.sln.DotSettings |     4 +-
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../TestExtensions.cs                           |     2 +
 .../Apache.Ignite.Core.Tests.csproj             |    62 +-
 .../ApiParity/BinaryParityTest.cs               |    48 +
 .../ApiParity/CacheAffinityParityTest.cs        |    39 +
 .../ApiParity/CacheConfigurationParityTest.cs   |    77 +
 .../ApiParity/CacheMetricsParityTest.cs         |    64 +
 .../ApiParity/CacheParityTest.cs                |    76 +
 .../ClientConnectorConfigurationParityTest.cs   |    39 +
 .../ApiParity/ClusterMetricsParityTest.cs       |    47 +
 .../ApiParity/ClusterParityTest.cs              |    50 +
 .../ApiParity/ComputeParityTest.cs              |    51 +
 .../DataRegionConfigurationParityTest.cs        |    39 +
 .../ApiParity/DataRegionMetricsParityTest.cs    |    54 +
 .../DataStorageConfigurationParityTest.cs       |    53 +
 .../ApiParity/DataStorageMetricsParityTest.cs   |    38 +
 .../ApiParity/EventsParityTest.cs               |    50 +
 .../ApiParity/IgniteConfigurationParityTest.cs  |    98 +
 .../ApiParity/IgniteParityTest.cs               |    79 +
 .../ApiParity/MessagingParityTest.cs            |    39 +
 .../ApiParity/ParityTest.cs                     |   201 +
 .../QueryEntityConfigurationParityTest.cs       |    49 +
 .../ApiParity/ServicesParityTest.cs             |    39 +
 .../ApiParity/StreamerParityTest.cs             |    54 +
 .../ApiParity/TransactionMetricsParityTest.cs   |    39 +
 .../ApiParity/TransactionsParityTest.cs         |    39 +
 .../AssertExtensions.cs                         |    90 +
 .../Binary/BinaryBuilderSelfTest.cs             |    10 +-
 .../Binary/BinaryDynamicRegistrationTest.cs     |    64 +-
 .../Binary/BinaryFooterTest.cs                  |     2 +-
 .../Binary/BinarySelfTest.cs                    |    97 +-
 .../Binary/EnumsTest.cs                         |     2 +-
 .../Serializable/AdvancedSerializationTest.cs   |     2 +
 .../BasicSerializableObjectsTest.cs             |     3 +-
 .../Binary/Serializable/CallbacksTest.cs        |     9 +-
 .../Serializable/GenericCollectionsTest.cs      |   112 +
 .../Binary/Serializable/SqlDmlTest.cs           |     4 +-
 .../BinaryConfigurationTest.cs                  |    14 +-
 .../Cache/Affinity/AffinityAttributeTest.cs     |   135 +
 .../Cache/Affinity/AffinityFieldTest.cs         |    45 +-
 .../Cache/CacheAbstractTest.cs                  |   153 +-
 .../Cache/CacheConfigurationTest.cs             |   114 +-
 .../Cache/DataRegionMetricsTest.cs              |   153 +
 .../Cache/DataStorageMetricsTest.cs             |   107 +
 .../Cache/MemoryMetricsTest.cs                  |     2 +
 .../Cache/PersistenceTest.cs                    |   234 +
 .../Cache/PersistentStoreTest.cs                |   224 -
 .../Cache/PersistentStoreTestObsolete.cs        |   193 +
 .../Cache/Query/CacheDmlQueriesTest.cs          |    48 +-
 .../Query/CacheDmlQueriesTestSimpleName.cs      |     2 +-
 .../Query/CacheQueriesCodeConfigurationTest.cs  |    36 +-
 .../Cache/Query/CacheQueriesTest.cs             |    53 +-
 .../Cache/Query/CacheQueriesTestSimpleName.cs   |     2 +-
 .../Cache/Query/Linq/CacheLinqTest.Base.cs      |     5 +-
 .../Query/Linq/CacheLinqTest.Introspection.cs   |    25 +-
 .../Cache/Query/Linq/CacheLinqTest.Join.cs      |   110 +-
 .../Cache/Query/Linq/CacheLinqTest.Misc.cs      |    11 +-
 .../Cache/Query/Linq/CacheLinqTest.Strings.cs   |    26 +
 .../Cache/Query/Linq/CacheLinqTestSimpleName.cs |     2 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |    13 +-
 .../Client/Cache/BinaryBuilderTest.cs           |   118 +
 .../Client/Cache/CacheTest.cs                   |   900 ++
 .../Client/Cache/CacheTestKeepBinary.cs         |   499 +
 .../Client/Cache/CacheTestNoMeta.cs             |   129 +
 .../Cache/ClientCacheConfigurationTest.cs       |   211 +
 .../Client/Cache/CreateCacheTest.cs             |   208 +
 .../Client/Cache/EmptyObject.cs                 |    54 +
 .../Client/Cache/LinqTest.cs                    |   117 +
 .../Client/Cache/Person.cs                      |    77 +
 .../Client/Cache/ScanQueryTest.cs               |   339 +
 .../Client/Cache/SqlQueryTest.cs                |   227 +
 .../Client/Cache/SqlQueryTestBase.cs            |    68 +
 .../Client/ClientConnectionTest.cs              |   175 +
 .../Client/ClientTestBase.cs                    |   181 +
 .../Client/IgniteClientConfigurationTest.cs     |    42 +
 .../Client/RawSocketTest.cs                     |   221 +
 .../Compute/AbstractTaskTest.cs                 |     2 -
 .../Compute/BinarizableClosureTaskTest.cs       |     1 -
 .../Compute/ComputeApiTest.JavaTask.cs          |   582 +
 .../Compute/ComputeApiTest.cs                   |   577 +-
 .../Compute/ComputeApiTestFullFooter.cs         |     2 +
 .../Config/Dynamic/dynamic-data.xml             |     2 +
 .../Config/cache-default.xml                    |    56 +
 .../Config/cache-query.xml                      |     6 +
 .../Config/full-config.xml                      |   157 +
 .../Config/spring-test.xml                      |    18 +-
 .../ConsoleRedirectTest.cs                      |    74 +-
 .../DataStructures/AtomicLongTest.cs            |     2 +-
 .../DataStructures/AtomicReferenceTest.cs       |     2 +-
 .../DataStructures/AtomicSequenceTest.cs        |     2 +-
 .../Dataload/DataStreamerTest.cs                |   170 +-
 .../Apache.Ignite.Core.Tests/DeploymentTest.cs  |   168 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |     7 +-
 .../EventsTestLocalListeners.cs                 |   187 +
 .../Examples/Example.cs                         |    19 +-
 .../Examples/ExamplesTest.cs                    |    42 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |     2 +
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |    18 +-
 .../IgniteConfigurationSerializerTest.cs        |   370 +-
 .../IgniteConfigurationTest.cs                  |   344 +-
 .../IgniteManagerTest.cs                        |    10 +-
 .../IgniteStartStopTest.cs                      |    12 +-
 .../Log/CustomLoggerTest.cs                     |     8 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |   131 +-
 .../MultiAppDomainTest.cs                       |   171 +
 .../Plugin/PluginTest.cs                        |     1 -
 .../Plugin/TestIgnitePluginConfiguration.cs     |     1 -
 .../Process/ListDataReader.cs                   |    52 +
 .../ProjectFilesTest.cs                         |    18 +-
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Services/ServicesAsyncWrapper.cs            |    28 +-
 .../Services/ServicesTest.cs                    |   273 +-
 .../TestUtils.Common.cs                         |   366 +
 .../TestUtils.Windows.cs                        |   120 +
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   406 -
 .../Apache.Ignite.Core.csproj                   |   112 +-
 .../Apache.Ignite.Core.nuspec                   |     7 +-
 .../Binary/BinaryConfiguration.cs               |    46 +-
 .../Affinity/AffinityKeyMappedAttribute.cs      |    25 +-
 .../Cache/CachePartialUpdateException.cs        |     9 +-
 .../Cache/Configuration/CacheConfiguration.cs   |   250 +-
 .../Configuration/CacheKeyConfiguration.cs      |    84 +
 .../Cache/Configuration/DataPageEvictionMode.cs |     3 +
 .../Cache/Configuration/MemoryConfiguration.cs  |     7 +-
 .../Configuration/MemoryPolicyConfiguration.cs  |     8 +-
 .../Cache/Configuration/QueryEntity.cs          |    97 +-
 .../Cache/Configuration/QueryField.cs           |    45 +
 .../Cache/Configuration/QueryIndex.cs           |    50 +-
 .../Configuration/QuerySqlFieldAttribute.cs     |    20 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |     9 +-
 .../Apache.Ignite.Core/Cache/IMemoryMetrics.cs  |     6 +-
 .../Cache/Query/IFieldsQueryCursor.cs           |    34 +
 .../Apache.Ignite.Core/Cache/Query/ScanQuery.cs |     2 +-
 .../Cache/Query/SqlFieldsQuery.cs               |    17 +-
 .../Client/Cache/CacheClientConfiguration.cs    |   420 +
 .../Client/Cache/ICacheClient.cs                |   254 +
 .../Client/ClientStatusCode.cs                  |    57 +
 .../Apache.Ignite.Core/Client/IIgniteClient.cs  |   103 +
 .../Client/IgniteClientConfiguration.cs         |   104 +
 .../Client/IgniteClientException.cs             |   116 +
 .../Apache.Ignite.Core/Common/IgniteGuid.cs     |    31 +-
 .../Configuration/CheckpointWriteOrder.cs       |    37 +
 .../ClientConnectorConfiguration.cs             |   159 +
 .../Configuration/DataPageEvictionMode.cs       |    59 +
 .../Configuration/DataRegionConfiguration.cs    |   222 +
 .../Configuration/DataStorageConfiguration.cs   |   473 +
 .../Configuration/SqlConnectorConfiguration.cs  |     2 +
 .../Apache.Ignite.Core/Configuration/WalMode.cs |    45 +
 .../Datastream/DataStreamerDefaults.cs          |    46 +
 .../Datastream/IDataStreamer.cs                 |    21 +-
 .../Datastream/StreamTransformer.cs             |     6 +-
 .../Datastream/StreamVisitor.cs                 |     6 +-
 .../Apache.Ignite.Core/Events/JobEvent.cs       |     6 +-
 .../Events/LocalEventListener.cs                |    79 +
 .../Apache.Ignite.Core/Events/TaskEvent.cs      |     4 +-
 .../Apache.Ignite.Core/IDataRegionMetrics.cs    |    55 +
 .../Apache.Ignite.Core/IDataStorageMetrics.cs   |    87 +
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |    38 +-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |   281 +-
 .../IgniteConfigurationSection.xsd              |   488 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |    51 +-
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |    19 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |   137 +-
 .../Impl/Binary/BinaryObjectSchemaSerializer.cs |    12 +-
 .../Impl/Binary/BinaryProcessor.cs              |   157 +-
 .../Impl/Binary/BinaryProcessorClient.cs        |   112 +
 .../Impl/Binary/BinaryReader.cs                 |   110 +-
 .../Impl/Binary/BinaryReaderExtensions.cs       |    76 +-
 .../Impl/Binary/BinaryReflectiveActions.cs      |    16 +
 .../Binary/BinarySurrogateTypeDescriptor.cs     |     8 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |   184 +-
 .../Impl/Binary/BinaryTypeId.cs                 |   228 +
 .../Impl/Binary/BinaryUtils.cs                  |   256 +-
 .../Impl/Binary/BinaryWriter.cs                 |   168 +-
 .../Impl/Binary/BinaryWriterExtensions.cs       |    41 +-
 .../Impl/Binary/IBinaryProcessor.cs             |    73 +
 .../Impl/Binary/IBinaryRawWriteAware.cs         |    42 +
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |     6 +-
 .../Impl/Binary/Io/BinaryHeapStream.cs          |  1018 +-
 .../Impl/Binary/Io/BinaryStreamBase.cs          |  1249 --
 .../Impl/Binary/Marshaller.cs                   |   107 +-
 .../Impl/Binary/Metadata/BinaryType.cs          |    86 +-
 .../Impl/Binary/MultidimensionalArrayHolder.cs  |   132 +
 .../Binary/MultidimensionalArraySerializer.cs   |    48 +
 .../Impl/Binary/ReflectionUtils.cs              |    27 +
 .../Impl/Binary/SerializableSerializer.cs       |    29 +-
 .../Impl/Binary/Structure/BinaryStructure.cs    |   147 +-
 .../Binary/Structure/BinaryStructureTracker.cs  |    16 +-
 .../Impl/Binary/TypeResolver.cs                 |     2 +-
 .../Impl/Cache/CacheAffinityImpl.cs             |     2 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheEntry.cs |    31 +-
 .../Impl/Cache/CacheEntryFilterHolder.cs        |     2 +-
 .../Impl/Cache/CacheEntryProcessorHolder.cs     |     4 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |    83 +-
 .../Impl/Cache/ICacheInternal.cs                |     6 +
 .../Impl/Cache/MemoryMetrics.cs                 |     2 +
 .../Impl/Cache/Query/AbstractQueryCursor.cs     |   264 -
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |    31 +-
 .../Impl/Cache/Query/PlatformQueryQursorBase.cs |    88 +
 .../Impl/Cache/Query/QueryCursor.cs             |    18 +-
 .../Impl/Cache/Query/QueryCursorBase.cs         |   309 +
 .../Impl/Cache/Store/CacheStoreInternal.cs      |    14 +-
 .../Impl/Client/Cache/CacheClient.cs            |   622 +
 .../Impl/Client/Cache/CacheFlags.cs             |    38 +
 .../Cache/ClientCacheConfigurationSerializer.cs |   261 +
 .../Cache/Query/ClientFieldsQueryCursor.cs      |    79 +
 .../Client/Cache/Query/ClientQueryCursor.cs     |    46 +
 .../Client/Cache/Query/ClientQueryCursorBase.cs |    89 +
 .../Impl/Client/Cache/Query/StatementType.cs    |    42 +
 .../Apache.Ignite.Core/Impl/Client/ClientOp.cs  |    72 +
 .../Impl/Client/ClientProtocolVersion.cs        |   119 +
 .../Impl/Client/ClientSocket.cs                 |   286 +
 .../Impl/Client/IgniteClient.cs                 |   249 +
 .../Impl/Cluster/ClusterGroupImpl.cs            |    57 +-
 .../Apache.Ignite.Core/Impl/Common/Classpath.cs |    52 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |    22 +-
 .../Impl/Common/IgniteHome.cs                   |     8 +-
 .../Impl/Compute/Closure/ComputeActionJob.cs    |     4 +-
 .../Impl/Compute/Closure/ComputeFuncJob.cs      |     6 +-
 .../Impl/Compute/Closure/ComputeOutFuncJob.cs   |     4 +-
 .../Closure/ComputeReducingClosureTask.cs       |     2 +-
 .../Compute/Closure/IComputeResourceInjector.cs |     2 +-
 .../Impl/Compute/ComputeFunc.cs                 |     2 +-
 .../Impl/Compute/ComputeImpl.cs                 |     2 +-
 .../Impl/Compute/ComputeJob.cs                  |     2 +-
 .../Impl/Compute/ComputeJobHolder.cs            |    21 +-
 .../Impl/Compute/ComputeOutFunc.cs              |     2 +-
 .../Impl/DataRegionMetrics.cs                   |    61 +
 .../Impl/DataStorageMetrics.cs                  |    87 +
 .../Impl/Datastream/DataStreamerBatch.cs        |    10 +-
 .../Impl/Datastream/DataStreamerImpl.cs         |    45 +-
 .../Impl/Deployment/PeerAssemblyResolver.cs     |    17 +-
 .../Impl/Deployment/PeerLoadingExtensions.cs    |     4 +-
 .../Impl/Deployment/PeerLoadingObjectHolder.cs  |     4 +-
 .../Apache.Ignite.Core/Impl/Events/Events.cs    |    33 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    43 +-
 .../Apache.Ignite.Core/Impl/IIgniteInternal.cs  |    80 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |    47 +-
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |    91 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   302 +-
 .../Apache.Ignite.Core/Impl/MemoryInfo.cs       |   110 +
 .../Impl/Messaging/MessageListenerHolder.cs     |     4 +-
 .../Apache.Ignite.Core/Impl/NativeMethods.cs    |    93 -
 .../PersistentStore/PersistentStoreMetrics.cs   |     2 +
 .../Impl/PlatformJniTarget.cs                   |   254 +-
 .../Impl/PlatformTargetAdapter.cs               |    13 +-
 .../Impl/Resource/ResourceProcessor.cs          |     2 +-
 .../Impl/Resource/ResourceTypeDescriptor.cs     |     2 +-
 .../Impl/Services/ServiceProxySerializer.cs     |    62 +-
 .../Impl/Services/Services.cs                   |   112 +-
 .../dotnet/Apache.Ignite.Core/Impl/Shell.cs     |    65 +
 .../Impl/Unmanaged/IUnmanagedTarget.cs          |    42 -
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |    96 -
 .../Impl/Unmanaged/Jni/AppDomains.cs            |   135 +
 .../Impl/Unmanaged/Jni/CallbackDelegates.cs     |    52 +
 .../Impl/Unmanaged/Jni/Callbacks.cs             |   292 +
 .../Impl/Unmanaged/Jni/ConsoleWriter.cs         |    47 +
 .../Impl/Unmanaged/Jni/DllLoader.cs             |   210 +
 .../Impl/Unmanaged/Jni/Env.cs                   |   505 +
 .../Impl/Unmanaged/Jni/EnvDelegates.cs          |   109 +
 .../Impl/Unmanaged/Jni/EnvInterface.cs          |   263 +
 .../Impl/Unmanaged/Jni/GlobalRef.cs             |    87 +
 .../Impl/Unmanaged/Jni/JniResult.cs             |    35 +
 .../Impl/Unmanaged/Jni/Jvm.cs                   |   299 +
 .../Impl/Unmanaged/Jni/JvmDelegates.cs          |    31 +
 .../Impl/Unmanaged/Jni/JvmDll.cs                |   414 +
 .../Impl/Unmanaged/Jni/JvmInitArgs.cs           |    33 +
 .../Impl/Unmanaged/Jni/JvmInterface.cs          |    40 +
 .../Impl/Unmanaged/Jni/JvmOption.cs             |    34 +
 .../Impl/Unmanaged/Jni/MethodId.cs              |   157 +
 .../Impl/Unmanaged/Jni/NativeMethod.cs          |    48 +
 .../Apache.Ignite.Core/Impl/Unmanaged/Os.cs     |    72 +
 .../Impl/Unmanaged/UnmanagedCallbackHandlers.cs |    38 -
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |     3 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   307 +-
 .../Impl/Unmanaged/UnmanagedContext.cs          |    53 -
 .../Unmanaged/UnmanagedNonReleaseableTarget.cs  |    70 -
 .../Impl/Unmanaged/UnmanagedTarget.cs           |    77 -
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   252 +-
 .../dotnet/Apache.Ignite.Core/NuGet/Install.ps1 |     2 +-
 .../Apache.Ignite.Core/NuGet/PostBuild.ps1      |     6 +-
 .../Apache.Ignite.Core/NuGet/Uninstall.ps1      |     2 +-
 .../PersistentStore/CheckpointWriteOrder.cs     |    40 +
 .../PersistentStore/IPersistentStoreMetrics.cs  |     2 +
 .../PersistentStoreConfiguration.cs             |    35 +-
 .../PersistentStore/WalMode.cs                  |     3 +
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Resource/InstanceResourceAttribute.cs       |     3 +-
 .../Apache.Ignite.Core/Services/IServices.cs    |    32 +
 .../Services/ServiceConfiguration.cs            |    70 +-
 .../Services/ServiceDeploymentException.cs      |   143 +
 .../Services/ServiceInvocationException.cs      |     9 +-
 .../dotnet/Apache.Ignite.Core/build-common.ps1  |    77 -
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Apache.Ignite.EntityFramework.csproj        |     3 +-
 .../Apache.Ignite.EntityFramework.nuspec        |     4 +
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Apache.Ignite.Linq.csproj                   |     3 +-
 .../Apache.Ignite.Linq.nuspec                   |     5 +
 .../CacheClientLinqExtensions.cs                |   131 +
 .../Apache.Ignite.Linq/CacheExtensions.cs       |   195 -
 .../Apache.Ignite.Linq/CacheLinqExtensions.cs   |   197 +
 .../Apache.Ignite.Linq/ICacheQueryable.cs       |     1 +
 .../Impl/CacheFieldsQueryExecutor.cs            |     3 +-
 .../Impl/CacheFieldsQueryProvider.cs            |     2 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |     5 +
 .../Impl/CacheQueryModelVisitor.cs              |    28 +-
 .../Apache.Ignite.Linq/Impl/CacheQueryable.cs   |     8 +-
 .../Impl/CacheQueryableBase.cs                  |     1 +
 .../Apache.Ignite.Linq/Impl/MethodVisitor.cs    |    59 +-
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../dotnet/Apache.Ignite.Linq/QueryOptions.cs   |    13 +
 .../Apache.Ignite.Log4Net.csproj                |     4 +-
 .../Apache.Ignite.Log4Net.nuspec                |     4 +
 .../Properties/AssemblyInfo.cs                  |     6 +-
 .../Apache.Ignite.NLog.nuspec                   |     4 +
 .../Properties/AssemblyInfo.cs                  |     6 +-
 modules/platforms/dotnet/Apache.Ignite.ndproj   | 11141 +++++++++++++++++
 modules/platforms/dotnet/Apache.Ignite.sln      |   143 -
 .../dotnet/Apache.Ignite.sln.DotSettings        |     2 +
 .../dotnet/Apache.Ignite/IgniteRunner.cs        |     9 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |     6 +-
 modules/platforms/dotnet/DEVNOTES.txt           |    15 +-
 modules/platforms/dotnet/README.md              |   241 +-
 modules/platforms/dotnet/build.ps1              |   134 +-
 modules/platforms/dotnet/docfx/.gitignore       |     9 +
 .../dotnet/docfx/Apache.Ignite.docfx.json       |    88 +
 modules/platforms/dotnet/docfx/README.txt       |     2 +
 modules/platforms/dotnet/docfx/api/index.md     |     5 +
 modules/platforms/dotnet/docfx/filterConfig.yml |    19 +
 .../platforms/dotnet/docfx/generate-docs.cmd    |     1 +
 .../platforms/dotnet/docfx/images/favicon.ico   |   Bin 0 -> 1150 bytes
 .../dotnet/docfx/images/logo_ignite_32_32.png   |   Bin 0 -> 1676 bytes
 modules/platforms/dotnet/docfx/index.md         |    10 +
 modules/platforms/dotnet/docfx/toc.yml          |    19 +
 .../Apache.Ignite.Examples.csproj               |     2 +
 .../Datagrid/BinaryModeExample.cs               |    11 +-
 .../Datagrid/EntryProcessorExample.cs           |     4 +
 .../Datagrid/MultiTieredCacheExample.cs         |     2 -
 .../Datagrid/QueryDmlExample.cs                 |     5 +-
 .../Misc/LifecycleExample.cs                    |     1 -
 .../ThinClient/ThinClientPutGetExample.cs       |    92 +
 .../ThinClient/ThinClientQueryExample.cs        |   147 +
 modules/platforms/dotnet/examples/README.txt    |     2 +
 .../dotnetcore/Apache.Ignite.Examples.csproj    |    29 +
 .../dotnet/examples/dotnetcore/App.config       |    41 +
 .../dotnet/examples/dotnetcore/Employee.cs      |    67 +
 .../dotnet/examples/dotnetcore/LinqExample.cs   |   239 +
 .../dotnet/examples/dotnetcore/Organization.cs  |    58 +
 .../dotnet/examples/dotnetcore/Program.cs       |   109 +
 .../dotnet/examples/dotnetcore/PutGetExample.cs |   122 +
 .../dotnet/examples/dotnetcore/README.txt       |     8 +
 .../dotnet/examples/dotnetcore/SqlExample.cs    |   191 +
 .../dotnet/run-dotnetcore-examples.bat          |    27 +
 modules/rest-http/pom.xml                       |     2 +-
 .../http/jetty/GridJettyObjectMapper.java       |     3 +
 .../http/jetty/GridJettyRestHandler.java        |    49 +-
 .../rest/protocols/http/jetty/favicon.ico       |   Bin 1406 -> 1150 bytes
 modules/rocketmq/pom.xml                        |     2 +-
 modules/scalar-2.10/pom.xml                     |     2 +-
 modules/scalar/pom.xml                          |     2 +-
 modules/schedule/pom.xml                        |     2 +-
 modules/slf4j/pom.xml                           |     2 +-
 .../apache/ignite/logger/slf4j/Slf4jLogger.java |     6 +
 modules/spark-2.10/pom.xml                      |     2 +-
 modules/spark/pom.xml                           |     2 +-
 .../org/apache/ignite/spark/IgniteContext.scala |     6 +-
 .../ignite/testsuites/IgniteRDDTestSuite.java   |     2 +-
 .../org/apache/ignite/spark/IgniteRDDSpec.scala |    11 +-
 modules/spring-data/pom.xml                     |     9 +-
 modules/spring/pom.xml                          |     2 +-
 .../org/apache/ignite/IgniteSpringBean.java     |    59 +-
 .../GridSpringBeanSerializationSelfTest.java    |     4 +-
 .../ignite/internal/IgniteSpringBeanTest.java   |     2 +-
 .../GridServiceInjectionSpringResourceTest.java |    10 +-
 ...teSpringBeanSpringResourceInjectionTest.java |   215 +
 .../ignite/spring/injection/spring-bean.xml     |    84 +
 .../testsuites/IgniteSpringTestSuite.java       |     2 +
 modules/sqlline/bin/sqlline.bat                 |   112 +
 modules/sqlline/bin/sqlline.sh                  |    54 +
 modules/sqlline/licenses/apache-2.0.txt         |   202 +
 modules/sqlline/pom.xml                         |    81 +
 modules/ssh/pom.xml                             |     2 +-
 modules/storm/pom.xml                           |     2 +-
 modules/tools/pom.xml                           |     2 +-
 .../ant/beautifier/GridJavadocAntTask.java      |     8 +-
 modules/twitter/pom.xml                         |     2 +-
 modules/urideploy/pom.xml                       |     2 +-
 modules/visor-console-2.10/pom.xml              |     2 +-
 modules/visor-console/pom.xml                   |     2 +-
 .../ignite/visor/commands/VisorConsole.scala    |    28 +-
 .../commands/alert/VisorAlertCommand.scala      |    29 +-
 .../commands/cache/VisorCacheCommand.scala      |   192 +-
 .../cache/VisorCacheRebalanceCommand.scala      |   134 +
 .../commands/common/VisorConsoleCommand.scala   |     5 +-
 .../config/VisorConfigurationCommand.scala      |    31 +-
 .../visor/commands/open/VisorOpenCommand.scala  |    34 +-
 .../commands/tasks/VisorTasksCommand.scala      |    33 +-
 .../commands/top/VisorTopologyCommand.scala     |   111 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   184 +-
 .../ignite/visor/VisorRuntimeBaseSpec.scala     |     9 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |    44 +-
 .../top/VisorActivationCommandSpec.scala        |    70 +
 .../testsuites/VisorConsoleSelfTestSuite.scala  |     3 +-
 modules/visor-plugins/pom.xml                   |     2 +-
 modules/web-console/.gitignore                  |    11 +-
 modules/web-console/DEVNOTES.txt                |    39 +-
 modules/web-console/assembly/README.txt         |    60 +
 modules/web-console/assembly/direct-install.xml |    91 +
 modules/web-console/backend/.eslintrc           |   185 -
 modules/web-console/backend/.gitignore          |     6 -
 modules/web-console/backend/app/agentSocket.js  |    16 +-
 .../web-console/backend/app/agentsHandler.js    |    86 +-
 modules/web-console/backend/app/apiServer.js    |    81 +-
 .../web-console/backend/app/browsersHandler.js  |   453 +-
 modules/web-console/backend/app/configure.js    |    14 +-
 modules/web-console/backend/app/mongo.js        |   156 +-
 modules/web-console/backend/app/mongoose.js     |     8 +-
 modules/web-console/backend/app/nconf.js        |    38 +-
 modules/web-console/backend/app/routes.js       |    26 +-
 modules/web-console/backend/app/settings.js     |    86 +-
 .../backend/config/settings.json.sample         |     8 +-
 .../ignite_modules/migrations/README.txt        |     4 +
 modules/web-console/backend/index.js            |    74 +-
 modules/web-console/backend/injector.js         |     4 +-
 modules/web-console/backend/middlewares/api.js  |     5 +
 .../1508395969410-init-registered-date.js       |    33 +
 .../web-console/backend/migrations/README.txt   |     4 +
 modules/web-console/backend/package.json        |    32 +-
 .../web-console/backend/routes/activities.js    |    37 +-
 modules/web-console/backend/routes/admin.js     |    13 +-
 modules/web-console/backend/routes/caches.js    |     6 +-
 modules/web-console/backend/routes/clusters.js  |     6 +-
 .../web-console/backend/routes/configuration.js |     6 +-
 modules/web-console/backend/routes/demo.js      |     7 +-
 .../backend/routes/demo/domains.json            |     5 +
 modules/web-console/backend/routes/domains.js   |     6 +-
 modules/web-console/backend/routes/downloads.js |     6 +-
 modules/web-console/backend/routes/igfss.js     |     6 +-
 modules/web-console/backend/routes/notebooks.js |     7 +-
 modules/web-console/backend/routes/profile.js   |    10 +-
 modules/web-console/backend/routes/public.js    |     9 +-
 modules/web-console/backend/services/Utils.js   |    51 +
 .../web-console/backend/services/activities.js  |     7 +-
 modules/web-console/backend/services/auth.js    |    27 +-
 modules/web-console/backend/services/caches.js  |    11 +-
 .../web-console/backend/services/clusters.js    |    11 +-
 .../backend/services/configurations.js          |     5 +-
 modules/web-console/backend/services/domains.js |    11 +-
 .../web-console/backend/services/downloads.js   |    13 +-
 modules/web-console/backend/services/igfss.js   |    11 +-
 modules/web-console/backend/services/mails.js   |    89 +-
 .../web-console/backend/services/notebooks.js   |    11 +-
 .../backend/services/notifications.js           |     5 +-
 .../web-console/backend/services/sessions.js    |     5 +-
 modules/web-console/backend/services/users.js   |    31 +-
 .../compose/frontend/nginx/web-console.conf     |     1 -
 .../docker/standalone/nginx/web-console.conf    |     1 -
 modules/web-console/frontend/.eslintrc          |     2 +-
 modules/web-console/frontend/.gitignore         |     8 +-
 modules/web-console/frontend/app/app.js         |    46 +-
 .../frontend/app/browserUpdate/index.js         |    34 +
 .../frontend/app/browserUpdate/style.scss       |    36 +
 .../app/components/bs-select-menu/style.scss    |    14 +-
 .../app/components/bs-select-menu/template.pug  |    15 +-
 .../cluster-select/cluster-select.controller.js |    64 -
 .../cluster-select/cluster-select.pug           |    47 -
 .../cluster-select/cluster-select.scss          |    30 -
 .../app/components/cluster-select/index.js      |    29 -
 .../components/cluster-selector/component.js    |    25 +
 .../components/cluster-selector/controller.js   |    62 +
 .../app/components/cluster-selector/index.js    |    23 +
 .../app/components/cluster-selector/style.scss  |    66 +
 .../components/cluster-selector/template.pug    |    75 +
 .../components/connected-clusters/controller.js |    36 +
 .../app/components/connected-clusters/index.js  |    29 +
 .../components/connected-clusters/style.scss    |    40 +
 .../components/connected-clusters/template.pug  |    18 +
 .../app/components/grid-export/component.js     |    52 +
 .../app/components/grid-export/index.js         |    24 +
 .../app/components/grid-export/template.pug     |    18 +
 .../components/grid-item-selected/controller.js |     3 +
 .../app/components/grid-no-data/component.js    |    33 +
 .../app/components/grid-no-data/controller.js   |    50 +
 .../app/components/grid-no-data/index.js        |    24 +
 .../app/components/grid-no-data/style.scss      |    31 +
 .../app/components/ignite-icon/directive.js     |    10 +-
 .../app/components/ignite-icon/index.js         |     2 +
 .../app/components/ignite-icon/service.js       |    32 +
 .../app/components/list-editable/component.js   |    36 +
 .../list-editable-cols/cols.directive.js        |    79 +
 .../list-editable-cols/cols.style.scss          |    51 +
 .../list-editable-cols/cols.template.pug        |    28 +
 .../components/list-editable-cols/index.js      |    28 +
 .../list-editable-cols/row.directive.js         |    40 +
 .../app/components/list-editable/controller.js  |    79 +
 .../app/components/list-editable/index.js       |    27 +
 .../app/components/list-editable/style.scss     |   132 +
 .../app/components/list-editable/template.pug   |    51 +
 .../list-of-registered-users.column-defs.js     |    49 +-
 .../list-of-registered-users.controller.js      |    23 +-
 .../list-of-registered-users.tpl.pug            |     2 +-
 .../components/pcbScaleNumber.js                |     1 +
 .../page-configure-basic/controller.js          |    10 +-
 .../mixins/pcb-form-field-size.pug              |     1 +
 .../components/page-queries/Notebook.data.js    |   168 +
 .../components/page-queries/Notebook.service.js |    74 +
 .../app/components/page-queries/controller.js   |  1935 +++
 .../app/components/page-queries/index.js        |    62 +
 .../page-queries/notebook.controller.js         |    62 +
 .../app/components/page-queries/style.scss      |    91 +
 .../components/page-queries/template.tpl.pug    |   410 +
 .../app/components/ui-grid-filters/directive.js |    62 +
 .../app/components/ui-grid-filters/index.js     |    43 +
 .../app/components/ui-grid-filters/style.scss   |    36 +
 .../app/components/ui-grid-filters/template.pug |    47 +
 .../app/components/version-picker/index.js      |     2 +-
 .../web-console-footer-links/component.js       |    23 +
 .../web-console-footer-links/style.scss         |    31 +
 .../web-console-footer-links/template.pug       |    17 +
 .../app/components/web-console-footer/index.js  |     4 +-
 .../components/web-console-footer/style.scss    |     8 +-
 .../components/web-console-footer/template.pug  |     1 +
 .../components/web-console-header/component.js  |    11 +
 .../web-console-header-extension/component.js   |    22 +
 .../web-console-header-extension/template.pug   |    15 +
 .../app/components/web-console-header/index.js  |     4 +-
 .../components/web-console-header/style.scss    |    57 +-
 .../components/web-console-header/template.pug  |    19 +-
 .../frontend/app/core/admin/Admin.data.js       |    12 +-
 .../frontend/app/data/getting-started.json      |    13 +
 .../app/directives/information/information.pug  |     2 +-
 .../app/directives/information/information.scss |     5 +-
 .../ui-ace-docker/ui-ace-docker.controller.js   |    26 +-
 .../ui-ace-java/ui-ace-java.controller.js       |   143 +-
 .../ui-ace-pojos/ui-ace-pojos.controller.js     |   148 +-
 .../ui-ace-pom/ui-ace-pom.controller.js         |    26 +-
 .../ui-ace-sharp/ui-ace-sharp.controller.js     |    12 +-
 .../ui-ace-spring/ui-ace-spring.controller.js   |   139 +-
 .../frontend/app/filters/duration.filter.js     |     2 +-
 .../helpers/jade/form/form-field-dropdown.pug   |     2 +-
 .../frontend/app/helpers/jade/mixins.pug        |    11 +-
 .../app/modules/agent/AgentManager.service.js   |   147 +-
 .../app/modules/agent/decompress.worker.js      |    34 +
 .../app/modules/branding/branding.module.js     |     4 +-
 .../app/modules/branding/branding.provider.js   |   111 -
 .../app/modules/branding/branding.service.js    |    47 +
 .../modules/configuration/Version.service.js    |   169 -
 .../configuration/configuration.module.js       |     4 -
 .../generator/AbstractTransformer.js            |    24 +-
 .../generator/ConfigurationGenerator.js         |   298 +-
 .../generator/JavaTransformer.service.js        |    10 +-
 .../configuration/generator/Maven.service.js    |     2 +-
 .../generator/PlatformGenerator.js              |     6 +-
 .../generator/SpringTransformer.service.js      |     2 +-
 .../generator/defaults/Cache.service.js         |    14 +-
 .../generator/defaults/Cluster.service.js       |    41 +
 .../app/modules/dialog/dialog.controller.js     |    26 +-
 .../app/modules/form/field/down.directive.js    |    16 +-
 .../app/modules/form/field/input/text.scss      |     1 +
 .../app/modules/form/field/up.directive.js      |    14 +-
 .../app/modules/form/group/add.directive.js     |    24 +-
 .../app/modules/form/group/tooltip.directive.js |    24 +-
 .../app/modules/navbar/userbar.directive.js     |    32 +-
 .../frontend/app/modules/sql/Notebook.data.js   |   168 -
 .../app/modules/sql/Notebook.service.js         |    74 -
 .../app/modules/sql/notebook.controller.js      |    62 -
 .../frontend/app/modules/sql/sql.controller.js  |  1786 ---
 .../frontend/app/modules/sql/sql.module.js      |    61 -
 .../app/modules/states/configuration.state.js   |     1 +
 .../states/configuration/caches/general.pug     |    23 +-
 .../states/configuration/caches/memory.pug      |    18 +-
 .../states/configuration/caches/store.pug       |     6 +-
 .../configuration/clusters/attributes.pug       |     4 +-
 .../configuration/clusters/client-connector.pug |    59 +
 .../clusters/collision/job-stealing.pug         |     4 +-
 .../states/configuration/clusters/connector.pug |     2 +-
 .../configuration/clusters/data-storage.pug     |   261 +
 .../states/configuration/clusters/memory.pug    |     6 +-
 .../configuration/clusters/persistence.pug      |     4 +-
 .../configuration/clusters/sql-connector.pug    |     4 +-
 .../states/configuration/clusters/swap.pug      |     2 +-
 .../states/configuration/domains/general.pug    |     4 +-
 .../states/configuration/domains/query.pug      |    15 +-
 .../states/configuration/domains/store.pug      |     2 +-
 .../frontend/app/modules/user/permissions.js    |     4 +-
 .../frontend/app/modules/user/user.module.js    |     7 +-
 .../frontend/app/primitives/btn/index.scss      |    17 +
 .../app/primitives/form-field/index.scss        |    17 +-
 .../frontend/app/primitives/switcher/index.pug  |     2 +-
 .../frontend/app/primitives/switcher/index.scss |    69 +-
 .../app/primitives/ui-grid-settings/index.scss  |    12 +
 .../frontend/app/primitives/ui-grid/index.scss  |     7 +
 .../frontend/app/services/Clusters.js           |     6 +
 .../frontend/app/services/JavaTypes.service.js  |    15 +
 .../app/services/LegacyTable.service.js         |     6 +-
 .../app/services/LegacyUtils.service.js         |    34 +-
 .../frontend/app/services/Messages.service.js   |    14 +-
 .../frontend/app/services/Version.service.js    |   179 +
 .../frontend/app/services/Version.spec.js       |   106 +
 .../web-console/frontend/app/services/index.js  |    23 +
 .../frontend/app/utils/SimpleWorkerPool.js      |   120 +
 .../frontend/controllers/clusters-controller.js |    69 +-
 .../frontend/controllers/domains-controller.js  |    31 +-
 modules/web-console/frontend/package.json       |    47 +-
 .../frontend/public/images/checkbox-active.svg  |    25 +
 .../frontend/public/images/checkbox.svg         |    22 +
 .../frontend/public/images/icons/alert.svg      |     1 +
 .../frontend/public/images/icons/attention.svg  |     3 +
 .../frontend/public/images/icons/checkmark.svg  |     3 +
 .../public/images/icons/connectedClusters.svg   |     1 +
 .../frontend/public/images/icons/index.js       |     7 +
 .../frontend/public/images/icons/info.svg       |     3 +
 .../frontend/public/images/icons/refresh.svg    |     1 +
 .../frontend/public/images/icons/sort.svg       |     1 +
 .../frontend/public/images/multicluster.png     |   Bin 0 -> 21921 bytes
 .../frontend/public/stylesheets/style.scss      |    22 +
 .../frontend/test/unit/Version.test.js          |   106 -
 modules/web-console/frontend/tsconfig.json      |    12 +
 .../views/configuration/clusters.tpl.pug        |    14 +-
 .../views/configuration/domains-import.tpl.pug  |     6 +
 .../frontend/views/includes/header-left.pug     |     8 +-
 .../frontend/views/includes/header-right.pug    |     8 +-
 modules/web-console/frontend/views/index.pug    |    10 +-
 .../frontend/views/settings/profile.tpl.pug     |     9 +-
 .../web-console/frontend/views/signin.tpl.pug   |     6 +
 .../web-console/frontend/views/sql/sql.tpl.pug  |   288 -
 .../frontend/views/templates/message.tpl.pug    |     1 +
 .../frontend/webpack/webpack.common.js          |     4 +-
 .../frontend/webpack/webpack.dev.babel.js       |     5 +-
 modules/web-console/pom.xml                     |   204 +-
 .../web-agent/bin/ignite-web-agent.bat          |    19 +
 .../web-agent/bin/ignite-web-agent.sh           |     5 +
 modules/web-console/web-agent/pom.xml           |     2 +-
 .../agent/db/dialect/OracleMetadataDialect.java |    13 +-
 .../agent/handlers/AbstractListener.java        |    27 +
 .../console/agent/handlers/ClusterListener.java |   184 +-
 .../ignite/console/agent/rest/RestExecutor.java |   264 +-
 .../ignite/console/agent/rest/RestResult.java   |    25 +-
 .../ignite/console/demo/AgentClusterDemo.java   |    41 +-
 .../ignite/console/demo/AgentMetadataDemo.java  |     7 +
 .../demo/service/DemoCachesLoadService.java     |     3 +-
 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      |    12 +-
 .../internal/websession/WebSessionSelfTest.java |     2 +
 modules/yardstick/DEVNOTES-standalone.txt       |    11 +-
 modules/yardstick/DEVNOTES.txt                  |    11 +
 .../config/benchmark-bin-identity.properties    |     1 +
 .../config/benchmark-cache-load.properties      |     1 +
 .../config/benchmark-client-mode.properties     |     1 +
 .../config/benchmark-failover.properties        |     1 +
 .../yardstick/config/benchmark-full.properties  |     1 +
 .../yardstick/config/benchmark-h2.properties    |     1 +
 .../yardstick/config/benchmark-ml.properties    |    90 +
 .../config/benchmark-multicast.properties       |     1 +
 .../yardstick/config/benchmark-mysql.properties |     1 +
 .../yardstick/config/benchmark-pgsql.properties |     1 +
 .../config/benchmark-put-indexed-val.properties |     1 +
 .../benchmark-query-put-separated.properties    |     1 +
 .../yardstick/config/benchmark-query.properties |     1 +
 .../config/benchmark-remote.properties          |     1 +
 .../config/benchmark-sql-dml.properties         |     1 +
 .../yardstick/config/benchmark-store.properties |     1 +
 modules/yardstick/config/benchmark.properties   |     1 +
 modules/yardstick/pom-standalone.xml            |    58 +-
 modules/yardstick/pom.xml                       |    58 +-
 .../yardstick/IgniteBenchmarkArguments.java     |     8 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    21 +-
 .../cache/WaitMapExchangeFinishCallable.java    |     4 +-
 .../cache/jdbc/JdbcAbstractBenchmark.java       |     4 +-
 .../yardstick/cache/jdbc/RdbmsBenchmark.java    |     6 +-
 .../apache/ignite/yardstick/ml/DataChanger.java |    65 +
 ...niteKMeansDistributedClustererBenchmark.java |    75 +
 .../IgniteKMeansLocalClustererBenchmark.java    |    50 +
 .../yardstick/ml/clustering/package-info.java   |    22 +
 .../IgniteCholeskyDecompositionBenchmark.java   |    69 +
 .../IgniteEigenDecompositionBenchmark.java      |    69 +
 .../IgniteLUDecompositionBenchmark.java         |    75 +
 ...niteSingularValueDecompositionBenchmark.java |    59 +
 .../ml/decomposition/package-info.java          |    22 +
 .../math/IgniteAbstractMatrixMulBenchmark.java  |   107 +
 ...niteDenseLocalOffHeapMatrixMulBenchmark.java |    32 +
 ...gniteDenseLocalOnHeapMatrixMulBenchmark.java |    32 +
 ...parseBlockDistributedMatrixMulBenchmark.java |    32 +
 ...niteSparseDistributedMatrixMulBenchmark.java |    35 +
 .../IgniteSparseLocalMatrixMulBenchmark.java    |    32 +
 .../ignite/yardstick/ml/math/package-info.java  |    22 +
 .../ignite/yardstick/ml/package-info.java       |    22 +
 ...iteOLSMultipleLinearRegressionBenchmark.java |    92 +
 .../yardstick/ml/regression/package-info.java   |    22 +
 .../IgniteColumnDecisionTreeGiniBenchmark.java  |    70 +
 ...niteColumnDecisionTreeVarianceBenchmark.java |    71 +
 .../yardstick/ml/trees/SplitDataGenerator.java  |   426 +
 .../ignite/yardstick/ml/trees/package-info.java |    22 +
 modules/yarn/pom.xml                            |     2 +-
 .../apache/ignite/yarn/ApplicationMaster.java   |     9 +-
 modules/zeromq/pom.xml                          |     2 +-
 modules/zookeeper/pom.xml                       |     2 +-
 parent/pom.xml                                  |    17 +
 pom.xml                                         |   182 +-
 2486 files changed, 182749 insertions(+), 46853 deletions(-)
----------------------------------------------------------------------