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 2021/03/24 14:15:12 UTC

[ignite] 01/01: Merge remote-tracking branch 'origin/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 0af35928ef29324130493a0caf27d116e111c05f
Merge: 25841d2 8d7a8eb
Author: Anton Vinogradov <av...@apache.org>
AuthorDate: Wed Mar 24 16:46:50 2021 +0300

    Merge remote-tracking branch 'origin/master' into ignite-ducktape

 .travis.yml                                        |    2 +-
 README.txt                                         |    3 -
 assembly/release-apache-ignite-base.xml            |   76 -
 checkstyle/checkstyle.xml                          |    8 +
 docs/Gemfile                                       |    3 +
 docs/_data/toc.yaml                                |    6 +-
 .../org/apache/ignite/snippets/WarmUpStrategy.java |   83 +
 docs/_docs/code-snippets/xml/warm-up-strategy.xml  |   71 +
 docs/_docs/memory-configuration/data-regions.adoc  |   97 +-
 docs/_docs/monitoring-metrics/metrics.adoc         |   19 +
 .../monitoring-metrics/new-metrics-system.adoc     |    2 -
 docs/_docs/monitoring-metrics/new-metrics.adoc     |    4 +-
 docs/_docs/persistence/snapshot-directory.adoc     |   39 +
 docs/_docs/quick-start/nodejs.adoc                 |    6 +-
 docs/_docs/quick-start/php.adoc                    |   17 +-
 docs/_docs/quick-start/python.adoc                 |    2 +-
 .../{persistence => snapshots}/snapshots.adoc      |   34 +-
 docs/_docs/thin-clients/cpp-thin-client.adoc       |   57 +
 docs/_docs/thin-clients/nodejs-thin-client.adoc    |    4 +-
 docs/_docs/thin-clients/php-thin-client.adoc       |   14 +-
 docs/_docs/thin-clients/python-thin-client.adoc    |    8 +-
 docs/_docs/tools/control-script.adoc               |   19 +
 .../ignite/examples/spark/SharedRDDExample.java    |    2 +-
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java    |    4 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java    |    4 +-
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java       |    2 +-
 .../internal/jdbc2/JdbcComplexQuerySelfTest.java   |    2 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java       |    2 +-
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |    2 +-
 .../jdbc2/JdbcNoCacheStreamingSelfTest.java        |    2 +-
 .../jdbc2/JdbcPreparedStatementSelfTest.java       |    2 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java      |    2 +-
 .../internal/jdbc2/JdbcStatementSelfTest.java      |    2 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java      |    4 +-
 .../jdbc2/JdbcStreamingToPublicCacheTest.java      |    2 +-
 .../ignite/jdbc/AbstractJdbcPojoQuerySelfTest.java |    2 +-
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java      |    2 +-
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |    2 +-
 .../apache/ignite/jdbc/JdbcMetadataSelfTest.java   |    2 +-
 .../ignite/jdbc/JdbcPreparedStatementSelfTest.java |    2 +-
 .../apache/ignite/jdbc/JdbcStatementSelfTest.java  |    2 +-
 .../thin/JdbcThinAbstractDmlStatementSelfTest.java |    4 +-
 .../ignite/jdbc/thin/JdbcThinBulkLoadSelfTest.java |    4 +-
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java    |    2 +-
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |    2 +-
 .../thin/JdbcThinPartitionAwarenessSelfTest.java   |    4 +-
 .../thin/JdbcThinPreparedStatementSelfTest.java    |    2 +-
 .../jdbc/thin/JdbcThinResultSetSelfTest.java       |    2 +-
 .../jdbc/thin/JdbcThinStatementCancelSelfTest.java |    2 +-
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |    2 +-
 .../thin/JdbcThinStatementTimeoutSelfTest.java     |    2 +-
 .../qa/query/WarningOnBigQueryResultsBaseTest.java |    4 +-
 .../clients/AbstractClientCompatibilityTest.java   |   17 +-
 .../persistence/FoldersReuseCompatibilityTest.java |    2 +-
 .../persistence/InlineIndexCompatibilityTest.java  |  359 +++
 .../IgniteCompatibilityBasicTestSuite.java         |    2 +
 .../AbstractPageCompressionIntegrationTest.java    |    2 +-
 .../compress/CompressionConfigurationTest.java     |    4 +-
 .../compress/CompressionProcessorTest.java         |    6 +-
 .../DiskPageCompressionIntegrationTest.java        |   10 +-
 .../WalPageCompressionIntegrationTest.java         |    4 +-
 .../internal/commandline/cache/IdleVerify.java     |   44 +-
 .../internal/commandline/query/KillCommand.java    |    2 +-
 .../commandline/snapshot/SnapshotCommand.java      |   51 +-
 .../commandline/snapshot/SnapshotSubcommand.java   |   25 +-
 .../commandline/CommandHandlerParsingTest.java     |    2 +-
 .../util/GridCommandHandlerAbstractTest.java       |    7 +-
 .../util/GridCommandHandlerClusterByClassTest.java |   36 +-
 .../util/GridCommandHandlerIndexingTest.java       |    2 +-
 .../GridCommandHandlerInterruptCommandTest.java    |    2 +-
 .../util/GridCommandHandlerPropertiesTest.java     |   39 +
 .../apache/ignite/util/GridCommandHandlerTest.java |   55 +-
 .../java/org/apache/ignite/DataRegionMetrics.java  |   12 +-
 .../apache/ignite/DataRegionMetricsAdapter.java    |   12 +-
 .../java/org/apache/ignite/DataStorageMetrics.java |   26 +-
 .../apache/ignite/DataStorageMetricsAdapter.java   |   12 +-
 .../src/main/java/org/apache/ignite/Ignite.java    |    9 +-
 .../java/org/apache/ignite/IgniteSemaphore.java    |   13 +
 .../org/apache/ignite/IgniteSystemProperties.java  |    4 +-
 .../main/java/org/apache/ignite/MemoryMetrics.java |    3 +-
 .../java/org/apache/ignite/PersistenceMetrics.java |    3 +-
 .../org/apache/ignite/binary/BinaryObject.java     |    6 +
 .../java/org/apache/ignite/cache/QueryEntity.java  |    2 +-
 .../sorted/SortedEvictionPolicyFactory.java        |    2 +-
 .../cache/store/jdbc/dialect/OracleDialect.java    |    7 +-
 .../ignite/client/ClientCacheConfiguration.java    |   44 +
 .../ignite/configuration/CacheConfiguration.java   |    4 +-
 .../events/CacheConsistencyViolationEvent.java     |    4 +-
 .../ignite/internal/GridEventConsumeHandler.java   |    2 +-
 .../internal/TransactionMetricsMxBeanImpl.java     |   13 +-
 .../internal/binary/BinaryEnumObjectImpl.java      |   14 +
 .../ignite/internal/binary/BinaryObjectImpl.java   |    5 +
 .../internal/binary/BinaryObjectOffheapImpl.java   |    5 +
 .../internal/client/thin/TcpClientChannel.java     |    2 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java       |    2 +-
 .../managers/discovery/GridDiscoveryManager.java   |    2 +-
 .../cache/CacheAffinitySharedManager.java          |   12 +-
 .../processors/cache/CacheEvictableEntryImpl.java  |    2 +-
 .../cache/CacheGroupMetricsMXBeanImpl.java         |   12 +-
 .../cache/CacheLocalMetricsMXBeanImpl.java         |   14 +-
 .../processors/cache/CacheMetricsImpl.java         |    8 +-
 .../processors/cache/ClusterCachesInfo.java        |    2 +
 .../cache/GridCacheDeploymentManager.java          |   25 +-
 .../processors/cache/GridCacheIoManager.java       |    2 +-
 .../processors/cache/GridCacheMapEntry.java        |    4 +-
 .../cache/GridCachePartitionExchangeManager.java   |    3 +
 .../processors/cache/GridCacheProcessor.java       |    2 +-
 .../processors/cache/GridCacheSharedContext.java   |    3 +-
 .../internal/processors/cache/GridCacheUtils.java  |    3 +
 .../binary/CacheObjectBinaryProcessorImpl.java     |    6 +-
 .../dht/preloader/GridDhtPartitionDemander.java    |   65 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |   78 +-
 .../dht/topology/GridClientPartitionTopology.java  |    2 +-
 .../dht/topology/GridDhtPartitionsReservation.java |    4 +-
 .../cache/distributed/near/GridNearGetFuture.java  |    2 +-
 .../cache/distributed/near/GridNearLockFuture.java |    2 +-
 .../cache/persistence/CacheDataRowAdapter.java     |   77 +-
 .../persistence/DataRegionMetricsMXBeanImpl.java   |   12 +-
 .../cache/persistence/DataStorageMetricsImpl.java  |   57 +-
 .../persistence/DataStorageMetricsSnapshot.java    |   30 +-
 .../GridCacheDatabaseSharedManager.java            |   26 +-
 .../cache/persistence/GridCacheOffheapManager.java |    2 +-
 .../IgniteCacheDatabaseSharedManager.java          |   46 +-
 .../cache/persistence/RecoveryDebug.java           |    2 +-
 .../persistence/checkpoint/CheckpointManager.java  |    7 +-
 .../cache/persistence/checkpoint/Checkpointer.java |   34 +-
 .../checkpoint/LightweightCheckpointManager.java   |    3 +-
 .../CachePartitionDefragmentationManager.java      |   12 +-
 .../cache/persistence/file/FilePageStore.java      |   16 +-
 .../persistence/file/FilePageStoreFactory.java     |   56 -
 .../persistence/file/FilePageStoreManager.java     |   69 +-
 .../file/FileVersionCheckingFactory.java           |   28 +-
 .../snapshot/IgniteSnapshotManager.java            |  538 ++++-
 .../snapshot/IgniteSnapshotVerifyException.java}   |   50 +-
 .../persistence/snapshot/SnapshotFutureTask.java   |   24 +-
 .../persistence/snapshot/SnapshotMetadata.java     |  199 ++
 .../snapshot/SnapshotMetadataCollectorTask.java    |  111 +
 .../snapshot/SnapshotPartitionsVerifyTask.java     |  319 +++
 .../cache/persistence/tree/BPlusTree.java          |    6 +-
 .../persistence/tree/io/AbstractDataPageIO.java    |    2 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |  164 +-
 .../processors/cache/query/CacheQueryEntry.java    |    2 +-
 .../query/GridCacheDistributedQueryManager.java    |    2 +-
 .../cache/query/jdbc/GridCacheQueryJdbcTask.java   |    6 +-
 .../cache/store/GridCacheWriteBehindStore.java     |   10 +-
 .../processors/cache/tree/CacheDataTree.java       |    2 +-
 .../internal/processors/cache/tree/DataRow.java    |    7 +
 .../cache/verify/IdleVerifyResultV2.java           |  102 +-
 .../processors/cache/verify/IdleVerifyUtility.java |  114 +-
 .../cache/verify/PartitionHashRecordV2.java        |   10 +-
 .../verify/VerifyBackupPartitionsDumpTask.java     |    8 +-
 .../cache/verify/VerifyBackupPartitionsTask.java   |    2 +-
 .../cache/verify/VerifyBackupPartitionsTaskV2.java |  190 +-
 .../processors/datastreamer/DataStreamerImpl.java  |    2 +-
 .../datastructures/AtomicDataStructureProxy.java   |    2 +-
 .../datastructures/DataStructuresProcessor.java    |    2 +-
 .../datastructures/GridCacheLockImpl.java          |    2 +-
 .../datastructures/GridCacheSemaphoreImpl.java     |   35 +
 .../datastructures/GridCacheSemaphoreState.java    |    4 +-
 .../processors/jobmetrics/GridJobMetrics.java      |   12 +-
 .../jobmetrics/GridJobMetricsProcessor.java        |   12 +-
 .../jobmetrics/GridJobMetricsSnapshot.java         |   12 +-
 .../internal/processors/odbc/SqlListenerUtils.java |    2 +-
 .../cache/ClientCacheSqlFieldsQueryRequest.java    |    2 +-
 .../platform/cluster/PlatformClusterGroup.java     |    2 +-
 .../internal/processors/query/QueryUtils.java      |   54 +-
 .../processors/query/RunningQueryManager.java      |    5 +-
 .../internal/processors/tracing/SpanTags.java      |    3 +
 .../org/apache/ignite/internal/util/GridDebug.java |    4 +-
 .../ignite/internal/util/GridJavaProcess.java      |    9 +-
 .../ignite/internal/util/GridMutableLong.java}     |   58 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |   30 +-
 .../ignite/internal/util/collection/IntMap.java    |   30 +
 .../util/distributed/DistributedProcess.java       |    2 +-
 .../util/ipc/loopback/IpcServerTcpEndpoint.java    |    2 +-
 .../ipc/shmem/IpcSharedMemoryServerEndpoint.java   |    2 +-
 .../internal/util/nio/ssl/GridNioSslHandler.java   |   12 +
 .../util/offheap/unsafe/GridUnsafeMap.java         |    2 +-
 .../util/tostring/CircularStringBuilder.java       |    2 +-
 .../visor/cache/index/IndexRebuildStatusTask.java  |    2 +-
 .../diagnostic/VisorPageLocksTrackerArgs.java      |    2 +-
 .../visor/snapshot/VisorSnapshotCheckTask.java     |   60 +
 .../java/org/apache/ignite/lang/IgniteBiTuple.java |    2 +-
 .../ignite/mxbean/CacheGroupMetricsMXBean.java     |   10 +-
 .../apache/ignite/mxbean/CacheMetricsMXBean.java   |   70 +-
 .../ignite/mxbean/DataRegionMetricsMXBean.java     |   32 +-
 .../ignite/mxbean/DataStorageMetricsMXBean.java    |   20 +-
 .../org/apache/ignite/mxbean/IgniteMXBean.java     |   74 +-
 .../org/apache/ignite/mxbean/ThreadPoolMXBean.java |   20 +-
 .../ignite/mxbean/TransactionMetricsMxBean.java    |   12 +-
 .../ignite/plugin/security/SecurityPermission.java |    2 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java    |    9 +-
 .../priorityqueue/PriorityQueueCollisionSpi.java   |    2 +-
 .../tcp/internal/CommunicationTcpUtils.java        |   40 +-
 .../tcp/internal/ConnectionClientPool.java         |   20 +-
 .../tcp/internal/GridNioServerWrapper.java         |   39 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java       |   45 +-
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |   20 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java    |   14 +-
 .../apache/ignite/spi/indexing/IndexingSpi.java    |    2 +-
 .../ignite/spi/indexing/noop/NoopIndexingSpi.java  |    2 +-
 .../ignite/spi/metric/MetricExporterSpi.java       |   11 +-
 .../ignite/spi/metric/ReadOnlyMetricRegistry.java  |   32 +
 .../spi/metric/jmx/JmxMetricExporterSpi.java       |   55 +-
 .../apache/ignite/stream/StreamTransformer.java    |    2 +-
 .../java/org/jsr166/ConcurrentLinkedHashMap.java   |    8 +-
 .../store/StoreResourceInjectionSelfTest.java      |    4 +-
 .../store/jdbc/dialect/OracleDialectTest.java      |   49 +
 .../TestJdbcPojoStoreFactoryWithHangWriteAll.java  |    2 +-
 .../org/apache/ignite/client/FunctionalTest.java   |   32 +-
 .../failure/FailureHandlerTriggeredTest.java       |    2 +-
 .../GridMultithreadedJobStealingSelfTest.java      |   12 +-
 .../internal/GridNodeMetricsLogPdsSelfTest.java    |   11 +-
 .../internal/GridNodeMetricsLogSelfTest.java       |   17 +-
 .../ignite/internal/IgniteClientFailuresTest.java  |   97 +-
 .../internal/binary/BinaryEnumsSelfTest.java       |    1 +
 .../BinaryFooterOffsetsAbstractSelfTest.java       |    2 +
 .../internal/binary/BinaryMarshallerSelfTest.java  |    1 +
 ...ectByteBufferStreamImplV2ByteOrderSelfTest.java |   18 +-
 .../optimized/OptimizedMarshallerTest.java         |   12 +-
 .../cache/CacheGroupsMetricsRebalanceTest.java     |   52 +-
 ...InterceptorPartitionCounterLocalSanityTest.java |   12 +-
 .../processors/cache/CacheRebalancingSelfTest.java |    2 +-
 .../cache/CacheStopAndDestroySelfTest.java         |   20 +-
 .../ClientFastReplyCoordinatorFailureTest.java     |  100 +
 .../cache/GridCacheEntryVersionSelfTest.java       |    2 +-
 .../cache/GridCacheOffheapUpdateSelfTest.java      |    2 +-
 .../cache/GridCacheTtlManagerLoadTest.java         |    2 +-
 .../IgniteCacheClusterReadOnlyModeSelfTest.java    |    4 +-
 .../processors/cache/IgniteCacheGroupsTest.java    |    2 +-
 ...acheAbstractDataStructuresFailoverSelfTest.java |    2 +-
 .../GridCacheAtomicStampedApiSelfAbstractTest.java |    2 +-
 .../IgniteAtomicStampedClusterReadOnlyTest.java    |    2 +-
 .../datastructures/IgniteLockAbstractSelfTest.java |    2 +-
 .../IgniteSemaphoreAbstractSelfTest.java           |   95 +
 .../SemaphoreFailoverNoWaitingAcquirerTest.java    |    2 +-
 .../distributed/CacheBlockOnReadAbstractTest.java  |    2 +-
 .../GridCacheMultiNodeLockAbstractTest.java        |   12 +-
 .../distributed/GridExchangeFreeSwitchTest.java    |    8 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java        |    2 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java        |    2 +-
 ...lanceIsProcessingWhenAssignmentIsEmptyTest.java |    2 +-
 .../dht/topology/PartitionEvictionOrderTest.java   |  159 ++
 .../GridCacheRebalancingSyncSelfTest.java          |    2 +-
 .../rebalancing/RebalanceMetricsTest.java          |  112 +
 ...teCacheStoreSessionWriteBehindAbstractTest.java |    4 +-
 .../GridCacheFastNodeLeftForTransactionTest.java   |    2 +-
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |    2 +-
 .../cache/mvcc/CacheMvccAbstractTest.java          |    6 +-
 .../mvcc/CacheMvccConfigurationValidationTest.java |    6 +-
 .../IgniteDataStorageMetricsSelfTest.java          |  142 ++
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |    2 +-
 .../IgnitePdsCacheRebalancingAbstractTest.java     |    2 +-
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |    2 +-
 .../IgnitePdsSporadicDataRecordsOnBackupTest.java  |    2 +-
 .../db/IgnitePdsDataRegionMetricsTest.java         |   19 +-
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |    2 +-
 .../db/file/IgnitePdsCheckpointSimpleTest.java     |   59 +-
 .../db/file/IgnitePdsThreadInterruptionTest.java   |    2 +-
 .../db/wal/WalArchiveSizeConfigurationTest.java    |  132 ++
 .../db/wal/WalDeletionArchiveAbstractTest.java     |   29 +-
 .../db/wal/WriteAheadLogManagerSelfTest.java       |  141 +-
 .../pagelocktracker/log/PageLockLogTest.java       |    6 +-
 .../snapshot/AbstractSnapshotSelfTest.java         |   24 +-
 .../snapshot/IgniteClusterSnapshotCheckTest.java   |  540 +++++
 .../snapshot/IgniteSnapshotManagerSelfTest.java    |  180 +-
 .../IgniteChangeGlobalStateCacheTest.java          |    2 +-
 .../wal/AbstractWalDeltaConsistencyTest.java       |    2 +-
 .../cache/query/CacheDataPageScanQueryTest.java    |   10 +-
 .../cache/query/IndexingSpiQuerySelfTest.java      |    2 +-
 .../CacheContinuousQueryCounterAbstractTest.java   |    4 +-
 .../CacheContinuousQueryRandomOperationsTest.java  |    2 +-
 .../continuous/CacheKeepBinaryIterationTest.java   |    4 +-
 .../GridCacheContinuousQueryAbstractSelfTest.java  |   16 +-
 .../GridCacheWriteBehindStoreAbstractSelfTest.java |    2 +-
 ...iteBehindStorePartitionedMultiNodeSelfTest.java |    2 +-
 .../TxRollbackOnTimeoutOnePhaseCommitTest.java     |    8 +-
 .../processors/database/BPlusTreeSelfTest.java     |   24 +-
 .../IgniteDataStreamerPerformanceTest.java         |    2 +-
 .../IgniteMessagingConfigVariationFullApiTest.java |    6 +-
 .../AbstractPerformanceStatisticsTest.java         |    4 +-
 .../ignite/internal/util/GridArraysSelfTest.java   |   20 +-
 .../ignite/internal/util/GridMutableLongTest.java  |   61 +
 .../ignite/internal/util/IgniteUtilsSelfTest.java  |   10 +
 .../internal/util/collection/IntHashMapTest.java   |   27 +
 .../GridOffHeapMapPerformanceAbstractTest.java     |    2 +-
 .../util/tostring/GridToStringBuilderSelfTest.java |    2 +-
 .../GridBoundedConcurrentOrderedMapSelfTest.java   |    4 +-
 .../GridContinuousOperationsLoadTest.java          |   10 +-
 .../marshaller/GridMarshallerAbstractTest.java     |    2 +-
 .../messaging/IgniteMessagingSendAsyncTest.java    |    2 +-
 .../java/org/apache/ignite/p2p/GridP2PTestJob.java |    2 +-
 .../platform/PlatformEventsWriteEventTask.java     |    2 +-
 ...unicationInverseConnectionEstablishingTest.java |   67 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java      |    2 +-
 ...cpClientDiscoverySpiFailureTimeoutSelfTest.java |    1 +
 .../tcp/TcpDiscoveryNodeJoinAndFailureTest.java    |    2 +-
 .../apache/ignite/testframework/GridTestUtils.java |   13 +-
 .../testframework/junits/GridAbstractTest.java     |    6 +-
 .../junits/common/GridCommonAbstractTest.java      |    4 +-
 .../testframework/test/VariationsIteratorTest.java |   10 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java    |    2 +
 .../IgniteBasicWithPersistenceTestSuite.java       |    2 +
 .../testsuites/IgniteCacheMvccTestSuite7.java      |    4 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java    |    2 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |    2 +
 .../testsuites/IgniteKernalSelfTestSuite.java      |    4 +-
 .../ignite/testsuites/IgnitePdsTestSuite2.java     |    3 +
 .../apache/ignite/util/GridLongListSelfTest.java   |   10 +-
 ...ridCommandHandlerClusterByClassTest_help.output |    6 +
 ...andHandlerClusterByClassWithSSLTest_help.output |    6 +
 .../development/utils/IgniteWalConverter.java      |   61 +-
 .../utils/IgniteWalConverterArguments.java         |  137 +-
 .../utils/IgniteWalConverterArgumentsTest.java     |  191 +-
 .../development/utils/IgniteWalConverterTest.java  |  125 +-
 .../ignite/tests/p2p/AlwaysTruePredicate.java      |    2 +-
 .../cache/hibernate/HibernateCacheProxy.java       |    4 +-
 .../processors/query/h2/IgniteH2Indexing.java      |   46 +-
 .../processors/query/h2/database/H2Tree.java       |   57 +-
 .../processors/query/h2/database/H2TreeIndex.java  |    2 +-
 .../h2/database/InlineObjectBytesDetector.java     |  197 ++
 .../query/h2/database/io/AbstractH2LeafIO.java     |    2 +-
 .../processors/query/h2/dml/DmlAstUtils.java       |    2 +-
 .../processors/query/h2/opt/GridH2MetaTable.java   |    2 +-
 .../query/h2/opt/join/CollocationModel.java        |    2 +-
 .../query/h2/opt/join/DistributedJoinContext.java  |    2 +-
 .../query/h2/opt/join/DistributedLookupBatch.java  |    2 +-
 .../processors/query/h2/sql/GridSqlConst.java      |    5 +
 .../processors/query/h2/sql/GridSqlDelete.java     |   10 +-
 .../processors/query/h2/sql/GridSqlInsert.java     |   18 +-
 .../processors/query/h2/sql/GridSqlJoin.java       |    8 +-
 .../processors/query/h2/sql/GridSqlMerge.java      |   16 +-
 .../processors/query/h2/sql/GridSqlQuery.java      |    4 +-
 .../query/h2/sql/GridSqlQuerySplitter.java         |   14 +-
 .../processors/query/h2/sql/GridSqlSelect.java     |   16 +-
 .../processors/query/h2/sql/GridSqlUnion.java      |   14 +-
 .../processors/query/h2/sql/GridSqlUpdate.java     |   12 +-
 .../query/h2/twostep/AbstractReducer.java          |    4 +-
 .../query/h2/twostep/GridMapQueryExecutor.java     |    2 +-
 .../query/h2/twostep/GridReduceQueryExecutor.java  |   10 +-
 .../processors/query/h2/twostep/ReduceIndex.java   |    4 +-
 .../query/h2/twostep/ReducePartitionMapper.java    |   10 +-
 .../query/h2/twostep/SortedReduceIndexAdapter.java |   36 +
 .../visor/verify/ValidateIndexesClosure.java       |   11 +-
 .../cache/BinaryTypeMismatchLoggingTest.java       |    2 +-
 .../CacheGroupMetricsWithIndexBuildFailTest.java   |   10 +-
 .../cache/CacheGroupMetricsWithIndexTest.java      |  204 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java    |    4 +-
 .../processors/cache/GridCacheOffHeapSelfTest.java |    2 +-
 .../cache/GridCacheQuerySimpleBenchmark.java       |    4 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java    |    2 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java    |    9 +-
 .../cache/IgniteCacheCollocatedQuerySelfTest.java  |    8 +-
 .../cache/IgniteCacheDistributedJoinTest.java      |   12 +-
 .../IgniteCacheFieldsQueryNoDataSelfTest.java      |    2 +-
 .../cache/IgniteCacheLargeResultSelfTest.java      |    2 +-
 .../cache/IgniteCacheOffheapEvictQueryTest.java    |    4 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java     |    2 +-
 .../IgniteCacheParallelismQuerySortOrderTest.java  |  257 ++
 .../cache/IgniteCacheQueryLoadSelfTest.java        |    2 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java     |    2 +-
 .../IgniteCacheSqlQueryMultiThreadedSelfTest.java  |    2 +-
 ...heClientQueryReplicatedNodeRestartSelfTest.java |    8 +-
 .../near/IgniteCacheQueryNodeRestartSelfTest.java  |    2 +-
 .../near/IgniteCacheQueryNodeRestartSelfTest2.java |    2 +-
 .../cache/index/H2ConnectionLeaksSelfTest.java     |    2 +-
 .../cache/index/H2DynamicTableSelfTest.java        |    2 +-
 .../cache/index/IgniteDecimalSelfTest.java         |    2 +-
 .../processors/cache/index/IndexMetricsTest.java   |    6 +-
 ...acheMvccAbstractSqlCoordinatorFailoverTest.java |    6 +-
 .../cache/mvcc/CacheMvccBackupsAbstractTest.java   |    6 +-
 .../cache/mvcc/CacheMvccSqlTxModesTest.java        |    2 +-
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |    4 +-
 ...cheMvccSqlTxQueriesWithReducerAbstractTest.java |   38 +-
 .../cache/mvcc/MvccRepeatableReadBulkOpsTest.java  |    2 +-
 .../IgniteClusterSnapshotCheckWithIndexesTest.java |  127 +
 .../IgniteDbSingleNodeWithIndexingPutGetTest.java  |   14 +-
 .../PerformanceStatisticsQueryTest.java            |    4 +-
 .../query/IgniteCacheGroupsCompareQueryTest.java   |    2 +-
 .../query/IgniteSqlParameterizedQueryTest.java     |    2 +-
 .../processors/query/IgniteSqlRoutingTest.java     |    2 +-
 .../query/IgniteSqlSplitterSelfTest.java           |   16 +-
 .../processors/query/LocalQueryLazyTest.java       |    2 +-
 .../query/MemLeakOnSqlWithClientReconnectTest.java |    2 +-
 .../query/RemoveConstantsFromQueryTest.java        |  235 ++
 .../processors/query/RunningQueriesTest.java       |    2 +-
 .../query/SqlFieldTypeValidationTypesTest.java     |   12 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |    4 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java         |   70 +-
 .../processors/query/h2/QueryDataPageScanTest.java |   38 +-
 .../query/h2/sql/AbstractH2CompareQueryTest.java   |    6 +-
 .../query/h2/sql/BaseH2CompareQueryTest.java       |    2 +-
 .../query/h2/sql/GridQueryParsingTest.java         |    4 +-
 .../query/h2/sql/H2CompareBigQueryTest.java        |    2 +-
 ...neOrSinglePartitionsQueryOptimizationsTest.java |    4 +-
 .../h2/twostep/TableViewSubquerySelfTest.java      |    2 +-
 .../IgniteBinaryCacheQueryTestSuite.java           |    4 +
 .../testsuites/IgnitePdsWithIndexingTestSuite.java |    2 +
 .../apache/ignite/ml/dataset/DatasetBuilder.java   |    2 +-
 .../bootstrapping/BootstrappedDatasetBuilder.java  |    2 +-
 .../ignite/ml/environment/logging/MLLogger.java    |    2 +-
 .../ml/preprocessing/PreprocessingTrainer.java     |    2 +-
 .../normalization/NormalizationPreprocessor.java   |    2 +-
 .../selection/split/TrainTestDatasetSplitter.java  |    2 +-
 .../split/mapper/SHA256UniformMapper.java          |    2 +-
 .../impl/local/LocalDatasetBuilderTest.java        |    2 +-
 .../java/org/apache/ignite/ml/math/BlasTest.java   |    4 +-
 .../vector/VectorImplementationsFixtures.java      |    2 +-
 .../discrete/DiscreteNaiveBayesModelTest.java      |    2 +-
 .../discrete/DiscreteNaiveBayesTrainerTest.java    |    2 +-
 .../gini/GiniImpurityMeasureCalculatorTest.java    |   26 +-
 .../mse/MSEImpurityMeasureCalculatorTest.java      |   18 +-
 .../data/impurity/GiniFeatureHistogramTest.java    |    4 +-
 .../data/impurity/ImpurityHistogramTest.java       |    4 +-
 .../monitoring/opencensus/AbstractTracingTest.java |   51 +-
 .../opencensus/OpenCensusSqlJdbcTracingTest.java   |    9 +-
 .../opencensus/OpenCensusSqlNativeTracingTest.java |   15 +-
 .../platforms/cpp/thin-client-test/src/tx_test.cpp |   85 +-
 modules/platforms/cpp/thin-client/CMakeLists.txt   |    1 +
 .../cpp/thin-client/project/vs/thin-client.vcxproj |    1 +
 .../project/vs/thin-client.vcxproj.filters         |   24 +
 .../src/impl/cache/cache_client_impl.cpp           |  145 +-
 .../thin-client/src/impl/cache/cache_client_impl.h |   37 +-
 .../cpp/thin-client/src/impl/data_router.h         |   10 +
 .../platforms/cpp/thin-client/src/impl/message.h   |   18 +-
 ...{transactions_impl.cpp => transaction_impl.cpp} |   94 +-
 .../src/impl/transactions/transaction_impl.h       |   50 +-
 .../src/impl/transactions/transactions_impl.cpp    |  135 +-
 .../src/impl/transactions/transactions_impl.h      |   48 +-
 .../Apache.Ignite.Core.Tests.DotNetCore.csproj     |    4 +-
 .../Apache.Ignite.Core.Tests.csproj                |    1 +
 .../Binary/BinaryDynamicRegistrationTest.cs        |   47 +-
 .../Binary/BinaryNameMapperTest.cs                 |   62 +-
 .../Cache/Affinity/AffinityTest.cs                 |   40 +
 .../Apache.Ignite.Core.Tests/Examples/Example.cs   |   12 +
 .../Examples/ExamplePaths.cs                       |   11 +-
 .../Examples/ExamplesTestBase.cs                   |  172 ++
 .../Examples/ExpectedOutput/AtomicLong.txt         |   24 +
 .../ExpectedOutput/AtomicLong_ExternalNode.txt     |   44 +
 .../Examples/ExpectedOutput/AtomicReference.txt    |    1 +
 .../Examples/ExpectedOutput/AtomicSequence.txt     |   23 +
 .../ExpectedOutput/AtomicSequence_ExternalNode.txt |   44 +
 .../Examples/ExpectedOutput/BinaryMode.txt         |   21 +
 .../Examples/ExpectedOutput/BinaryModeThin.txt     |   18 +
 .../Examples/ExpectedOutput/ClientReconnect.txt    |   19 +
 .../Examples/ExpectedOutput/DataStreamer.txt       |   51 +
 .../Examples/ExpectedOutput/Ddl.txt                |    9 +
 .../Examples/ExpectedOutput/DdlThin.txt            |   13 +
 .../Examples/ExpectedOutput/Dml.txt                |   17 +
 .../Examples/ExpectedOutput/DmlThin.txt            |   17 +
 .../Examples/ExpectedOutput/EntryProcessor.txt     |   45 +
 .../Examples/ExpectedOutput/Events.txt             |   10 +
 .../ExpectedOutput/Events_ExternalNode.txt         |   10 +
 .../Examples/ExpectedOutput/Func.txt               |   15 +
 .../Examples/ExpectedOutput/Lifecycle.txt          |   17 +
 .../Examples/ExpectedOutput/Linq.txt               |   32 +
 .../Examples/ExpectedOutput/LinqThin.txt           |   32 +
 .../Examples/ExpectedOutput/Messaging.txt          |   28 +
 .../Examples/ExpectedOutput/MultiTieredCache.txt   |   34 +
 .../ExpectedOutput/OptimisticTransaction.txt       |    7 +
 .../ExpectedOutput/OptimisticTransactionThin.txt   |    7 +
 .../ExpectedOutput/PeerAssemblyLoading.txt         |    4 +
 .../Examples/ExpectedOutput/PutGet.txt             |   13 +
 .../Examples/ExpectedOutput/PutGetThin.txt         |   13 +
 .../Examples/ExpectedOutput/QueryContinuous.txt    |    6 +
 .../ExpectedOutput/QueryContinuousThin.txt         |    6 +
 .../Examples/ExpectedOutput/QueryFullText.txt      |    5 +
 .../Examples/ExpectedOutput/QueryScan.txt          |    5 +
 .../Examples/ExpectedOutput/QueryScanThin.txt      |    5 +
 .../Examples/ExpectedOutput/Services.txt           |    7 +
 .../Examples/ExpectedOutput/ServicesThin.txt       |    3 +
 .../Examples/ExpectedOutput/Sql.txt                |   15 +
 .../Examples/ExpectedOutput/SqlThin.txt            |   15 +
 .../Examples/ExpectedOutput/Store.txt              |   21 +
 .../Examples/ExpectedOutput/Task.txt               |   15 +
 .../Examples/ExpectedOutput/Task_ExternalNode.txt  |   16 +
 .../Examples/ExpectedOutput/Transaction.txt        |   26 +
 .../TransactionDeadlockDetection.txt               |   17 +
 .../Examples/ExpectedOutput/TransactionThin.txt    |   26 +
 .../Examples/ThickExamplesExternalNodeTest.cs      |    4 +-
 .../Examples/ThickExamplesTest.cs                  |    4 +-
 .../Examples/ThinExamplesTest.cs                   |   34 +-
 .../Examples/ThinExamplesTwoServersTest.cs}        |   30 +-
 .../Services/JavaServiceDynamicProxy.cs            |    2 +-
 .../Services/PlatformTestService.cs                |  619 +++++
 .../Services/ServicesTest.cs                       |  394 ++--
 .../Services/ServicesTypeAutoResolveTest.cs        |   83 +-
 .../Apache.Ignite.Core/Apache.Ignite.Core.nuspec   |   12 +-
 .../Apache.Ignite.Core/Impl/Binary/Marshaller.cs   |   21 +
 .../Impl/Binary/TypeNameParser.cs                  |    2 +-
 .../examples/Shared/Events/LocalEventListener.cs   |   54 -
 .../Thick/Cache/MultiTieredCache/Program.cs        |    8 +-
 .../examples/Thick/Cache/QueryFullText/Program.cs  |    2 +-
 .../examples/Thick/Cache/QueryScan/Program.cs      |    2 +-
 .../dotnet/examples/Thick/Cache/Store/Program.cs   |    2 +-
 .../examples/Thick/Cache/Transaction/Program.cs    |    4 +-
 .../dotnet/examples/Thick/Misc/Events/Program.cs   |   32 +-
 .../dotnet/examples/Thick/Sql/Linq/Program.cs      |    6 +-
 .../examples/Thin/Cache/QueryScanThin/Program.cs   |    2 +-
 .../examples/Thin/Cache/TransactionThin/Program.cs |    4 +-
 .../dotnet/examples/Thin/Sql/LinqThin/Program.cs   |    6 +-
 modules/platforms/nodejs/README.md                 |   32 -
 modules/platforms/nodejs/api_spec/conf.json        |   12 -
 .../platforms/nodejs/examples/AuthTlsExample.js    |  128 -
 .../nodejs/examples/CachePutGetExample.js          |  186 --
 .../platforms/nodejs/examples/FailoverExample.js   |   59 -
 modules/platforms/nodejs/examples/SqlExample.js    |  242 --
 .../nodejs/examples/SqlQueryEntriesExample.js      |  136 --
 modules/platforms/nodejs/examples/certs/ca.crt     |   32 -
 modules/platforms/nodejs/examples/certs/client.crt |   30 -
 modules/platforms/nodejs/examples/certs/client.key |   51 -
 .../platforms/nodejs/examples/certs/keystore.jks   |  Bin 3828 -> 0 bytes
 .../platforms/nodejs/examples/certs/truststore.jks |  Bin 1477 -> 0 bytes
 modules/platforms/nodejs/index.js                  |   43 -
 modules/platforms/nodejs/lib/BinaryObject.js       |  530 -----
 modules/platforms/nodejs/lib/CacheClient.js        |  759 ------
 modules/platforms/nodejs/lib/CacheConfiguration.js | 1734 --------------
 modules/platforms/nodejs/lib/Cursor.js             |  307 ---
 modules/platforms/nodejs/lib/EnumItem.js           |  212 --
 modules/platforms/nodejs/lib/Errors.js             |  133 --
 modules/platforms/nodejs/lib/IgniteClient.js       |  290 ---
 .../nodejs/lib/IgniteClientConfiguration.js        |  112 -
 modules/platforms/nodejs/lib/ObjectType.js         |  600 -----
 modules/platforms/nodejs/lib/Query.js              |  508 ----
 modules/platforms/nodejs/lib/Timestamp.js          |   76 -
 .../nodejs/lib/internal/ArgumentChecker.js         |   83 -
 .../nodejs/lib/internal/BinaryCommunicator.js      |  409 ----
 .../platforms/nodejs/lib/internal/BinaryType.js    |  483 ----
 .../nodejs/lib/internal/BinaryTypeStorage.js       |  112 -
 .../platforms/nodejs/lib/internal/BinaryUtils.js   |  602 -----
 .../nodejs/lib/internal/ClientFailoverSocket.js    |  134 --
 .../platforms/nodejs/lib/internal/ClientSocket.js  |  454 ----
 modules/platforms/nodejs/lib/internal/Logger.js    |   45 -
 .../platforms/nodejs/lib/internal/MessageBuffer.js |  293 ---
 modules/platforms/nodejs/package.json              |   40 -
 modules/platforms/nodejs/spec/ExamplesExecutor.js  |   28 -
 modules/platforms/nodejs/spec/TestingHelper.js     |  391 ---
 .../nodejs/spec/cache/BinaryObject.spec.js         |  176 --
 modules/platforms/nodejs/spec/cache/Cache.spec.js  |  262 ---
 .../nodejs/spec/cache/CacheKeyValueOps.spec.js     | 1022 --------
 .../nodejs/spec/cache/CachePutGetDiffTypes.spec.js |  686 ------
 .../nodejs/spec/cache/ComplexObject.spec.js        |  540 -----
 modules/platforms/nodejs/spec/cache/UUID.spec.js   |  105 -
 modules/platforms/nodejs/spec/config.js            |   27 -
 .../nodejs/spec/examples/AuthExample.spec.js       |   33 -
 .../nodejs/spec/examples/Examples.spec.js          |   45 -
 .../platforms/nodejs/spec/query/ScanQuery.spec.js  |  207 --
 .../nodejs/spec/query/SqlFieldsQuery.spec.js       |  266 ---
 .../platforms/nodejs/spec/query/SqlQuery.spec.js   |  247 --
 modules/platforms/nodejs/spec/support/jasmine.json |   11 -
 modules/platforms/php/.gitignore                   |    2 -
 modules/platforms/php/README.md                    |   37 -
 modules/platforms/php/api_docs/Doxyfile            | 2487 --------------------
 modules/platforms/php/composer.json                |   27 -
 modules/platforms/php/examples/AuthTlsExample.php  |  129 -
 .../platforms/php/examples/CachePutGetExample.php  |  184 --
 modules/platforms/php/examples/FailoverExample.php |   67 -
 modules/platforms/php/examples/SqlExample.php      |  237 --
 .../php/examples/SqlQueryEntriesExample.php        |  127 -
 modules/platforms/php/examples/certs/ca.pem        |   32 -
 modules/platforms/php/examples/certs/client.pem    |   81 -
 modules/platforms/php/examples/certs/keystore.jks  |  Bin 3828 -> 0 bytes
 .../platforms/php/examples/certs/truststore.jks    |  Bin 1477 -> 0 bytes
 .../src/Apache/Ignite/Cache/CacheConfiguration.php | 1011 --------
 .../php/src/Apache/Ignite/Cache/CacheInterface.php |  379 ---
 .../Apache/Ignite/Cache/CacheKeyConfiguration.php  |  107 -
 .../php/src/Apache/Ignite/Cache/QueryEntity.php    |  315 ---
 .../php/src/Apache/Ignite/Cache/QueryField.php     |  279 ---
 .../php/src/Apache/Ignite/Cache/QueryIndex.php     |  191 --
 modules/platforms/php/src/Apache/Ignite/Client.php |  243 --
 .../php/src/Apache/Ignite/ClientConfiguration.php  |  294 ---
 .../php/src/Apache/Ignite/Data/BinaryObject.php    |  469 ----
 .../platforms/php/src/Apache/Ignite/Data/Date.php  |   83 -
 .../php/src/Apache/Ignite/Data/EnumItem.php        |  155 --
 .../platforms/php/src/Apache/Ignite/Data/Time.php  |   58 -
 .../php/src/Apache/Ignite/Data/Timestamp.php       |   66 -
 .../Apache/Ignite/Exception/ClientException.php    |   35 -
 .../Ignite/Exception/NoConnectionException.php     |   35 -
 .../Apache/Ignite/Exception/OperationException.php |   35 -
 .../Exception/OperationStatusUnknownException.php  |   35 -
 .../Ignite/Internal/Binary/BinaryCommunicator.php  |  493 ----
 .../Apache/Ignite/Internal/Binary/BinaryField.php  |   78 -
 .../Ignite/Internal/Binary/BinaryObjectField.php   |  113 -
 .../Apache/Ignite/Internal/Binary/BinarySchema.php |  145 --
 .../Apache/Ignite/Internal/Binary/BinaryType.php   |  233 --
 .../Ignite/Internal/Binary/BinaryTypeBuilder.php   |  207 --
 .../Ignite/Internal/Binary/BinaryTypeStorage.php   |  123 -
 .../Apache/Ignite/Internal/Binary/BinaryUtils.php  |  450 ----
 .../Ignite/Internal/Binary/ClientOperation.php     |   64 -
 .../Ignite/Internal/Binary/MessageBuffer.php       |  307 ---
 .../src/Apache/Ignite/Internal/Binary/Request.php  |   85 -
 .../src/Apache/Ignite/Internal/Binary/TypeInfo.php |  312 ---
 .../php/src/Apache/Ignite/Internal/Cache.php       |  387 ---
 .../Internal/Connection/ClientFailoverSocket.php   |  134 --
 .../Ignite/Internal/Connection/ClientSocket.php    |  247 --
 .../Ignite/Internal/Connection/ProtocolVersion.php |   82 -
 .../src/Apache/Ignite/Internal/Query/Cursor.php    |  166 --
 .../Ignite/Internal/Query/SqlFieldsCursor.php      |   75 -
 .../Ignite/Internal/Utils/ArgumentChecker.php      |   87 -
 .../src/Apache/Ignite/Internal/Utils/Logger.php    |   62 -
 .../src/Apache/Ignite/Query/CursorInterface.php    |   56 -
 .../php/src/Apache/Ignite/Query/Query.php          |   70 -
 .../php/src/Apache/Ignite/Query/ScanQuery.php      |   88 -
 .../Ignite/Query/SqlFieldsCursorInterface.php      |   82 -
 .../php/src/Apache/Ignite/Query/SqlFieldsQuery.php |  206 --
 .../php/src/Apache/Ignite/Query/SqlQuery.php       |  225 --
 .../Apache/Ignite/Type/CollectionObjectType.php    |  142 --
 .../src/Apache/Ignite/Type/ComplexObjectType.php   |  165 --
 .../php/src/Apache/Ignite/Type/MapObjectType.php   |  123 -
 .../php/src/Apache/Ignite/Type/ObjectArrayType.php |   68 -
 .../php/src/Apache/Ignite/Type/ObjectType.php      |  442 ----
 modules/platforms/php/tests/BinaryObjectTest.php   |  196 --
 .../platforms/php/tests/CacheKeyValueOpsTest.php   |  763 ------
 modules/platforms/php/tests/CachePutGetTest.php    |  765 ------
 modules/platforms/php/tests/CacheTest.php          |  240 --
 modules/platforms/php/tests/ComplexObjectTest.php  |  428 ----
 modules/platforms/php/tests/ScanQueryTest.php      |  167 --
 modules/platforms/php/tests/SqlFieldsQueryTest.php |  224 --
 modules/platforms/php/tests/SqlQueryTest.php       |  204 --
 modules/platforms/php/tests/TestingHelper.php      |  363 ---
 .../php/tests/examples/ExecuteAuthTlsExample.php   |   36 -
 .../php/tests/examples/ExecuteExamples.php         |   61 -
 modules/platforms/python/LICENSE                   |  202 --
 modules/platforms/python/README.md                 |   75 -
 modules/platforms/python/docs/Makefile             |   20 -
 modules/platforms/python/docs/conf.py              |  176 --
 .../python/docs/datatypes/cache_props.rst          |  163 --
 .../platforms/python/docs/datatypes/parsers.rst    |  175 --
 modules/platforms/python/docs/examples.rst         |  624 -----
 modules/platforms/python/docs/index.rst            |   33 -
 modules/platforms/python/docs/modules.rst          |   31 -
 modules/platforms/python/docs/readme.rst           |  202 --
 modules/platforms/python/docs/source/modules.rst   |    7 -
 .../python/docs/source/pyignite.api.binary.rst     |    7 -
 .../docs/source/pyignite.api.cache_config.rst      |    7 -
 .../python/docs/source/pyignite.api.key_value.rst  |    7 -
 .../python/docs/source/pyignite.api.result.rst     |    7 -
 .../platforms/python/docs/source/pyignite.api.rst  |   19 -
 .../python/docs/source/pyignite.api.sql.rst        |    7 -
 .../python/docs/source/pyignite.binary.rst         |    7 -
 .../python/docs/source/pyignite.cache.rst          |    7 -
 .../python/docs/source/pyignite.client.rst         |    7 -
 .../docs/source/pyignite.connection.generators.rst |    7 -
 .../docs/source/pyignite.connection.handshake.rst  |    7 -
 .../python/docs/source/pyignite.connection.rst     |   17 -
 .../python/docs/source/pyignite.connection.ssl.rst |    7 -
 .../python/docs/source/pyignite.constants.rst      |    7 -
 .../python/docs/source/pyignite.datatypes.base.rst |    7 -
 .../docs/source/pyignite.datatypes.binary.rst      |    7 -
 .../source/pyignite.datatypes.cache_config.rst     |    7 -
 .../source/pyignite.datatypes.cache_properties.rst |    7 -
 .../docs/source/pyignite.datatypes.complex.rst     |    7 -
 .../docs/source/pyignite.datatypes.internal.rst    |    7 -
 .../docs/source/pyignite.datatypes.key_value.rst   |    7 -
 .../docs/source/pyignite.datatypes.null_object.rst |    7 -
 .../docs/source/pyignite.datatypes.primitive.rst   |    7 -
 .../source/pyignite.datatypes.primitive_arrays.rst |    7 -
 .../pyignite.datatypes.primitive_objects.rst       |    7 -
 .../docs/source/pyignite.datatypes.prop_codes.rst  |    7 -
 .../python/docs/source/pyignite.datatypes.rst      |   29 -
 .../python/docs/source/pyignite.datatypes.sql.rst  |    7 -
 .../docs/source/pyignite.datatypes.standard.rst    |    7 -
 .../docs/source/pyignite.datatypes.type_codes.rst  |    7 -
 .../python/docs/source/pyignite.exceptions.rst     |    7 -
 .../docs/source/pyignite.queries.op_codes.rst      |    7 -
 .../python/docs/source/pyignite.queries.rst        |   15 -
 modules/platforms/python/docs/source/pyignite.rst  |   30 -
 .../python/docs/source/pyignite.utils.rst          |    7 -
 modules/platforms/python/examples/binary_basics.py |   53 -
 modules/platforms/python/examples/create_binary.py |  103 -
 modules/platforms/python/examples/failover.py      |   61 -
 modules/platforms/python/examples/get_and_put.py   |   41 -
 .../platforms/python/examples/migrate_binary.py    |  190 --
 modules/platforms/python/examples/read_binary.py   |  275 ---
 modules/platforms/python/examples/readme.md        |   17 -
 modules/platforms/python/examples/scans.py         |   55 -
 modules/platforms/python/examples/sql.py           |  298 ---
 modules/platforms/python/examples/type_hints.py    |   51 -
 modules/platforms/python/pyignite/__init__.py      |   17 -
 modules/platforms/python/pyignite/api/__init__.py  |   71 -
 modules/platforms/python/pyignite/api/binary.py    |  209 --
 .../platforms/python/pyignite/api/cache_config.py  |  279 ---
 modules/platforms/python/pyignite/api/key_value.py |  995 --------
 modules/platforms/python/pyignite/api/result.py    |   38 -
 modules/platforms/python/pyignite/api/sql.py       |  475 ----
 modules/platforms/python/pyignite/binary.py        |  136 --
 modules/platforms/python/pyignite/cache.py         |  595 -----
 modules/platforms/python/pyignite/client.py        |  406 ----
 .../python/pyignite/connection/__init__.py         |  333 ---
 .../python/pyignite/connection/generators.py       |   48 -
 .../python/pyignite/connection/handshake.py        |   91 -
 .../platforms/python/pyignite/connection/ssl.py    |   49 -
 modules/platforms/python/pyignite/constants.py     |   52 -
 .../python/pyignite/datatypes/__init__.py          |   27 -
 .../platforms/python/pyignite/datatypes/base.py    |   24 -
 .../platforms/python/pyignite/datatypes/binary.py  |   45 -
 .../python/pyignite/datatypes/cache_config.py      |  153 --
 .../python/pyignite/datatypes/cache_properties.py  |  287 ---
 .../platforms/python/pyignite/datatypes/complex.py |  526 -----
 .../python/pyignite/datatypes/internal.py          |  472 ----
 .../python/pyignite/datatypes/key_value.py         |   24 -
 .../python/pyignite/datatypes/null_object.py       |   64 -
 .../python/pyignite/datatypes/primitive.py         |  106 -
 .../python/pyignite/datatypes/primitive_arrays.py  |  208 --
 .../python/pyignite/datatypes/primitive_objects.py |  158 --
 .../python/pyignite/datatypes/prop_codes.py        |   51 -
 modules/platforms/python/pyignite/datatypes/sql.py |   23 -
 .../python/pyignite/datatypes/standard.py          |  739 ------
 .../python/pyignite/datatypes/type_codes.py        |   57 -
 modules/platforms/python/pyignite/exceptions.py    |   80 -
 .../platforms/python/pyignite/queries/__init__.py  |  339 ---
 .../platforms/python/pyignite/queries/op_codes.py  |   65 -
 modules/platforms/python/pyignite/utils.py         |  172 --
 modules/platforms/python/requirements/docs.txt     |    6 -
 modules/platforms/python/requirements/install.txt  |    4 -
 modules/platforms/python/requirements/setup.txt    |    3 -
 modules/platforms/python/requirements/tests.txt    |    5 -
 modules/platforms/python/setup.py                  |  104 -
 modules/platforms/python/tests/config/ssl.xml      |   58 -
 .../platforms/python/tests/config/ssl/README.txt   |    3 -
 .../python/tests/config/ssl/client_full.pem        |   52 -
 .../tests/config/ssl/client_with_pass_full.pem     |   54 -
 .../platforms/python/tests/config/ssl/server.jks   |  Bin 2380 -> 0 bytes
 .../platforms/python/tests/config/ssl/trust.jks    |  Bin 1346 -> 0 bytes
 modules/platforms/python/tests/conftest.py         |  227 --
 modules/platforms/python/tests/test_binary.py      |  280 ---
 modules/platforms/python/tests/test_cache_class.py |  221 --
 .../platforms/python/tests/test_cache_class_sql.py |  103 -
 .../platforms/python/tests/test_cache_config.py    |   75 -
 modules/platforms/python/tests/test_datatypes.py   |  176 --
 modules/platforms/python/tests/test_examples.py    |   57 -
 .../platforms/python/tests/test_generic_object.py  |   33 -
 modules/platforms/python/tests/test_get_names.py   |   30 -
 modules/platforms/python/tests/test_handshake.py   |   64 -
 modules/platforms/python/tests/test_key_value.py   |  400 ----
 modules/platforms/python/tests/test_scan.py        |   66 -
 modules/platforms/python/tests/test_sql.py         |  184 --
 .../GridSpringResourceInjectionSelfTest.java       |    2 +-
 modules/sqlline/bin/sqlline.bat                    |    8 +-
 modules/sqlline/bin/sqlline.sh                     |    6 +-
 .../scanners/file/UriDeploymentFileScanner.java    |    2 +-
 .../cache/IgniteCacheAbstractBenchmark.java        |    2 +-
 .../spi/discovery/zk/internal/ZkIgnitePaths.java   |    2 +-
 .../zk/ZookeeperDiscoverySpiTestUtil.java          |    4 +-
 parent/pom.xml                                     |   10 +-
 745 files changed, 10526 insertions(+), 44391 deletions(-)

diff --cc .travis.yml
index 8e63eb8,c29e3fd..a9e1d36
--- a/.travis.yml
+++ b/.travis.yml
@@@ -61,18 -57,6 +61,18 @@@ matrix
        dist: trusty
        install: skip
        jdk: openjdk8
-       script: mvn test -Pcheck-test-suites -B -V
+       script: mvn test -Pcheck-test-suites,all-java,all-scala,scala -B -V
        before_cache: rm -rfv $HOME/.m2/repository/org/apache/ignite
        cache: { directories: [ $HOME/.m2/repository ] }
 +
 +    - language: python
 +      python: 3.7.9
 +      <<: *ducktape-tox
 +      script:
 +        - tox -e py37
 +
 +    - language: python
 +      python: 3.8.5
 +      <<: *ducktape-tox
 +      script:
 +        - tox -e linter,codestyle,py38