You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by av...@apache.org on 2020/07/03 12:45:26 UTC

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

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

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

commit d6fc9cd66460645425a7ae568a4cbf23e21b596d
Merge: 8311f0b f90bcaa
Author: Anton Vinogradov <av...@apache.org>
AuthorDate: Fri Jul 3 15:44:35 2020 +0300

    Merge branch 'master' into ignite-ducktape
    
    # Conflicts:
    #	parent/pom.xml

 .gitignore                                         |  30 +-
 LICENSE                                            |   6 +
 assembly/release-apache-ignite-base.xml            |  16 +-
 checkstyle/checkstyle.xml                          |   9 +
 .../examples/datagrid/SpatialQueryExample.java     |  14 +-
 .../ComputeClientBinaryTaskExecutionExample.java   |   2 +-
 .../binary/computegrid/ComputeClientTask.java      |   2 +-
 .../examples/client/ClientPutGetExample.java       |   4 +-
 .../examples/datagrid/DataRegionsExample.java      |   2 +-
 .../dataset/AlgorithmSpecificDatasetExample.java   |   2 +-
 .../inference/h2o/H2OMojoModelParserExample.java   |   2 +-
 ...eeClassificationTrainerSQLInferenceExample.java |  36 +-
 ...onTreeClassificationTrainerSQLTableExample.java | 109 ++-
 .../org/apache/ignite/examples/model/Address.java  |   2 +-
 .../OpenCensusMetricsExporterExample.java          |   4 +-
 .../spark/JavaIgniteDataFrameWriteExample.java     |   3 +-
 .../ignite/examples/spark/SharedRDDExample.java    |   5 +-
 .../ignite/examples/CacheExamplesSelfTest.java     |   2 +-
 idea/ignite_codeStyle.xml                          |   2 +
 .../apache/ignite/gridify/BasicAopSelfTest.java    |   5 +-
 .../ignite/spi/checkpoint/s3/S3CheckpointSpi.java  |  20 +-
 .../tcp/ipfinder/elb/TcpDiscoveryAlbIpFinder.java  |   8 +-
 .../tcp/ipfinder/elb/TcpDiscoveryElbIpFinder.java  |   9 +-
 .../spi/checkpoint/s3/S3CheckpointSpiSelfTest.java |   6 +-
 .../tcp/ipfinder/s3/client/DummyObjectListing.java |   4 +-
 .../ipfinder/s3/client/DummyObjectListingTest.java |   4 +-
 .../tcp/ipfinder/s3/client/DummyS3Client.java      |  22 +-
 .../tcp/ipfinder/s3/client/DummyS3ClientTest.java  |   6 +-
 .../internal/benchmarks/jmh/algo/BenchmarkCRC.java |   5 +-
 .../benchmarks/jmh/cache/JmhCacheBenchmark.java    |   3 +-
 .../GridDhtPartitionsStateValidatorBenchmark.java  |  11 +-
 .../benchmarks/jmh/misc/JmhIncrementBenchmark.java |   3 +-
 .../jmh/runner/JmhIdeBenchmarkRunner.java          |   3 +-
 .../jmh/sequence/JmhSequenceBenchmark.java         |   2 +-
 .../jmh/streamer/JmhStreamerAddDataBenchmark.java  |   6 +-
 .../benchmarks/jol/GridMetricsJolBenchmark.java    |   2 +-
 .../ignite/internal/benchmarks/model/IntValue.java |   9 +-
 .../stream/camel/IgniteCamelStreamerTest.java      |  14 +-
 .../store/cassandra/serializer/KryoSerializer.java |   8 +-
 .../apache/ignite/tests/KryoSerializerTest.java    |   2 -
 .../cache/store/cassandra/CassandraCacheStore.java |   8 +-
 .../store/cassandra/common/CassandraHelper.java    |   6 +-
 .../cassandra/common/PropertyMappingHelper.java    |   4 +-
 .../persistence/KeyValuePersistenceSettings.java   |   2 +-
 .../persistence/PersistenceController.java         |   7 +-
 .../cassandra/persistence/PersistenceSettings.java |  10 +-
 .../store/cassandra/persistence/PojoField.java     |   7 +-
 .../cassandra/persistence/PojoFieldAccessor.java   |   3 +-
 .../store/cassandra/session/CassandraSession.java  |   3 +-
 .../session/GenericBatchExecutionAssistant.java    |   2 +-
 .../session/LoadCacheCustomQueryWorker.java        |   2 +-
 .../session/WrappedPreparedStatement.java          |   5 +-
 .../session/transaction/WriteMutation.java         |   2 -
 .../tests/CassandraDirectPersistenceTest.java      |  15 +-
 .../ignite/tests/CassandraSessionImplTest.java     |  28 +-
 .../ignite/tests/DatasourceSerializationTest.java  |  17 +-
 .../ignite/tests/IgnitePersistentStoreTest.java    |  18 +-
 .../tests/LoadTestsCassandraArtifactsCreator.java  |   5 +-
 .../apache/ignite/tests/pojos/SimplePerson.java    |   3 +-
 .../apache/ignite/tests/pojos/SimplePersonId.java  |   3 +-
 .../apache/ignite/tests/utils/CassandraHelper.java |  11 +-
 .../apache/ignite/tests/utils/TestTransaction.java |   3 +-
 .../org/apache/ignite/tests/utils/TestsHelper.java |  24 +-
 .../client/ClientDefaultCacheSelfTest.java         |   4 +-
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java       |  17 +-
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java     |  17 +-
 .../rest/ChangeStateCommandHandlerTest.java        |   5 +-
 .../rest/JettyRestProcessorAbstractSelfTest.java   |   8 +-
 .../rest/JettyRestProcessorCommonSelfTest.java     |   4 +-
 .../rest/JettyRestProcessorGetAllAsArrayTest.java  |   2 +-
 .../tcp/redis/RedisProtocolStringSelfTest.java     |  75 ++
 .../apache/ignite/jdbc/JdbcMetadataSelfTest.java   |   8 +-
 .../apache/ignite/jdbc/JdbcResultSetSelfTest.java  |  25 +-
 .../ignite/jdbc/JdbcVersionMismatchSelfTest.java   |   7 +-
 ...eJdbcThinDriverPartitionAwarenessTestSuite.java |   2 +-
 .../ignite/jdbc/thin/JdbcThinBulkLoadSelfTest.java |   8 +-
 .../JdbcThinComplexDmlDdlCustomSchemaSelfTest.java |   3 +-
 .../thin/JdbcThinPreparedStatementLeakTest.java    |   7 +-
 .../jdbc/thin/JdbcThinWalModeChangeSelfTest.java   |   9 +-
 .../ipfinder/cloud/TcpDiscoveryCloudIpFinder.java  |   8 +-
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |   3 +-
 .../SystemViewRowAttributeWalkerGenerator.java     |   6 +-
 .../junits/IgniteCompatibilityNodeRunner.java      |   2 +-
 .../testframework/util/MavenUtils.java             |   5 +-
 .../compress/CompressionProcessorImpl.java         |   2 +-
 .../processors/compress/FileSystemUtilsTest.java   |   4 +-
 .../main/java/org/apache/ignite/IgniteCluster.java |  42 +-
 .../java/org/apache/ignite/IgniteFileSystem.java   |   2 +-
 .../java/org/apache/ignite/IgniteServices.java     |   2 +-
 .../ignite/binary/BinaryTypeConfiguration.java     |   5 +-
 .../ignite/cache/query/BulkLoadContextCursor.java  |   7 +-
 .../org/apache/ignite/cluster/ClusterState.java    |  47 +-
 .../configuration/FileSystemConfiguration.java     |   3 +-
 .../ignite/configuration/HadoopConfiguration.java  |   2 +-
 .../configuration/PlatformCacheConfiguration.java  |   3 +-
 .../igfs/IgfsParentNotDirectoryException.java      |   2 +-
 .../local/LocalIgfsSecondaryFileSystem.java        |  37 +-
 .../ignite/internal/GridEventConsumeHandler.java   |  12 +-
 .../apache/ignite/internal/GridKernalContext.java  |   2 +-
 .../ignite/internal/GridKernalContextImpl.java     |   2 +-
 .../org/apache/ignite/internal/IgniteFeatures.java |   4 +-
 .../ignite/internal/binary/BinaryContext.java      |   7 +
 .../ignite/internal/binary/BinaryEnumCache.java    |   3 +-
 .../ignite/internal/binary/BinaryFieldImpl.java    |   4 +-
 .../internal/binary/BinaryFieldMetadata.java       |   5 +-
 .../internal/binary/BinaryMethodWriteReplacer.java |   5 +-
 .../ignite/internal/binary/BinaryRawWriterEx.java  |   2 +-
 .../internal/binary/BinaryReaderHandles.java       |   3 +-
 .../ignite/internal/binary/BinarySchema.java       |   3 +-
 .../internal/binary/BinarySchemaRegistry.java      |   3 +-
 .../binary/BinarySerializedFieldComparator.java    |   3 +-
 .../internal/binary/BinaryThreadLocalContext.java  |   2 +-
 .../ignite/internal/binary/BinaryTreeMap.java      |   9 +-
 .../binary/BinaryTreeMapWriteReplacer.java         |   3 +-
 .../ignite/internal/binary/BinaryTreeSet.java      |   7 +-
 .../binary/BinaryTreeSetWriteReplacer.java         |   3 +-
 .../ignite/internal/binary/BinaryTypeImpl.java     |   6 +-
 .../ignite/internal/binary/BinaryTypeProxy.java    |   3 +-
 .../apache/ignite/internal/binary/BinaryUtils.java |   7 +-
 .../internal/binary/GridBinaryMarshaller.java      |   2 +-
 .../internal/binary/builder/BinaryBuilderEnum.java |   4 +-
 .../binary/builder/BinaryBuilderReader.java        |  21 +-
 .../binary/builder/BinaryEnumArrayLazyValue.java   |   4 +-
 .../binary/builder/BinaryLazyArrayList.java        |   2 +-
 .../binary/builder/BinaryLazyLinkedList.java       |   2 +-
 .../internal/binary/builder/BinaryLazyMap.java     |   2 +-
 .../internal/binary/builder/BinaryLazySet.java     |   2 +-
 .../binary/builder/BinaryObjectArrayLazyValue.java |   4 +-
 .../binary/builder/BinaryPlainBinaryObject.java    |   2 +-
 .../GridClientZipOptimizedMarshaller.java          |   2 +-
 .../client/router/impl/GridRouterClientImpl.java   |   2 +-
 .../internal/client/thin/ClientComputeImpl.java    |  11 +-
 .../internal/client/thin/ReliableChannel.java      |  12 +
 .../client/thin/TcpClientTransactions.java         |  64 +-
 .../internal/client/thin/TcpIgniteClient.java      |  18 +-
 .../internal/cluster/ClusterNodeLocalMapImpl.java  |   2 +-
 .../internal/cluster/IgniteClusterAsyncImpl.java   |  15 +
 .../ignite/internal/cluster/IgniteClusterImpl.java |  65 ++
 .../internal/commandline/BaselineCommand.java      |   4 +-
 .../internal/commandline/CommandArgIterator.java   |  41 +-
 .../ignite/internal/commandline/CommandList.java   |   6 +-
 .../internal/commandline/CommonArgParser.java      |   4 +-
 .../ignite/internal/commandline/TxCommands.java    |   6 +-
 .../commandline/cache/CacheValidateIndexes.java    |   4 +-
 .../internal/commandline/meta/MetadataCommand.java | 132 +++
 .../commandline/meta/MetadataSubCommandsList.java  |  78 ++
 .../subcommands/MetadataAbstractSubCommand.java    | 145 ++++
 .../meta/subcommands/MetadataDetailsCommand.java   |  90 ++
 .../meta/subcommands/MetadataHelpCommand.java      |  54 ++
 .../meta/subcommands/MetadataListCommand.java      |  56 ++
 .../meta/subcommands/MetadataRemoveCommand.java    | 116 +++
 .../meta/subcommands/MetadataUpdateCommand.java    |  88 ++
 .../commandline/meta/tasks/MetadataInfoTask.java   |  91 ++
 .../commandline/meta/tasks/MetadataListResult.java |  74 ++
 .../commandline/meta/tasks/MetadataMarshalled.java |  86 ++
 .../commandline/meta/tasks/MetadataRemoveTask.java | 149 ++++
 .../commandline/meta/tasks/MetadataTypeArgs.java   | 129 +++
 .../commandline/meta/tasks/MetadataUpdateTask.java |  99 +++
 .../org/apache/ignite/internal/jdbc/JdbcUtils.java |   2 +-
 .../internal/jdbc/thin/JdbcThinConnection.java     |   8 +-
 .../internal/managers/IgniteMBeansManager.java     |   4 +-
 .../managers/deployment/GridDeployment.java        |   2 +-
 .../managers/discovery/ClusterMetricsImpl.java     |   2 +-
 .../managers/discovery/GridDiscoveryManager.java   |   5 +-
 .../systemview/walker/ComputeJobViewWalker.java    |   2 +-
 .../pagemem/impl/PageMemoryNoStoreImpl.java        |   4 +-
 .../pagemem/wal/record/CheckpointRecord.java       |   3 +-
 .../processors/bulkload/BulkLoadCsvFormat.java     |   3 +-
 .../processors/bulkload/BulkLoadCsvParser.java     |  13 +-
 .../processors/bulkload/BulkLoadParser.java        |   3 +-
 .../bulkload/pipeline/CharsetDecoderBlock.java     |   5 +-
 .../bulkload/pipeline/CsvLineProcessorBlock.java   |   3 +-
 .../bulkload/pipeline/LineSplitterBlock.java       |   3 +-
 .../cache/CacheAffinitySharedManager.java          |   3 +
 .../cache/CacheDefaultBinaryAffinityKeyMapper.java |   5 +-
 .../processors/cache/CacheMetricsImpl.java         |   7 +-
 .../internal/processors/cache/ExchangeActions.java |   6 +-
 .../processors/cache/GridCacheEntryInfo.java       |   3 +-
 .../cache/GridCacheLockTimeoutException.java       |   2 +-
 .../processors/cache/GridCacheProcessor.java       |   3 +
 .../processors/cache/StateChangeRequest.java       |   4 +-
 .../processors/cache/WalStateAbstractMessage.java  |   3 +-
 .../processors/cache/WalStateAckMessage.java       |   5 +-
 .../cache/WalStateDistributedProcess.java          |   9 +-
 .../internal/processors/cache/WalStateManager.java |   2 +-
 .../cache/binary/BinaryMetadataFileStore.java      | 204 ++++-
 .../cache/binary/BinaryMetadataHolder.java         |  32 +-
 .../cache/binary/BinaryMetadataTransport.java      | 446 +++++++---
 .../binary/CacheObjectBinaryProcessorImpl.java     |  82 +-
 .../processors/cache/binary/IgniteBinaryImpl.java  |   7 +-
 .../binary/MetadataRemoveAcceptedMessage.java}     |  89 +-
 .../binary/MetadataRemoveProposedMessage.java      | 143 +++
 .../GridDistributedTxFinishRequest.java            |   2 +-
 .../GridDistributedTxRemoteAdapter.java            |   2 +-
 .../dht/GridDhtAssignmentFetchFuture.java          |   2 +-
 .../cache/distributed/dht/GridDhtCacheAdapter.java |   4 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java | 172 ++--
 .../dht/preloader/GridDhtPreloader.java            |   9 +-
 .../IgniteDhtPartitionHistorySuppliersMap.java     |  15 +-
 .../distributed/near/IgniteTxMappingsImpl.java     |   2 +-
 .../cache/local/GridLocalLockFuture.java           |   4 +-
 .../processors/cache/mvcc/MvccVersionImpl.java     |   3 +-
 .../cache/persistence/DataStorageMetricsImpl.java  |   2 +-
 .../cache/persistence/DataStructure.java           |   4 +-
 .../persistence/checkpoint/CheckpointProgress.java |   3 +-
 .../checkpoint/CheckpointProgressImpl.java         |   9 +-
 .../checkpoint/PartitionDestroyQueue.java          |   5 +-
 .../pagelocktracker/stack/LockStack.java           |   2 +-
 .../evict/Random2LruPageEvictionTracker.java       |   2 +-
 .../cache/persistence/file/EncryptedFileIO.java    |   4 +-
 .../persistence/file/EncryptedFileIOFactory.java   |   2 +-
 .../partstorage/PartitionMetaStorage.java          |   2 +-
 .../snapshot/IgniteSnapshotManager.java            |  11 +-
 .../persistence/tree/reuse/ReuseListImpl.java      |   2 +-
 .../cache/persistence/tree/util/PageHandler.java   |   2 +-
 .../wal/aware/SegmentCompressStorage.java          |   2 +-
 .../wal/io/LockedSegmentFileInputFactory.java      |   2 +-
 .../query/GridCacheDistributedQueryManager.java    |   2 +-
 .../cache/query/GridCacheQueryMetricsAdapter.java  |   2 +-
 .../query/GridCacheQuerySqlMetadataJobV2.java      |  13 +-
 .../cache/query/GridCacheQuerySqlMetadataV2.java   |   5 +-
 .../CacheContinuousQueryEventBuffer.java           |   2 +-
 .../cache/store/CacheOsStoreManager.java           |   2 +-
 .../cache/transactions/IgniteTxManager.java        |   5 +-
 .../cache/verify/VerifyBackupPartitionsTaskV2.java |   2 +-
 .../cacheobject/IgniteCacheObjectProcessor.java    |  10 +
 .../cluster/ChangeGlobalStateFinishMessage.java    |   4 +-
 .../cluster/ChangeGlobalStateMessage.java          |   2 +-
 .../ClientGetClusterStateComputeRequest.java}      |  25 +-
 .../ClientSetClusterStateComputeRequest.java       |  84 ++
 .../ClusterIdAndTag.java}                          |  61 +-
 .../processors/cluster/ClusterProcessor.java       | 180 +++-
 .../processors/cluster/ClusterTagGenerator.java    | 862 ++++++++++++++++++
 .../cluster/DiscoveryDataClusterState.java         |   2 +-
 .../cluster/GridClusterStateProcessor.java         | 217 ++---
 .../datastreamer/DataStreamProcessor.java          |   7 +-
 .../datastructures/DataStructureInfoKey.java       |   3 +-
 .../datastructures/DataStructuresCacheKey.java     |   3 +-
 .../datastructures/GridCacheAtomicLongImpl.java    |   2 +-
 .../GridCacheAtomicSequenceImpl.java               |   2 +-
 .../GridCacheCountDownLatchImpl.java               |   2 +-
 .../datastructures/GridCacheLockImpl.java          |   2 +-
 .../datastructures/GridCacheSemaphoreImpl.java     |   2 +-
 .../processors/hadoop/HadoopClassLoader.java       |  21 +-
 .../processors/hadoop/HadoopNoopHelper.java        |   3 +-
 .../hadoop/shuffle/HadoopDirectShuffleMessage.java |   9 +-
 .../hadoop/shuffle/HadoopShuffleAck.java           |  11 +-
 .../hadoop/shuffle/HadoopShuffleFinishRequest.java |   9 +-
 .../shuffle/HadoopShuffleFinishResponse.java       |   9 +-
 .../processors/igfs/IgfsAbstractOutputStream.java  |   7 +-
 .../processors/igfs/IgfsClientSession.java         |   2 +-
 .../internal/processors/igfs/IgfsCreateResult.java |   3 +-
 .../internal/processors/igfs/IgfsDataManager.java  |   4 +-
 .../internal/processors/igfs/IgfsDeleteWorker.java |  15 +-
 .../processors/igfs/IgfsDirectoryInfo.java         |  15 +-
 .../internal/processors/igfs/IgfsEntryInfo.java    |  13 +-
 .../internal/processors/igfs/IgfsFileImpl.java     |  13 +-
 .../internal/processors/igfs/IgfsFileInfo.java     |  13 +-
 .../processors/igfs/IgfsFileWorkerBatch.java       |   9 +-
 .../processors/igfs/IgfsInputStreamImpl.java       |  21 +-
 .../internal/processors/igfs/IgfsIpcHandler.java   |  15 +-
 ...sLazySecondaryFileSystemPositionedReadable.java |   3 +-
 .../internal/processors/igfs/IgfsListingEntry.java |   9 +-
 .../processors/igfs/IgfsOutputStreamImpl.java      |   7 +-
 .../processors/igfs/IgfsOutputStreamProxyImpl.java |   7 +-
 .../internal/processors/igfs/IgfsPathIds.java      |   5 +-
 .../processors/igfs/IgfsPathsCreateResult.java     |   3 +-
 .../internal/processors/igfs/IgfsProcessor.java    |   2 +-
 .../igfs/IgfsSecondaryFileSystemCreateContext.java |   5 +-
 .../igfs/IgfsSecondaryFileSystemImpl.java          |   7 +-
 .../ignite/internal/processors/igfs/IgfsUtils.java |  29 +-
 .../igfs/client/IgfsClientAffinityCallable.java    |   3 +-
 .../igfs/client/IgfsClientListFilesCallable.java   |   3 +-
 .../igfs/client/IgfsClientListPathsCallable.java   |   3 +-
 .../igfs/client/IgfsClientMkdirsCallable.java      |   3 +-
 .../igfs/client/IgfsClientUpdateCallable.java      |   3 +-
 .../meta/IgfsClientMetaIdsForPathCallable.java     |   3 +-
 .../processors/igfs/data/IgfsDataPutProcessor.java |  15 +-
 .../meta/IgfsMetaDirectoryCreateProcessor.java     |  19 +-
 .../meta/IgfsMetaDirectoryListingAddProcessor.java |  17 +-
 .../IgfsMetaDirectoryListingRemoveProcessor.java   |  19 +-
 .../IgfsMetaDirectoryListingRenameProcessor.java   |  19 +-
 .../IgfsMetaDirectoryListingReplaceProcessor.java  |  19 +-
 .../igfs/meta/IgfsMetaFileCreateProcessor.java     |  17 +-
 .../igfs/meta/IgfsMetaFileLockProcessor.java       |  15 +-
 .../meta/IgfsMetaFileRangeDeleteProcessor.java     |  15 +-
 .../meta/IgfsMetaFileRangeUpdateProcessor.java     |  15 +-
 .../meta/IgfsMetaFileReserveSpaceProcessor.java    |  15 +-
 .../igfs/meta/IgfsMetaFileUnlockProcessor.java     |  15 +-
 .../meta/IgfsMetaUpdatePropertiesProcessor.java    |  17 +-
 .../igfs/meta/IgfsMetaUpdateTimesProcessor.java    |  15 +-
 .../local/LocalFileSystemPositionedReadable.java   |   3 +-
 .../igfs/secondary/local/LocalFileSystemUtils.java |  13 +-
 .../internal/processors/job/GridJobProcessor.java  |   2 +-
 .../metastorage/DistributedMetaStorage.java        |   5 +
 .../processors/metric/GridMetricManager.java       |   2 +-
 .../metric/PushMetricsExporterAdapter.java         |   2 +-
 .../ClientListenerAbstractConnectionContext.java   |   2 +-
 .../odbc/ClientListenerBufferedParser.java         |   7 +-
 .../processors/odbc/ClientListenerProcessor.java   | 138 +--
 .../processors/odbc/odbc/OdbcRequestHandler.java   |   4 +-
 .../odbc/odbc/OdbcRequestHandlerWorker.java        |   3 +-
 .../processors/odbc/odbc/OdbcTableMeta.java        |   3 +-
 .../odbc/odbc/escape/OdbcEscapeUtils.java          |   5 +-
 .../platform/PlatformConfigurationEx.java          |   5 +-
 .../processors/platform/PlatformContext.java       |   3 +-
 .../processors/platform/PlatformContextImpl.java   |  15 +-
 .../platform/PlatformDefaultJavaObjectFactory.java |   3 +-
 .../platform/PlatformJavaObjectFactoryEx.java      |   3 +-
 .../platform/PlatformJavaObjectFactoryProxy.java   |  13 +-
 .../internal/processors/platform/PlatformLock.java |   3 +-
 .../platform/PlatformNativeException.java          |   3 +-
 .../processors/platform/PlatformProcessorImpl.java |  19 +-
 .../platform/binary/PlatformBinaryProcessor.java   |   5 +-
 .../cache/PlatformCacheEntryProcessorImpl.java     |  13 +-
 .../cache/PlatformCachePartialUpdateException.java |   3 +-
 .../platform/cache/affinity/PlatformAffinity.java  |   2 +-
 .../cache/affinity/PlatformAffinityFunction.java   |  13 +-
 .../affinity/PlatformAffinityFunctionTarget.java   |   3 +-
 .../cache/affinity/PlatformAffinityUtils.java      |   7 +-
 .../cache/expiry/PlatformExpiryPolicy.java         |   2 +-
 .../cache/query/PlatformContinuousQuery.java       |   3 +-
 .../query/PlatformContinuousQueryRemoteFilter.java |  17 +-
 .../cache/query/PlatformFieldsQueryCursor.java     |   3 +-
 .../platform/client/IgniteClientException.java     |   3 +-
 .../client/binary/ClientBinaryTypeGetResponse.java |   2 +-
 .../cache/ClientCacheConfigurationSerializer.java  |  16 +-
 .../client/cache/ClientCacheEntryQueryCursor.java  |   3 +-
 .../client/cache/ClientCacheFieldsQueryCursor.java |   3 +-
 .../client/cache/ClientCacheGetAllRequest.java     |   3 +-
 .../client/cache/ClientCacheGetAllResponse.java    |   3 +-
 .../client/cache/ClientCacheGetNamesRequest.java   |   3 +-
 .../client/cache/ClientCacheGetNamesResponse.java  |   3 +-
 .../client/cache/ClientCacheQueryCursor.java       |   5 +-
 .../platform/client/cache/ClientCacheRequest.java  |   3 +-
 .../cache/ClientCacheSqlFieldsQueryResponse.java   |   3 +-
 .../cluster/ClientClusterGetStateRequest.java      |   2 +-
 .../ClientClusterGroupGetNodeIdsResponse.java      |   3 +-
 .../ClientClusterGroupGetNodesDetailsRequest.java  |   5 +-
 ...lientClusterGroupGetNodesEndpointsResponse.java |   6 +-
 .../client/compute/ClientExecuteTaskRequest.java   |   2 +-
 .../platform/compute/PlatformAbstractFunc.java     |   3 +-
 .../platform/compute/PlatformFullTask.java         |   2 +-
 .../cpp/PlatformCppConfigurationClosure.java       |   9 +-
 .../platform/cpp/PlatformCppConfigurationEx.java   |   3 +-
 .../datastreamer/PlatformDataStreamer.java         |   2 +-
 .../datastreamer/PlatformStreamReceiverImpl.java   |  11 +-
 .../platform/dotnet/PlatformDotNetBootstrap.java   |   3 +-
 .../platform/dotnet/PlatformDotNetCacheStore.java  |  17 +-
 .../dotnet/PlatformDotNetConfigurationClosure.java |   7 +-
 .../dotnet/PlatformDotNetConfigurationEx.java      |   5 +-
 .../dotnet/PlatformDotNetConsoleStream.java        |   3 +-
 ...latformDotNetEntityFrameworkCacheExtension.java |  17 +-
 .../PlatformDotNetEntityFrameworkCacheKey.java     |   3 +-
 ...NetEntityFrameworkIncreaseVersionProcessor.java |   3 +-
 .../events/PlatformEventFilterListenerImpl.java    |  11 +-
 .../processors/platform/events/PlatformEvents.java |   9 +-
 .../platform/message/PlatformMessageFilter.java    |   3 +-
 .../messaging/PlatformMessageFilterImpl.java       |   3 +-
 .../messaging/PlatformMessageLocalFilter.java      |   3 +-
 .../platform/messaging/PlatformMessaging.java      |   3 +-
 .../platform/services/PlatformServices.java        |  17 +-
 .../transactions/PlatformTransactions.java         |   9 +-
 .../platform/utils/PlatformConfigurationUtils.java |  20 +-
 .../platform/utils/PlatformListenable.java         |   4 +-
 .../processors/platform/utils/PlatformUtils.java   |  33 +-
 .../PlatformDotNetSessionCacheExtension.java       |   5 +-
 .../websession/PlatformDotNetSessionData.java      |   9 +-
 .../PlatformDotNetSessionLockProcessor.java        |   9 +-
 .../PlatformDotNetSessionLockResult.java           |   3 +-
 ...PlatformDotNetSessionSetAndUnlockProcessor.java |  11 +-
 .../processors/plugin/CachePluginManager.java      |   3 +-
 .../processors/query/GridQueryIndexDescriptor.java |   3 +-
 .../internal/processors/query/QueryEntityEx.java   |   5 +-
 .../internal/processors/query/QueryField.java      |   3 +-
 .../processors/query/QueryIndexDescriptorImpl.java |  11 +-
 .../internal/processors/query/QueryIndexKey.java   |   3 +-
 .../processors/query/QueryKeyValueIterable.java    |   5 +-
 .../processors/query/QueryKeyValueIterator.java    |   7 +-
 .../query/property/QueryFieldAccessor.java         |   3 +-
 .../query/property/QueryMethodsAccessor.java       |   3 +-
 .../property/QueryReadOnlyMethodsAccessor.java     |   3 +-
 .../SchemaIndexOperationCancellationToken.java     |   3 +-
 .../query/schema/SchemaOperationClientFuture.java  |   3 +-
 .../query/schema/SchemaOperationManager.java       |  11 +-
 .../query/schema/SchemaOperationWorker.java        |   3 +-
 .../message/SchemaOperationStatusMessage.java      |   5 +-
 .../schema/operation/SchemaAbstractOperation.java  |   3 +-
 .../operation/SchemaIndexCreateOperation.java      |   3 +-
 .../schema/operation/SchemaIndexDropOperation.java |   3 +-
 .../redis/string/GridRedisMGetCommandHandler.java  |   2 +-
 .../tcp/redis/GridRedisProtocolParser.java         |  40 +
 .../internal/sql/command/SqlBulkLoadCommand.java   |   7 +-
 .../sql/command/SqlCreateIndexCommand.java         |  13 +-
 .../optimizer/affinity/PartitionTableModel.java    |   3 +-
 .../ignite/internal/tck/TCKMBeanServerBuilder.java |   2 +-
 .../internal/util/GridConcurrentFactory.java       |   2 +-
 .../util/GridConcurrentMultiPairQueue.java         |   5 +-
 .../org/apache/ignite/internal/util/GridDebug.java |   4 +-
 .../apache/ignite/internal/util/GridKeyLock.java   |   2 +-
 .../internal/util/SerializableTransient.java       |   3 +-
 .../ignite/internal/util/lang/GridInClosure3X.java |   5 +-
 .../gridfunc/ConcurrentMapFactoryCallable.java     |   2 +-
 .../ignite/internal/util/nio/GridNioServer.java    |  10 +-
 .../apache/ignite/internal/util/scala/impl.java    |   6 +-
 .../util/tostring/GridToStringBuilder.java         |   2 +-
 .../util/tostring/GridToStringInclude.java         |   3 +-
 .../internal/util/tostring/SBLimitedLength.java    |   2 +-
 .../apache/ignite/internal/util/typedef/CI3.java   |   3 +-
 .../ignite/internal/visor/cache/VisorCache.java    |   2 +-
 .../internal/visor/cache/VisorCacheJdbcType.java   |   3 +-
 .../internal/visor/cache/VisorPartitionMap.java    |   2 +-
 .../visor/node/VisorMemoryConfiguration.java       |   2 +-
 .../websession/WebSessionAttributeProcessor.java   |  11 +-
 .../internal/websession/WebSessionEntity.java      |   9 +-
 .../AbstractNodeNameAwareMarshaller.java           |   5 +-
 .../dotnet/PlatformDotNetAffinityFunction.java     |  15 +-
 .../dotnet/PlatformDotNetBinaryConfiguration.java  |   3 +-
 .../dotnet/PlatformDotNetCacheStoreFactory.java    |   5 +-
 .../PlatformDotNetCacheStoreFactoryNative.java     |   3 +-
 .../dotnet/PlatformDotNetConfiguration.java        |   5 +-
 .../dotnet/PlatformDotNetLifecycleBean.java        |   3 +-
 .../apache/ignite/plugin/CachePluginProvider.java  |   3 +-
 .../ignite/plugin/PluginValidationException.java   |   5 +-
 .../ignite/plugin/security/SecurityPermission.java |   5 +-
 .../spi/IgniteSpiOperationTimeoutHelper.java       |  16 +
 .../spi/deployment/local/LocalDeploymentSpi.java   |   2 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java       | 119 ++-
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |   9 +
 .../TcpDiscoveryServerOnlyCustomEventMessage.java  |   3 +-
 .../spi/indexing/IndexingQueryCacheFilter.java     |   3 +-
 .../spi/indexing/IndexingQueryFilterImpl.java      |   3 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java         |   2 +-
 .../ignite/spi/systemview/view/CacheGroupView.java |   2 +-
 .../ignite/spi/systemview/view/CacheView.java      |   2 +-
 .../main/resources/META-INF/classnames.properties  |  16 +-
 .../test/java/org/apache/ignite/GridTestJob.java   |   3 +-
 .../RendezvousAffinityFunctionSimpleBenchmark.java |  23 +-
 ...StoreSessionListenerWriteBehindEnabledTest.java |   2 +-
 .../cache/store/CacheStoreWriteErrorTest.java      |   2 +-
 .../store/StoreResourceInjectionSelfTest.java      |  14 +-
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |   3 +-
 .../ignite/cache/store/jdbc/model/TestPojo.java    |   2 +-
 .../org/apache/ignite/client/FunctionalTest.java   | 102 +++
 .../ignite/internal/GridGetOrStartSelfTest.java    |   9 +-
 .../BinaryArrayIdentityResolverSelfTest.java       |   7 +-
 .../BinaryConfigurationConsistencySelfTest.java    |   2 +-
 .../binary/BinaryFieldsAbstractSelfTest.java       |  11 +-
 .../internal/binary/BinaryMarshallerSelfTest.java  |   2 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java     |   8 +-
 .../BinaryObjectBuilderDefaultMappersSelfTest.java |   4 +-
 .../internal/binary/BinaryObjectToStringTest.java  |   2 +-
 .../BinarySerialiedFieldComparatorSelfTest.java    |  13 +-
 .../binary/GridBinaryAffinityKeySelfTest.java      |   2 +-
 .../binary/GridBinaryWildcardsSelfTest.java        |   2 +-
 ...DefaultBinaryMappersBinaryMetaDataSelfTest.java |  14 +-
 .../GridBinaryMarshalerAwareTestClass.java         |   4 +-
 .../binary/mutabletest/GridBinaryTestClasses.java  |   2 +-
 .../internal/client/thin/TestFailoverTask.java     |   7 +-
 .../internal/client/thin/TestResultCacheTask.java  |   5 +-
 .../ignite/internal/client/thin/TestTask.java      |  11 +-
 .../FullyConnectedComponentSearcherTest.java       |   2 +-
 .../internal/cluster/IgniteClusterIdTagTest.java   | 288 ++++++
 .../commandline/CommandHandlerParsingTest.java     |   3 +-
 .../encryption/EncryptedCacheCreateTest.java       |   2 +-
 .../MessageDirectTypeIdConflictTest.java           |   1 -
 .../internal/metric/IoStatisticsCacheSelfTest.java |   2 +-
 .../ignite/internal/metric/SystemViewSelfTest.java |   4 +-
 .../affinity/GridAffinityAssignmentV2Test.java     |   4 +-
 .../cache/CacheGroupsMetricsRebalanceTest.java     |   2 +-
 .../cache/CacheLockCandidatesThreadTest.java       |  13 +-
 .../cache/CacheOffheapMapEntrySelfTest.java        |   2 +-
 .../processors/cache/CacheRemoveAllSelfTest.java   |   2 +-
 ...ActiveStateChangeWithNodeOutOfBaselineTest.java |   6 +-
 .../processors/cache/ClusterStateAbstractTest.java |   2 +-
 .../cache/ClusterStateServerAbstractTest.java      |   2 +-
 ...dCacheAbstractFullApiMultithreadedSelfTest.java |   2 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java    |  18 +-
 .../cache/GridCacheAbstractLocalStoreSelfTest.java |   2 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java    |   2 +-
 .../cache/GridCacheAbstractRemoveFailureTest.java  |   2 +-
 .../GridCacheInterceptorAbstractSelfTest.java      |   2 +-
 ...ultinodeUpdateNearEnabledNoBackupsSelfTest.java |   2 +-
 ...ridCacheMultinodeUpdateNearEnabledSelfTest.java |   2 +-
 .../cache/GridCacheP2PUndeploySelfTest.java        |   2 +-
 .../cache/GridCachePutAllFailoverSelfTest.java     |   2 +-
 ...dLocalCacheStoreManagerDeserializationTest.java |   5 +-
 .../cache/GridLocalIgniteSerializationTest.java    |  17 +-
 .../IgniteAbstractDynamicCacheStartFailTest.java   |  20 +-
 .../processors/cache/IgniteCacheAbstractTest.java  |   2 +-
 .../processors/cache/IgniteCacheGroupsTest.java    |   2 +-
 .../cache/IgniteCachePeekModesAbstractTest.java    |   2 +-
 .../cache/IgniteCacheStoreCollectionTest.java      |   2 +-
 .../cache/IgniteCacheTxNearPeekModesTest.java      |   3 +-
 .../cache/IgniteCachingProviderSelfTest.java       |   2 +-
 .../cache/IgniteClusterActivateDeactivateTest.java |  41 +-
 .../cache/IgniteDynamicCacheAndNodeStop.java       |  14 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java     |  45 +-
 .../cache/IgniteIncompleteCacheObjectSelfTest.java |   5 +-
 .../cache/IgniteOnePhaseCommitNearSelfTest.java    |  61 +-
 .../processors/cache/MapCacheStoreStrategy.java    |   2 +-
 ...NonAffinityCoordinatorDynamicStartStopTest.java |   4 +-
 .../cache/binary/BinaryMetadataRemoveTest.java     | 308 +++++++
 .../BinaryMetadataRemoveWithPersistenceTest.java   |  86 ++
 .../GridCacheBinaryStoreAbstractSelfTest.java      |   4 +-
 ...ridCacheClientNodeBinaryObjectMetadataTest.java |   2 +-
 .../DataStreamProcessorBinarySelfTest.java         |   2 +-
 .../GridCacheAffinityRoutingBinarySelfTest.java    |   4 +-
 ...riesNearPartitionedByteArrayValuesSelfTest.java |   2 +-
 ...riesPartitionedOnlyByteArrayValuesSelfTest.java |   2 +-
 .../IgniteDataStructureUniqueNameTest.java         |   2 +-
 .../SemaphoreFailoverNoWaitingAcquirerTest.java    |   3 +-
 ...chePartitionedQueueCreateMultiNodeSelfTest.java |   1 -
 .../CacheClientsConcurrentStartTest.java           |  23 +-
 .../distributed/CacheLockChangingTopologyTest.java |   9 +-
 .../distributed/CacheOperationsInterruptTest.java  |   7 +-
 .../CachePartitionLossWithRestartsTest.java        |  36 +-
 .../cache/distributed/CachePartitionStateTest.java |   4 +-
 ...gniteCacheClientNodePartitionsExchangeTest.java |   2 +-
 .../distributed/IgniteCacheTxIteratorSelfTest.java |   3 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java        |   2 +-
 .../dht/GridCacheDhtPreloadPerformanceTest.java    |   3 +-
 .../dht/IgniteCacheCrossCacheTxFailoverTest.java   |   2 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java       |   2 +-
 .../PartitionsEvictManagerAbstractTest.java        |   2 +-
 .../eviction/EvictionPolicyFailureHandlerTest.java |   2 +-
 .../eviction/paged/PageEvictionAbstractTest.java   |   2 +-
 .../IgniteCacheExpireWhileRebalanceTest.java       |   9 +-
 .../IgniteCacheLoadAllAbstractTest.java            |   2 +-
 .../local/GridCacheLocalMultithreadedSelfTest.java |   2 +-
 .../cache/mvcc/CacheMvccClientTopologyTest.java    | 305 +++++++
 .../mvcc/CacheMvccConfigurationValidationTest.java |  30 -
 .../mvcc/CacheMvccRemoteTxOnNearNodeStartTest.java |   2 +-
 .../cache/mvcc/MvccUnsupportedTxModesTest.java     |   2 +-
 ...gniteLostPartitionsOnLeaveBaselineSelfTest.java |   2 +-
 .../IgnitePdsBinaryMetadataAsyncWritingTest.java   |   2 +-
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java |   9 +-
 .../IgnitePdsCacheRebalancingAbstractTest.java     |   2 +-
 .../persistence/IgnitePdsCorruptedIndexTest.java   |   2 +-
 .../IgnitePersistenceSequentialCheckpointTest.java |   2 +-
 .../ClientAffinityAssignmentWithBaselineTest.java  |   2 +-
 .../persistence/db/CheckpointFailingIoFactory.java |   9 +-
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |   4 +-
 .../db/file/IgnitePdsCheckpointSimpleTest.java     |   2 +-
 .../db/file/IgnitePdsPageReplacementTest.java      |   4 +-
 .../db/wal/IgniteWalFlushFailoverTest.java         |   2 +-
 .../db/wal/WalRebalanceRestartTest.java            | 321 +++++++
 .../db/wal/crc/IgniteDataIntegrityTests.java       |   3 +-
 .../db/wal/crc/IgnitePureJavaCrcCompatibility.java |   5 +-
 .../dumpprocessors/ToFileDumpProcessorTest.java    |   2 +-
 .../cache/persistence/file/FileDownloaderTest.java |   2 +-
 .../BPlusTreeReuseListPageMemoryImplTest.java      |   4 +-
 .../IgnitePageMemReplaceDelayedWriteUnitTest.java  |   4 +-
 .../pagemem/IgniteThrottlingUnitTest.java          |   2 +-
 .../pagemem/IndexStoragePageMemoryImplTest.java    |   2 +-
 .../pagemem/PageMemoryImplNoLoadTest.java          |   4 +-
 .../persistence/pagemem/PageMemoryImplTest.java    |   8 +-
 .../snapshot/AbstractSnapshotSelfTest.java         |   7 +-
 .../snapshot/IgniteClusterSnapshotSelfTest.java    |  19 +
 .../standbycluster/IgniteStandByClusterTest.java   |   2 +-
 .../join/JoinActiveNodeToActiveCluster.java        |   2 +-
 .../join/JoinInActiveNodeToActiveCluster.java      |   2 +-
 ...inActiveNodeToActiveClusterWithPersistence.java |   2 +-
 ...ActiveNodeToInActiveClusterWithPersistence.java |   2 +-
 ...InActiveNodeToActiveClusterWithPersistence.java |   2 +-
 ...ActiveNodeToInActiveClusterWithPersistence.java |   2 +-
 ...niteStandByClientReconnectToNewClusterTest.java |   2 +-
 .../PageMemoryTrackerPluginProvider.java           |   2 +-
 .../ScanQueryOffheapExpiryPolicySelfTest.java      |   7 +-
 ...eContinuousQueryFilterDeploymentFailedTest.java |   3 +
 .../CacheContinuousQueryLongP2PTest.java           |   4 +-
 .../AbstractDeadlockDetectionTest.java             |   5 +-
 .../transactions/PartitionUpdateCounterTest.java   |   4 +-
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |   4 +-
 .../cache/transactions/TxDeadlockCauseTest.java    |  31 +-
 .../TxPartitionCounterStateConsistencyTest.java    | 121 +--
 .../TxPessimisticDeadlockDetectionTest.java        |   4 +-
 .../transactions/TxWithKeyContentionSelfTest.java  |   2 +-
 .../TestDistibutedConfigurationPlugin.java         |   9 +-
 .../database/IgniteDbMemoryLeakAbstractTest.java   |   2 +-
 .../database/SwapPathConstructionSelfTest.java     |   6 +-
 .../failure/FailureProcessorLoggingTest.java       |   2 +-
 .../processors/igfs/IgfsAbstractSelfTest.java      |  36 +-
 .../processors/igfs/IgfsDataManagerSelfTest.java   |  13 +-
 .../processors/igfs/IgfsDualAbstractSelfTest.java  |  11 +-
 ...calSecondaryFileSystemDualAbstractSelfTest.java |  15 +-
 .../IgfsLocalSecondaryFileSystemTestAdapter.java   |  15 +-
 .../processors/igfs/IgfsMetaManagerSelfTest.java   |  11 +-
 .../ignite/internal/processors/igfs/IgfsMock.java  |   7 +-
 .../igfs/IgfsProcessorValidationSelfTest.java      |  11 +-
 .../igfs/IgfsSecondaryFileSystemTestAdapter.java   |   5 +-
 .../processors/igfs/IgfsStartCacheTest.java        |   7 +-
 .../processors/igfs/IgfsStreamsSelfTest.java       |  21 +-
 .../internal/processors/igfs/IgfsTaskSelfTest.java |  13 +-
 .../odbc/OdbcEscapeSequenceSelfTest.java           |   3 +-
 .../rest/RestProcessorInitializationTest.java      |   2 +-
 .../cache/GridCacheCommandHandlerSelfTest.java     |   3 +-
 .../query/GridQueryCommandHandlerTest.java         |   3 +-
 .../AbstractTestSecurityPluginProvider.java        |   2 +-
 ...eOperationPermissionCreateDestroyCheckTest.java |   4 +-
 .../TestCertificateSecurityPluginProvider.java     |   2 +-
 ...oyment2ClassLoadersOptimizedMarshallerTest.java |   2 +-
 ...loymentClassLoadingOptimizedMarshallerTest.java |   2 +-
 .../IgniteServiceProxyTimeoutInitializedTest.java  |  11 +-
 .../internal/sql/SqlParserAbstractSelfTest.java    |   3 +-
 .../util/GridConcurrentMultiPairQueueTest.java     |   9 +-
 .../offheap/GridOffHeapMapAbstractSelfTest.java    |   2 +-
 .../util/tostring/GridToStringBuilderSelfTest.java |   2 +-
 .../utils/IgniteOffheapReadWriteLockSelfTest.java  |  11 +-
 .../communication/GridIoManagerBenchmark.java      |   2 +-
 .../marshaller/GridMarshallerPerformanceTest.java  |   8 +-
 .../messaging/IgniteMessagingSendAsyncTest.java    |   4 +-
 .../apache/ignite/p2p/SharedDeploymentTest.java    |   6 +-
 .../platform/PlatformCacheEntryEventFilter.java    |  13 +-
 .../PlatformCacheEntryEventFilterFactory.java      |   7 +-
 .../platform/PlatformCacheWriteMetricsTask.java    |   7 +-
 .../PlatformComputeActiveTaskFuturesTask.java      |   9 +-
 .../PlatformComputeBinarizableArgTask.java         |  15 +-
 .../platform/PlatformComputeBroadcastTask.java     |  13 +-
 .../platform/PlatformComputeDecimalTask.java       |  17 +-
 .../ignite/platform/PlatformComputeEchoTask.java   |   7 +-
 .../platform/PlatformComputeGetThreadNameTask.java |   7 +-
 .../PlatformDefaultJavaObjectFactorySelfTest.java  |  11 +-
 .../platform/PlatformEventsWriteEventTask.java     |  20 +-
 .../ignite/platform/PlatformExceptionTask.java     |  30 +-
 .../platform/PlatformIsPartitionReservedTask.java  |   7 +-
 .../PlatformJavaObjectFactoryProxySelfTest.java    |  11 +-
 .../ignite/platform/PlatformMaxMemoryTask.java     |   9 +-
 .../ignite/platform/PlatformMinMemoryTask.java     |   9 +-
 .../ignite/platform/PlatformSqlQueryTask.java      |  21 +-
 .../ignite/platform/PlatformStartIgniteTask.java   |   7 +-
 .../ignite/platform/PlatformStopIgniteTask.java    |   7 +-
 .../ignite/platform/PlatformStringTestTask.java    |   7 +-
 .../ignite/platform/PlatformThreadNamesTask.java   |   9 +-
 .../lifecycle/PlatformJavaLifecycleTask.java       |   9 +-
 .../security/SecurityPermissionSetBuilderTest.java |   2 +-
 .../session/GridSessionCheckpointSelfTest.java     |   2 +-
 ...municationSpiSkipWaitHandshakeOnClientTest.java |   2 +-
 .../tcp/TcpCommunicationSpiFreezingClientTest.java |   2 +-
 .../discovery/LongClientConnectToClusterTest.java  |  12 +-
 .../TestReconnectSecurityPluginProvider.java       |   2 +-
 .../spi/discovery/tcp/IgniteClientConnectTest.java |   5 +-
 .../tcp/TcpDiscoverySnapshotHistoryTest.java       |   3 +-
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |   5 +-
 .../stream/socket/SocketStreamerSelfTest.java      |   4 +-
 .../apache/ignite/testframework/GridTestUtils.java |   8 +-
 .../ConfigVariationsTestSuiteBuilder.java          |   2 +-
 .../testframework/http/GridEmbeddedHttpServer.java |  10 +-
 .../testframework/junits/GridAbstractTest.java     |   9 +-
 .../apache/ignite/testframework/junits/Repeat.java |   5 +-
 .../common/GridRollingRestartAbstractTest.java     |   5 +-
 .../junits/multijvm/IgniteClusterProcessProxy.java |  15 +
 .../IgniteBasicWithPersistenceTestSuite.java       |   5 +-
 .../testsuites/IgniteBinaryObjectsTestSuite.java   |   5 +
 .../testsuites/IgniteCacheMvccTestSuite.java       |   2 +
 .../ignite/testsuites/IgniteCacheTestSuite2.java   |   2 +-
 .../ignite/testsuites/IgniteCacheTestSuite8.java   |   2 +-
 .../ignite/testsuites/IgniteIgfsTestSuite.java     |  20 +-
 .../testsuites/IgniteMarshallerSelfTestSuite.java  |   1 -
 .../ignite/testsuites/IgniteP2PSelfTestSuite.java  |   2 +-
 .../ignite/testsuites/IgnitePdsTestSuite4.java     |   2 +
 .../testsuites/IgniteRestHandlerTestSuite.java     |   2 +-
 .../ignite/testsuites/IgniteUtilSelfTestSuite.java |   2 +-
 .../ignite/testsuites/SecurityTestSuite.java       |   4 +-
 .../util/GridCommandHandlerAbstractTest.java       |   2 +-
 .../util/GridCommandHandlerClusterByClassTest.java |   8 +-
 .../ignite/util/mbeans/GridMBeanBaselineTest.java  |   4 +-
 ...ridCommandHandlerClusterByClassTest_help.output |  16 +
 ...andHandlerClusterByClassWithSSLTest_help.output |  16 +
 .../cache/persistence/file/AlignedBuffers.java     |   2 +-
 .../file/AlignedBuffersDirectFileIO.java           |   6 +-
 .../cache/persistence/file/IgniteNativeIoLib.java  |   6 +-
 .../CacheDeploymentCachePluginConfiguration.java   |   3 +-
 ...tformTestPluginConfigurationClosureFactory.java |   5 +-
 .../plugin/PlatformTestPluginProvider.java         |   7 +-
 .../plugin/cache/PlatformGetCachePluginsTask.java  |   7 +-
 ...latformTestCachePluginConfigurationClosure.java |   5 +-
 .../cache/PlatformTestCachePluginProvider.java     |   3 +-
 .../uri/tasks/GridUriDeploymentTestTask10.java     |   5 +-
 .../uri/tasks/GridUriDeploymentTestTask11.java     |   5 +-
 .../uri/tasks/GridUriDeploymentTestTask8.java      |   5 +-
 .../uri/tasks/GridUriDeploymentTestTask9.java      |   7 +-
 .../tasks/GridUriDeploymentTestWithNameTask10.java |   5 +-
 .../tasks/GridUriDeploymentTestWithNameTask11.java |   5 +-
 .../tasks/GridUriDeploymentTestWithNameTask8.java  |   5 +-
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java     |  20 +-
 .../testsuites/GeoSpatialIndexingTestSuite.java    |   2 +-
 .../hadoop/fs/BasicHadoopFileSystemFactory.java    |   9 +-
 .../ignite/hadoop/fs/HadoopFileSystemFactory.java  |   3 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java    |   9 +-
 .../hadoop/fs/KerberosHadoopFileSystemFactory.java |   5 +-
 .../IgniteHadoopWeightedMapReducePlanner.java      |  33 +-
 .../planner/HadoopAbstractMapReducePlanner.java    |  11 +-
 .../ignite/hadoop/util/BasicUserNameMapper.java    |   3 +-
 .../ignite/hadoop/util/ChainedUserNameMapper.java  |   3 +-
 .../apache/ignite/hadoop/util/UserNameMapper.java  |   3 +-
 .../processors/hadoop/HadoopAttributes.java        |  11 +-
 .../processors/hadoop/HadoopCommonUtils.java       |   5 +-
 .../processors/hadoop/HadoopExternalSplit.java     |   5 +-
 .../processors/hadoop/HadoopHelperImpl.java        |   5 +-
 .../processors/hadoop/HadoopProcessor.java         |   9 +-
 .../hadoop/delegate/HadoopDelegateUtils.java       |   7 +-
 .../delegate/HadoopFileSystemFactoryDelegate.java  |   3 +-
 .../hadoop/impl/HadoopMapReduceCounterGroup.java   |   7 +-
 .../hadoop/impl/HadoopMapReduceCounters.java       |  21 +-
 .../processors/hadoop/impl/HadoopUtils.java        |  25 +-
 .../HadoopBasicFileSystemFactoryDelegate.java      |  11 +-
 .../HadoopCachingFileSystemFactoryDelegate.java    |   3 +-
 .../HadoopDefaultFileSystemFactoryDelegate.java    |   3 +-
 .../HadoopFileSystemCounterWriterDelegateImpl.java |   7 +-
 .../HadoopIgfsSecondaryFileSystemDelegateImpl.java |  17 +-
 .../HadoopKerberosFileSystemFactoryDelegate.java   |   5 +-
 .../hadoop/impl/fs/HadoopFileSystemCacheUtils.java |   5 +-
 .../hadoop/impl/fs/HadoopLazyConcurrentMap.java    |   9 +-
 .../hadoop/impl/fs/HadoopLocalFileSystemV1.java    |   3 +-
 .../hadoop/impl/fs/HadoopLocalFileSystemV2.java    |   7 +-
 .../hadoop/impl/fs/HadoopRawLocalFileSystem.java   |  19 +-
 .../processors/hadoop/impl/igfs/HadoopIgfs.java    |   7 +-
 .../processors/hadoop/impl/igfs/HadoopIgfsEx.java  |   3 +-
 .../hadoop/impl/igfs/HadoopIgfsInputStream.java    |   7 +-
 .../hadoop/impl/igfs/HadoopIgfsIpcIo.java          |  27 +-
 .../hadoop/impl/igfs/HadoopIgfsOutProc.java        |   7 +-
 .../hadoop/impl/igfs/HadoopIgfsOutputStream.java   |   5 +-
 .../hadoop/impl/igfs/HadoopIgfsProperties.java     |   3 +-
 .../impl/igfs/HadoopIgfsProxyInputStream.java      |   5 +-
 .../impl/igfs/HadoopIgfsProxyOutputStream.java     |   5 +-
 ...pIgfsSecondaryFileSystemPositionedReadable.java |   3 +-
 .../hadoop/impl/igfs/HadoopIgfsUtils.java          |   5 +-
 .../hadoop/impl/proto/HadoopClientProtocol.java    |   5 +-
 .../hadoop/impl/v1/HadoopV1CleanupTask.java        |   3 +-
 .../processors/hadoop/impl/v1/HadoopV1Counter.java |   7 +-
 .../hadoop/impl/v1/HadoopV1OutputCollector.java    |   3 +-
 .../hadoop/impl/v1/HadoopV1SetupTask.java          |   3 +-
 .../hadoop/impl/v1/HadoopV1Splitter.java           |   9 +-
 .../processors/hadoop/impl/v1/HadoopV1Task.java    |   5 +-
 .../hadoop/impl/v2/HadoopSerializationWrapper.java |  11 +-
 .../hadoop/impl/v2/HadoopV2CleanupTask.java        |   3 +-
 .../processors/hadoop/impl/v2/HadoopV2Context.java |   7 +-
 .../processors/hadoop/impl/v2/HadoopV2Counter.java |   5 +-
 .../processors/hadoop/impl/v2/HadoopV2Job.java     |  39 +-
 .../hadoop/impl/v2/HadoopV2JobResourceManager.java |  21 +-
 .../hadoop/impl/v2/HadoopV2SetupTask.java          |   3 +-
 .../hadoop/impl/v2/HadoopV2Splitter.java           |  13 +-
 .../processors/hadoop/impl/v2/HadoopV2Task.java    |   3 +-
 .../hadoop/impl/v2/HadoopV2TaskContext.java        |  21 +-
 .../impl/v2/HadoopWritableSerialization.java       |   7 +-
 .../hadoop/jobtracker/HadoopJobMetadata.java       |   2 +-
 .../hadoop/jobtracker/HadoopJobTracker.java        |   6 +-
 .../hadoop/mapreduce/MapReduceClient.java          |   7 +-
 .../hadoop/planner/HadoopDefaultMapReducePlan.java |   7 +-
 .../hadoop/planner/HadoopMapReducePlanGroup.java   |   5 +-
 .../planner/HadoopMapReducePlanTopology.java       |   5 +-
 .../processors/hadoop/shuffle/HadoopShuffle.java   |  13 +-
 .../hadoop/shuffle/HadoopShuffleJob.java           |  21 +-
 .../hadoop/shuffle/HadoopShuffleRemoteState.java   |   3 +-
 .../shuffle/direct/HadoopDirectDataInput.java      |   9 +-
 .../shuffle/direct/HadoopDirectDataOutput.java     |   5 +-
 .../direct/HadoopDirectDataOutputContext.java      |   5 +-
 .../hadoop/taskexecutor/HadoopExecutorService.java |   2 +-
 .../external/HadoopExternalTaskExecutor.java       |   4 +-
 .../processors/hadoop/HadoopTestClassLoader.java   |   9 +-
 .../hadoop/impl/HadoopAbstractWordCountTest.java   |   2 +-
 .../hadoop/impl/HadoopCommandLineTest.java         |   2 +-
 .../processors/hadoop/impl/HadoopGroupingTest.java |  21 +-
 .../hadoop/impl/HadoopPlannerMockJob.java          |   7 +-
 .../hadoop/impl/HadoopTaskExecutionSelfTest.java   |   2 +-
 .../processors/hadoop/impl/HadoopTasksV1Test.java  |   2 +-
 .../processors/hadoop/impl/HadoopTasksV2Test.java  |   2 +-
 .../impl/HadoopTasksVersionsAbstractTest.java      |   2 +-
 .../processors/hadoop/impl/HadoopTestUtils.java    |   7 +-
 .../hadoop/impl/HadoopUserLibsSelfTest.java        |   5 +-
 .../hadoop/impl/HadoopV2JobSelfTest.java           |   2 +-
 .../impl/HadoopWeightedMapReducePlannerTest.java   |  27 +-
 .../hadoop/impl/examples/HadoopPopularWords.java   |   2 +-
 .../impl/igfs/HadoopFIleSystemFactorySelfTest.java |  11 +-
 .../impl/igfs/HadoopIgfsDualAbstractSelfTest.java  |   7 +-
 .../HadoopIgfsSecondaryFileSystemTestAdapter.java  |   2 +-
 ...HadoopSecondaryFileSystemConfigurationTest.java |  13 +-
 .../igfs/IgniteHadoopFileSystemLoggerSelfTest.java |  11 +-
 .../HadoopConcurrentHashMultimapSelftest.java      |   4 +-
 .../shuffle/collections/HadoopHashMapSelfTest.java |  11 +-
 .../collections/HadoopSkipListSelfTest.java        |   4 +-
 .../shuffle/streams/HadoopDataStreamSelfTest.java  |   1 -
 .../taskexecutor/HadoopExecutorServiceTest.java    |   5 +-
 .../HadoopExternalTaskExecutionSelfTest.java       |   2 +-
 .../impl/util/BasicUserNameMapperSelfTest.java     |   5 +-
 .../impl/util/ChainedUserNameMapperSelfTest.java   |   5 +-
 .../hadoop/state/HadoopGroupingTestState.java      |   5 +-
 .../state/HadoopJobTrackerSelfTestState.java       |   3 +-
 .../HadoopMapReduceEmbeddedSelfTestState.java      |   3 +-
 .../state/HadoopTaskExecutionSelfTestValues.java   |   3 +-
 .../ignite/testsuites/IgniteHadoopTestSuite.java   |  95 +-
 .../processors/cache/query/QueryTable.java         |   3 +-
 .../processors/query/h2/CommandProcessor.java      |   2 +-
 .../processors/query/h2/CommandResult.java         |   3 +-
 .../processors/query/h2/H2DatabaseType.java        |   7 +-
 .../processors/query/h2/H2SqlFieldMetadata.java    |   9 +-
 .../processors/query/h2/IndexBuildClosure.java     |   2 +-
 .../query/h2/IndexRebuildPartialClosure.java       |  11 +-
 .../internal/processors/query/h2/UpdateResult.java |   5 +-
 .../query/h2/dml/DmlBulkLoadDataConverter.java     |   3 +-
 .../query/h2/dml/DmlPageProcessingErrorResult.java |   5 +-
 .../query/h2/dml/DmlPageProcessingResult.java      |   3 +-
 .../query/h2/dml/DmlUpdateResultsIterator.java     |   5 +-
 .../processors/query/h2/opt/GridH2ProxyIndex.java  |   5 +-
 .../query/h2/opt/GridH2ProxySpatialIndex.java      |   5 +-
 .../processors/query/h2/opt/GridLuceneIndex.java   |   2 +-
 .../processors/query/h2/opt/H2TableScanIndex.java  |   3 +-
 .../processors/query/h2/opt/QueryContextKey.java   |   3 +-
 .../query/h2/opt/join/BroadcastCursor.java         |   9 +-
 .../query/h2/opt/join/CursorIteratorWrapper.java   |   3 +-
 .../query/h2/opt/join/DistributedJoinContext.java  |   7 +-
 .../h2/opt/join/ProxyDistributedLookupBatch.java   |   5 +-
 .../processors/query/h2/opt/join/RangeSource.java  |   7 +-
 .../processors/query/h2/opt/join/RangeStream.java  |  13 +-
 .../query/h2/sql/GridSqlQueryParser.java           |   2 +-
 .../query/h2/sql/SplitterQueryModel.java           |   5 +-
 .../processors/query/h2/sql/SplitterUtils.java     |   3 +-
 .../processors/query/h2/sys/SqlSystemIndex.java    |   3 +-
 .../processors/query/h2/twostep/MapRequestKey.java |   3 +-
 .../query/h2/twostep/PartitionReservation.java     |   5 +-
 .../h2/twostep/ReducePartitionsSpecializer.java    |   3 +-
 .../query/h2/twostep/ReduceSourceKey.java          |   3 +-
 .../query/h2/twostep/ReduceTableEngine.java        |   7 +-
 .../visor/verify/ValidateIndexesClosure.java       |   3 +-
 .../apache/ignite/client/FunctionalQueryTest.java  |   3 +-
 ...aryMetadataConcurrentUpdateWithIndexesTest.java |   2 +-
 .../cache/BinarySerializationQuerySelfTest.java    |  23 +-
 .../cache/CacheIteratorScanQueryTest.java          |   7 +-
 .../ClientReconnectAfterClusterRestartTest.java    |   2 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java    |   4 +-
 ...gniteCacheJoinPartitionedAndReplicatedTest.java |  11 +-
 .../IgniteCacheLockPartitionOnAffinityRunTest.java |   2 +-
 .../IgniteCachePrimitiveFieldsQuerySelfTest.java   |   5 +-
 ...ingleNodeWithIndexingPutGetPersistenceTest.java |   2 +-
 .../cache/QueryEntityCaseMismatchTest.java         |   9 +-
 ...acheDistributedQueryDefaultTimeoutSelfTest.java |   2 +-
 ...tributedQueryStopOnCancelOrTimeoutSelfTest.java |   2 +-
 .../near/IgniteSqlQueryWithBaselineTest.java       |   4 +-
 .../cache/index/AbstractSchemaSelfTest.java        |   2 +-
 .../index/IoStatisticsBasicIndexSelfTest.java      |   2 +-
 ...niteCacheLocalQueryCancelOrTimeoutSelfTest.java |   2 +-
 .../cache/mvcc/CacheMvccTxNodeMappingTest.java     |   4 +-
 .../cache/mvcc/MvccRepeatableReadBulkOpsTest.java  |   6 +-
 .../ttl/CacheTtlAtomicPartitionedSelfTest.java     |   2 +-
 ...ntConnectorConfigurationValidationSelfTest.java |  17 +-
 .../query/IgniteQueryDedicatedPoolTest.java        |   2 +-
 .../processors/query/RunningQueriesTest.java       |   2 +-
 .../query/SqlPartOfComplexPkLookupTest.java        |   2 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |   2 +-
 .../query/h2/GridIndexFullRebuildTest.java         |   2 +-
 .../query/h2/sql/ParameterTypeInferenceTest.java   |  11 +-
 .../testsuites/IgniteCacheMvccSqlTestSuite.java    |   2 +-
 .../testsuites/IgniteCacheQuerySelfTestSuite6.java |   2 +-
 ...teCacheWithIndexingAndPersistenceTestSuite.java |   4 +-
 ...idCommandHandlerIndexingClusterByClassTest.java |   4 +-
 .../util/GridCommandHandlerIndexingTest.java       |   2 +-
 .../util/GridCommandHandlerMetadataTest.java       | 384 ++++++++
 .../org/apache/ignite/util/KillCommandsTests.java  |   2 +-
 .../stream/jms11/IgniteJmsStreamerTestSuite.java   |   4 +-
 .../cache/jta/AbstractCacheJtaSelfTest.java        |   4 +-
 .../ignite/testsuites/IgniteJtaTestSuite.java      |   2 +-
 .../ignite/stream/kafka/TestKafkaBroker.java       |   4 +-
 .../kubernetes/TcpDiscoveryKubernetesIpFinder.java |  26 +-
 .../ignite/mesos/resource/IgniteProvider.java      |   4 +-
 .../org/apache/ignite/ml/h2o/H2OMojoModel.java     |   7 +-
 .../apache/ignite/ml/h2o/H2OMojoModelParser.java   |   5 +-
 .../gmm/CovarianceMatricesAggregator.java          |   9 +-
 .../gmm/NewComponentStatisticsAggregator.java      |   3 +-
 .../ignite/ml/dataset/feature/ObjectHistogram.java |   6 +-
 .../BootstrappedDatasetPartition.java              |   3 +-
 .../impl/bootstrapping/BootstrappedVector.java     |   5 +-
 .../ignite/ml/dataset/primitive/SimpleDataset.java |   2 +-
 .../ignite/ml/knn/NNClassificationModel.java       |   2 +-
 .../main/java/org/apache/ignite/ml/math/Blas.java  |   2 +-
 .../ignite/ml/math/isolve/lsqr/AbstractLSQR.java   |   2 +-
 .../ignite/ml/math/isolve/lsqr/LSQROnHeap.java     |   2 +-
 .../matrix/storage/SparseMatrixStorage.java        |   8 +-
 .../math/primitives/vector/impl/SparseVector.java  |   2 +-
 .../vector/storage/SparseVectorStorage.java        |   4 +-
 .../apache/ignite/ml/math/stat/Distribution.java   |   3 +-
 .../ignite/ml/math/stat/DistributionMixture.java   |   7 +-
 .../ignite/ml/multiclass/MultiClassModel.java      |   7 +-
 .../discrete/DiscreteNaiveBayesModel.java          |   5 +-
 .../gaussian/GaussianNaiveBayesModel.java          |   5 +-
 .../updatecalculators/RPropParameterUpdate.java    |   9 +-
 .../updatecalculators/SimpleGDParameterUpdate.java |   7 +-
 .../ml/selection/cv/DebugCrossValidation.java      |   3 +-
 .../scoring/cursor/LocalLabelPairCursor.java       |   7 +-
 .../selection/scoring/evaluator/package-info.java  |   4 +-
 .../randomforest/data/impurity/GiniHistogram.java  |  13 +-
 .../data/impurity/ImpurityHistogram.java           |   3 +-
 .../data/impurity/ImpurityHistogramsComputer.java  |  13 +-
 .../randomforest/data/impurity/MSEHistogram.java   |   9 +-
 .../data/statistics/LeafValuesComputer.java        |  13 +-
 .../NormalDistributionStatisticsComputer.java      |   9 +-
 .../primitives/vector/VectorGenerator.java         |  15 +-
 .../primitives/vector/VectorGeneratorsFamily.java  |   9 +-
 .../apache/ignite/ml/common/KeepBinaryTest.java    |   3 +-
 .../convergence/ConvergenceCheckerTest.java        |   7 +-
 .../deploy/DeployingContextImplTest.java           |   2 +-
 .../apache/ignite/ml/knn/LabeledDatasetHelper.java |   5 +-
 .../ignite/ml/nn/MLPTrainerIntegrationTest.java    |  10 +-
 .../org/apache/ignite/ml/nn/MLPTrainerTest.java    |  18 +-
 .../ml/selection/cv/CrossValidationTest.java       |   9 +-
 .../gini/GiniImpurityMeasureCalculatorTest.java    |   2 +-
 .../mse/MSEImpurityMeasureCalculatorTest.java      |   2 +-
 .../data/impurity/MSEHistogramTest.java            |   5 +-
 .../apache/ignite/stream/mqtt/MqttStreamer.java    |  16 +-
 .../ignite/stream/mqtt/IgniteMqttStreamerTest.java |   8 +-
 .../opencensus/OpenCensusMetricExporterSpi.java    |  14 +-
 .../OpenCensusMetricExporterSpiTest.java           |   4 +-
 .../org/apache/ignite/osgi/IgniteOsgiUtils.java    |   2 +-
 modules/platforms/cpp/CMakeLists.txt               |  83 ++
 modules/platforms/cpp/DEVNOTES.txt                 |  77 +-
 modules/platforms/cpp/Makefile.am                  |  77 --
 modules/platforms/cpp/Makefile.amrel               |  59 --
 modules/platforms/cpp/binary/CMakeLists.txt        |  73 ++
 modules/platforms/cpp/binary/Makefile.am           |  74 --
 modules/platforms/cpp/binary/configure.ac          |  62 --
 modules/platforms/cpp/binary/include/Makefile.am   |  51 --
 modules/platforms/cpp/cmake/FindIgnite.cmake       |  45 +
 modules/platforms/cpp/cmake/FindODBC.cmake         | 148 ++++
 modules/platforms/cpp/common/CMakeLists.txt        |  81 ++
 modules/platforms/cpp/common/Makefile.am           |  63 --
 modules/platforms/cpp/common/configure.ac          |  62 --
 modules/platforms/cpp/common/include/Makefile.am   |  45 -
 .../cpp/common/os/linux/include/Makefile.am        |  25 -
 .../os/linux/include/ignite/common/concurrent_os.h |   6 +-
 .../common/os/linux/src/common/platform_utils.cpp  |   5 +-
 modules/platforms/cpp/configure.ac                 | 126 ---
 modules/platforms/cpp/configure.acrel              | 109 ---
 modules/platforms/cpp/core-test/CMakeLists.txt     |  76 ++
 modules/platforms/cpp/core-test/Makefile.am        |  96 --
 modules/platforms/cpp/core-test/configure.ac       |  62 --
 .../platforms/cpp/core-test/include/Makefile.am    |  24 -
 modules/platforms/cpp/core/CMakeLists.txt          |  54 ++
 modules/platforms/cpp/core/Makefile.am             |  85 --
 modules/platforms/cpp/core/configure.ac            |  62 --
 modules/platforms/cpp/core/ignite.pc.in            |   9 -
 modules/platforms/cpp/core/include/Makefile.am     |  82 --
 modules/platforms/cpp/examples/CMakeLists.txt      |  36 +
 modules/platforms/cpp/examples/Makefile.am         |  28 -
 modules/platforms/cpp/examples/README.txt          |  21 +-
 .../cpp/examples/compute-example/CMakeLists.txt    |  31 +
 .../cpp/examples/compute-example/Makefile.am       |  59 --
 modules/platforms/cpp/examples/configure.ac        |  64 --
 .../continuous-query-example/CMakeLists.txt        |  31 +
 .../examples/continuous-query-example/Makefile.am  |  58 --
 modules/platforms/cpp/examples/include/Makefile.am |  24 -
 .../cpp/examples/odbc-example/CMakeLists.txt       |  33 +
 .../cpp/examples/odbc-example/Makefile.am          |  59 --
 .../cpp/examples/put-get-example/CMakeLists.txt    |  31 +
 .../cpp/examples/put-get-example/Makefile.am       |  58 --
 .../cpp/examples/query-example/CMakeLists.txt      |  31 +
 .../cpp/examples/query-example/Makefile.am         |  58 --
 .../thin-client-put-get-example/CMakeLists.txt     |  28 +
 .../thin-client-put-get-example/Makefile.am        |  53 --
 modules/platforms/cpp/ignite/CMakeLists.txt        |  32 +
 modules/platforms/cpp/ignite/Makefile.am           |  61 --
 modules/platforms/cpp/ignite/configure.ac          |  62 --
 modules/platforms/cpp/jni/CMakeLists.txt           |  43 +
 modules/platforms/cpp/jni/Makefile.am              |  65 --
 modules/platforms/cpp/jni/configure.ac             |  62 --
 modules/platforms/cpp/jni/include/Makefile.am      |  25 -
 modules/platforms/cpp/jni/os/linux/src/utils.cpp   |  33 +-
 modules/platforms/cpp/jni/os/win/src/utils.cpp     |  24 +-
 modules/platforms/cpp/network/CMakeLists.txt       |  74 ++
 modules/platforms/cpp/network/Makefile.am          |  63 --
 modules/platforms/cpp/network/configure.ac         |  62 --
 modules/platforms/cpp/network/include/Makefile.am  |  28 -
 .../os/linux/src/network/tcp_socket_client.cpp     |   5 +-
 .../cpp/network/src/network/ssl/ssl_gateway.cpp    |  16 +-
 modules/platforms/cpp/odbc-test/CMakeLists.txt     | 104 +++
 modules/platforms/cpp/odbc-test/Makefile.am        | 127 ---
 modules/platforms/cpp/odbc-test/config/ssl/ca.pem  |  50 +-
 .../cpp/odbc-test/config/ssl/client_full.pem       | 132 ++-
 .../cpp/odbc-test/config/ssl/client_unknown.pem    |  94 +-
 .../odbc-test/config/ssl/generate_certificates.sh  | 119 +++
 .../platforms/cpp/odbc-test/config/ssl/server.jks  | Bin 4256 -> 2392 bytes
 .../platforms/cpp/odbc-test/config/ssl/trust.jks   | Bin 1089 -> 1199 bytes
 .../platforms/cpp/odbc-test/include/Makefile.am    |  26 -
 modules/platforms/cpp/odbc/CMakeLists.txt          | 108 +++
 modules/platforms/cpp/odbc/Makefile.am             | 106 ---
 modules/platforms/cpp/odbc/configure.ac            |  62 --
 modules/platforms/cpp/odbc/include/Makefile.am     |  73 --
 .../platforms/cpp/thin-client-test/CMakeLists.txt  |  53 ++
 modules/platforms/cpp/thin-client-test/Makefile.am |  79 --
 .../cpp/thin-client-test/config/ssl/ca.pem         |  50 +-
 .../thin-client-test/config/ssl/client_full.pem    | 132 ++-
 .../thin-client-test/config/ssl/client_unknown.pem |  94 +-
 .../config/ssl/generate_certificates.sh            | 119 +++
 .../cpp/thin-client-test/config/ssl/server.jks     | Bin 4256 -> 2392 bytes
 .../cpp/thin-client-test/config/ssl/trust.jks      | Bin 1089 -> 1199 bytes
 .../platforms/cpp/thin-client-test/configure.ac    |  62 --
 .../cpp/thin-client-test/include/Makefile.am       |  24 -
 modules/platforms/cpp/thin-client/CMakeLists.txt   |  48 +
 modules/platforms/cpp/thin-client/Makefile.am      |  75 --
 .../platforms/cpp/thin-client/include/Makefile.am  |  32 -
 .../ApiParity/ClusterParityTest.cs                 |   4 +-
 .../Impl/Client/Compute/ComputeClient.cs           |   2 +-
 .../Apache.Ignite.Core/Impl/Common/Classpath.cs    |   9 +-
 .../http/jetty/GridJettyObjectMapper.java          |  12 +-
 .../protocols/http/jetty/GridJettyRestHandler.java |   6 +-
 .../jetty/IgniteBinaryObjectJsonDeserializer.java  |   8 +-
 .../protocols/http/jetty/RestSetupSimpleTest.java  |   4 +-
 .../schedule/IgniteScheduleProcessor.java          |   2 +-
 .../processors/schedule/ScheduleFutureImpl.java    |   8 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java     |   7 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java     |   7 +-
 modules/spring-data-2.0/README.txt                 |  15 +
 modules/spring-data-2.0/pom.xml                    |   6 +
 .../springdata20/repository/IgniteRepository.java  |  73 +-
 .../repository/config/DynamicQueryConfig.java      | 348 ++++++++
 .../config/EnableIgniteRepositories.java           |   4 +-
 .../IgniteRepositoryConfigurationExtension.java    |   2 +-
 .../springdata20/repository/config/Query.java      | 106 ++-
 .../repository/config/RepositoryConfig.java        |  38 +-
 .../repository/query/DeclaredQuery.java            |  96 ++
 .../repository/query/EmptyDeclaredQuery.java       |  74 ++
 .../query/ExpressionBasedStringQuery.java          | 153 ++++
 .../springdata20/repository/query/IgniteQuery.java |  74 +-
 .../repository/query/IgniteQueryGenerator.java     |  33 +-
 .../repository/query/IgniteRepositoryQuery.java    | 961 ++++++++++++++++++---
 .../springdata20/repository/query/QueryUtils.java  | 307 +++++++
 .../springdata20/repository/query/StringQuery.java | 879 +++++++++++++++++++
 .../repository/query/spel/SpelEvaluator.java       |  96 ++
 .../repository/query/spel/SpelQueryContext.java    | 342 ++++++++
 .../repository/support/ConditionFalse.java         |   5 +-
 .../support/IgniteRepositoryFactory.java           | 195 +++--
 .../support/IgniteRepositoryFactoryBean.java       |  58 +-
 .../repository/support/IgniteRepositoryImpl.java   | 158 ++--
 .../IgniteSpringDataCrudSelfExpressionTest.java    |  16 +-
 .../springdata/IgniteSpringDataCrudSelfTest.java   | 231 +++--
 .../IgniteSpringDataQueriesSelfTest.java           | 128 ++-
 .../springdata/misc/ApplicationConfiguration.java  |  72 +-
 ...ithCompoundKey.java => FullNameProjection.java} |  17 +-
 .../org/apache/ignite/springdata/misc/Person.java  |   2 +
 .../ignite/springdata/misc/PersonProjection.java}  |  27 +-
 .../ignite/springdata/misc/PersonRepository.java   |  34 +-
 ...va => PersonRepositoryOtherIgniteInstance.java} |  33 +-
 .../misc/PersonRepositoryWithCompoundKey.java      |   2 +-
 .../misc/SampleEvaluationContextExtension.java     |  92 ++
 modules/spring-data-2.2/README.txt                 |  15 +
 modules/spring-data-2.2/pom.xml                    |   6 +
 .../springdata22/repository/IgniteRepository.java  |  73 +-
 .../repository/config/DynamicQueryConfig.java      | 348 ++++++++
 .../config/EnableIgniteRepositories.java           |   5 +-
 .../config/IgniteRepositoriesRegistar.java         |   1 +
 .../IgniteRepositoryConfigurationExtension.java    |   2 +-
 .../springdata22/repository/config/Query.java      | 105 ++-
 .../repository/config/RepositoryConfig.java        |  38 +
 .../repository/query/DeclaredQuery.java            |  96 ++
 .../repository/query/EmptyDeclaredQuery.java       |  74 ++
 .../query/ExpressionBasedStringQuery.java          | 153 ++++
 .../springdata22/repository/query/IgniteQuery.java |  74 +-
 .../repository/query/IgniteQueryGenerator.java     |  33 +-
 .../repository/query/IgniteRepositoryQuery.java    | 961 ++++++++++++++++++---
 .../springdata22/repository/query/QueryUtils.java  | 307 +++++++
 .../springdata22/repository/query/StringQuery.java | 879 +++++++++++++++++++
 .../repository/support/ConditionFalse.java         |   5 +-
 .../support/IgniteRepositoryFactory.java           | 195 +++--
 .../support/IgniteRepositoryFactoryBean.java       |  58 +-
 .../repository/support/IgniteRepositoryImpl.java   | 158 ++--
 .../IgniteSpringDataCrudSelfExpressionTest.java    |  17 +-
 .../springdata/IgniteSpringDataCrudSelfTest.java   | 233 +++--
 .../IgniteSpringDataQueriesSelfTest.java           | 114 ++-
 .../springdata/misc/ApplicationConfiguration.java  |  72 +-
 .../springdata/misc/FullNameProjection.java}       |  17 +-
 .../org/apache/ignite/springdata/misc/Person.java  |   2 +
 ...yWithCompoundKey.java => PersonProjection.java} |  27 +-
 .../ignite/springdata/misc/PersonRepository.java   |  37 +-
 ...va => PersonRepositoryOtherIgniteInstance.java} |  35 +-
 .../misc/PersonRepositoryWithCompoundKey.java      |   2 +-
 .../springdata/misc/PersonSecondRepository.java    |   1 +
 .../misc/SampleEvaluationContextExtension.java     |  93 ++
 .../IgniteSpringDataQueriesSelfTest.java           |   2 +-
 .../GridServiceInjectionSpringResourceTest.java    |  13 +-
 .../ignite/testsuites/IgniteSpringTestSuite.java   |  12 +-
 .../util/nodestart/StartNodeCallableImpl.java      |  10 +-
 .../ignite/tools/javadoc/IgniteLinkTaglet.java     |   4 +-
 .../ignite/tools/javadoc/IgniteLinkTaglet.java     |   4 +-
 .../visor/commands/start/VisorStartCommand.scala   |   4 +-
 .../apache/ignite/console/agent/AgentLauncher.java |   6 +-
 .../apache/ignite/console/agent/AgentUtils.java    |   6 +-
 .../console/agent/handlers/AbstractListener.java   |   6 +-
 .../console/agent/handlers/ClusterListener.java    |   6 +-
 .../console/agent/handlers/DatabaseListener.java   |   2 +-
 .../ignite/console/agent/rest/RestExecutor.java    |   4 +-
 .../ignite/console/demo/AgentClusterDemo.java      |   6 +-
 .../console/agent/rest/RestExecutorSelfTest.java   |   6 +-
 .../apache/ignite/webtest/TestJtaTxServlet.java    |   2 +-
 .../ignite/cache/websession/WebSessionV2.java      |  21 +-
 .../internal/websession/WebSessionSelfTest.java    |  20 +-
 .../ignite/yardstick/IgniteAbstractBenchmark.java  |   2 +-
 .../ignite/yardstick/IgniteBenchmarkArguments.java |   6 +-
 .../cache/IgniteCreateIndexBenchmark.java          |  17 +-
 .../cache/IgniteInvokeWithInjectionBenchmark.java  |   5 +-
 .../cache/IgnitePutGetWithPageReplacements.java    |  13 +-
 .../yardstick/cache/IgnitePutValue8Benchmark.java  |   3 +-
 .../cache/WaitMapExchangeFinishCallable.java       |   2 +-
 .../failover/IgniteFailoverAbstractBenchmark.java  |   2 +-
 .../yardstick/upload/UploadBenchmarkArguments.java |   2 +-
 parent/pom.xml                                     |  13 +
 pom.xml                                            |  81 +-
 1105 files changed, 18676 insertions(+), 7884 deletions(-)

diff --cc parent/pom.xml
index 6e12a59,aad7b6c..f00802b
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@@ -862,7 -865,14 +865,15 @@@
                                          <exclude>**/keystore/ca/*.txt.attr</exclude><!--auto generated files-->
                                          <exclude>**/keystore/ca/*serial</exclude><!--auto generated files-->
                                          <exclude>**/META-INF/services/**</exclude> <!-- Interface mappings: cannot be changed -->
 +                                        <exclude>**/id_rsa**</exclude>  <!--SSH-->
+                                         <!-- spring data 2.X modules, borrowed code from spring-jpa 5.2.0, Apache 2.0 licenses -->
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/QueryUtils.java</exclude>
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/EmptyDeclaredQuery.java</exclude>
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/ExpressionBasedStringQuery.java</exclude>
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/spel/SpelEvaluator.java</exclude>
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/spel/SpelQueryContext.java</exclude>
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/DeclaredQuery.java</exclude>
+                                         <exclude>src/main/java/org/apache/ignite/springdata2*/repository/query/StringQuery.java</exclude>
                                          <!--special excludes-->
                                          <exclude>.travis.yml</exclude>
                                          <exclude>.github/PULL_REQUEST_TEMPLATE.md</exclude>