You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ni...@apache.org on 2021/04/28 13:29:42 UTC

[ignite] branch ignite-cdc updated (d318245 -> c430c51)

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

nizhikov pushed a change to branch ignite-cdc
in repository https://gitbox.apache.org/repos/asf/ignite.git.


    from d318245  IGNITE-13581 compilation fix.
     add b014376  IGNITE-14458 Fix flaky IgniteLocalWalSizeTest. (#8958)
     add 8113ec0  IGNITE-14375 Pending messages can be erroneously send (#8943)
     add cfebe24  IGNITE-13873 Milti-cell transaction changes may be not visible (durin… (#8822)
     add 92b3f1a  IGNITE-14439 Re-fixed NPE when accessing clustername before first exchange finished - Fixes #8944.
     add a4bec2d  IGNITE-14425 Hang transactions in FINISH [COMMIT] phase when сommunication spi is blocked. Fixes #8936
     add c608a6c  IGNITE-14475: Fix C++ Query Example when run with multiple nodes
     add 55e5717  IGNITE-14451 fix corrupt PK index tree caused fields order (closes #8951)
     add 1d28b39  IGNITE-14471 JDBCv2: fix query cursors leak when node to execute queries is specified (#8966)
     add a451c9d  IGNITE-14493 Document versions of Spring integration extensions. (#8979)
     add 43123aa  IGNITE-14492 Java thin client: Refactor notification listener - Fixes #8978.
     add 6b74e4fc IGNITE-14461 Track down those who initiated a query (#8965)
     add b94aa78  IGNITE-14482 replaced ref with value in code snippet - Fixes #8974.
     add b65411e  IGNITE-14402 Java thin client: Continuous queries support - Fixes #8960.
     add 31ac65e  IGNITE-14499 Support dynamic DNS in TcpDiscoveryVmIpFinder - Fixes #8981.
     add 48e4474  IGNITE-14491: moving-sections-and-deleting-incorrect-note (#8986)
     add d7782bd  IGNITE-13381 Local cluster group should have correct node ID after reconnect - Fixes #8985.
     add 866dec4  IGNITE-14507 Un-deprecate IGNITE_BINARY_SORT_OBJECT_FIELDS - Fixes #8992.
     add 72f0671  IGNITE-14404-specify-correct-java-versions (#8993)
     add 71dbf16  IGNITE-13976 Fixed inconsistency in WAL mode state when changing WAL state on unstable topology - Fixes #8643.
     add 43a7a1a  IGNITE-14321 Fix force index rebuilding (#8962)
     add 1ce1a19  IGNITE-14428 Formalizes the names of the metrics included in the metric registry (#8937)
     add 00631f1  Merge branch 'master' into ignite-cdc
     add 9084b83  IGNITE-14462 Add support EmptyCatchBlock for checkstyle (#9000)
     add 3a07d4a  IGNITE-14384 No automatic page diagnostic for CorruptedTreeException, only metadata storing for further investigation - Fixes #8926.
     add 118c64e  IGNITE-14385: Add checkpoint information to the performance statistics. (#8928)
     add 3baeac8  IGNITE-13818 Add extended logging topology for node left/join a grid. Fixes #8559
     add ed876a6  IGNITE-14547 Fix NPE in control.sh if there is illegal parameter after --cache indexes_force_rebuild - Fixes #9005.
     add 9195498  IGNITE-14331 Fixed an issue when Data Streamer flushing could hang due to a connectivity problem. Fixes #8955
     add 3561e87  IGNITE-14528 Fixed race between rebalance and checkpoint which led to assertion error in GridDhtPartitionDemander$RebalanceFuture.ownPartitionsAndFinishFuture. Fixes #9003
     add 074046b  IGNITE-14523 .NET: Add string.Compare support to LINQ provider
     add 38d279a  IGNITE-12033 Move async continuations away from striped pool
     add e5d266e  IGNITE-14346 Implement Azure Blob Storage based IP Finder - Fixes #8897.
     add 01e541e  IGNITE-14324 EVT_CLIENT_NODE_DISCONNECTED is not triggered in k8s (#8980)
     add b1480f0  Fix thin continuous query mention in RELEASE_NOTES for 2.10
     add 2b6cad5  IGNITE-14505 Print information about a striped pool in local node metrics - Fixes #8988.
     add 6c402ed  IGNITE-14497 Move background task deletion at the end of next checkpoint (#8983)
     add 7498164  IGNITE-13444 Durable tasks are cancelled on grid deactivation, starting new tasks is prohibited - Fixes #8244.
     add 46e0449  IGNITE-13399 Fix access right issues in computation of system metrics - Fixes #8903.
     add 79add25  IGNITE-14565 Added additional update counter logging for detecting of AssertionError: LWM after HWM. Fixes #9011
     add 255a30c  IGNITE-14620 Fix GridCacheAsyncOperationsLimitSelfTest#testAsyncOps flakiness
     add bec58b0  IGNITE-14423 Fixed node failure caused by AssertionError: Transaction does not own lock for update. Fixes #8935
     add e3674cc  IGNITE-14527 CVE-2021-2816[3,4,5] in Jetty (#9002)
     add c430c51  Merge branch 'master' into ignite-cdc

No new revisions were added by this update.

Summary of changes:
 RELEASE_NOTES.txt                                  |   2 +-
 assembly/dependencies-apache-ignite-slim.xml       |   1 +
 assembly/libs/README.txt                           |   1 +
 checkstyle/checkstyle.xml                          |   5 +
 docs/_docs/clustering/discovery-in-the-cloud.adoc  |  44 +-
 docs/_docs/code-snippets/java/pom.xml              |   5 +
 .../ignite/snippets/DiscoveryInTheCloud.java       |  24 +
 .../spring/spring-data.adoc                        |  15 +-
 .../spring/spring-tx.adoc                          |   9 +
 docs/_docs/includes/cpp-prerequisites.adoc         |   2 +-
 docs/_docs/includes/dotnet-prerequisites.adoc      |   2 +-
 docs/_docs/includes/java9.adoc                     |   2 +-
 docs/_docs/includes/partition-awareness.adoc       |   8 -
 docs/_docs/includes/prereqs.adoc                   |   2 +-
 .../kubernetes/generic-configuration.adoc          |  20 +-
 docs/_docs/quick-start/java.adoc                   |   2 +-
 docs/_docs/setup.adoc                              |   1 +
 modules/azure/README.txt                           |  32 +
 modules/azure/pom.xml                              | 342 +++++++++
 .../azure/TcpDiscoveryAzureBlobStoreIpFinder.java  | 382 ++++++++++
 .../spi/discovery/tcp/ipfinder/package-info.java}  |  17 +-
 ...TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java |  91 +++
 .../tcp/ipfinder/azure/package-info.java}          |  17 +-
 .../ignite/testsuites/IgniteAzureTestSuite.java    |  61 ++
 .../jmh/cache/JmhCacheAsyncListenBenchmark.java    | 162 +++++
 .../common/RunningQueryInfoCheckInitiatorTest.java | 420 +++++++++++
 .../ignite/internal/jdbc2/JdbcCursorLeaksTest.java | 202 ++++++
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |   4 +
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |   2 +
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |   4 +-
 .../src/test/resources/jetty/rest-jetty.xml        |   2 +-
 .../clients/AbstractClientCompatibilityTest.java   |   8 +
 .../clients/JavaThinCompatibilityTest.java         |  26 +
 .../cache/CacheIndexesForceRebuild.java            |   2 +-
 .../GridCommandHandlerIndexForceRebuildTest.java   |  17 +-
 .../org/apache/ignite/IgniteSystemProperties.java  |   3 +-
 .../apache/ignite/cache/query/SqlFieldsQuery.java  |  53 ++
 .../java/org/apache/ignite/client/ClientCache.java |  62 +-
 .../ClientDisconnectListener.java}                 |  21 +-
 .../ignite/configuration/IgniteConfiguration.java  |  37 +
 .../apache/ignite/internal/GridKernalContext.java  |   8 +
 .../ignite/internal/GridKernalContextImpl.java     |  10 +
 .../org/apache/ignite/internal/IgniteKernal.java   |  23 +-
 .../org/apache/ignite/internal/IgnitionEx.java     |  23 +-
 .../internal/cache/query/index/IndexProcessor.java |   9 +-
 .../thin/ClientCacheEntryListenerHandler.java      | 265 +++++++
 .../thin/ClientCacheEntryListenersRegistry.java    |  61 ++
 .../ignite/internal/client/thin/ClientChannel.java |   9 +-
 .../internal/client/thin/ClientComputeImpl.java    | 249 ++-----
 .../client/thin/ClientContinuousQueryCursor.java   |  61 ++
 .../internal/client/thin/ClientJCacheAdapter.java  | 194 ++++++
 .../thin/ClientJCacheEntryListenerAdapter.java     |  70 ++
 ...onListener.java => ClientNotificationType.java} |  33 +-
 .../internal/client/thin/ClientOperation.java      |  21 +-
 .../internal/client/thin/NotificationListener.java |  12 +-
 .../internal/client/thin/ReliableChannel.java      |  50 +-
 .../internal/client/thin/TcpClientCache.java       | 128 +++-
 .../internal/client/thin/TcpClientChannel.java     | 113 ++-
 .../internal/client/thin/TcpIgniteClient.java      |  23 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |   2 +-
 .../JdbcCloseCursorTask.java}                      |  28 +-
 .../ignite/internal/jdbc2/JdbcConnection.java      |  48 ++
 .../jdbc2/JdbcQueryMultipleStatementsTask.java     |  11 +
 .../jdbc2/JdbcQueryMultipleStatementsTaskV3.java   |  72 ++
 .../ignite/internal/jdbc2/JdbcResultSet.java       |  18 +-
 .../ignite/internal/jdbc2/JdbcStatement.java       |  29 +-
 .../jdbc2/JdbcStreamedPreparedStatement.java       |   2 +-
 .../communication/GridIoMessageFactory.java        |   4 -
 .../managers/discovery/GridDiscoveryManager.java   |  78 ++-
 .../managers/indexing/IndexesRebuildTask.java      |  53 +-
 .../systemview/walker/SqlQueryViewWalker.java      |   4 +-
 .../cache/CacheAffinitySharedManager.java          |  35 +-
 .../cache/DynamicCacheChangeRequest.java           |   2 +-
 .../internal/processors/cache/ExchangeActions.java |   4 +-
 .../cache/GatewayProtectedCacheProxy.java          |   4 +-
 .../processors/cache/GridCacheEvictionManager.java |   2 +-
 .../processors/cache/GridCacheMapEntry.java        |  12 +-
 .../cache/GridCachePartitionExchangeManager.java   |  12 +-
 .../processors/cache/GridCachePreloader.java       |   3 +-
 .../cache/GridCachePreloaderAdapter.java           |   2 +-
 .../processors/cache/GridCacheProcessor.java       |  11 +-
 .../processors/cache/GridCacheSharedContext.java   |   7 +-
 .../processors/cache/IgniteCacheFutureImpl.java    |   8 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |   2 +-
 .../processors/cache/IgniteCacheProxyImpl.java     |  26 +-
 .../cache/IgniteFinishedCacheFutureImpl.java       |   2 +-
 .../cache/PartitionUpdateCounterErrorWrapper.java  | 182 +++++
 .../cache/PartitionUpdateCounterTrackingImpl.java  |  31 +-
 .../internal/processors/cache/WalStateManager.java |  42 +-
 .../distributed/GridCacheTxRecoveryFuture.java     |   2 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java    |   8 +-
 .../dht/colocated/GridDhtColocatedLockFuture.java  |   2 +-
 .../dht/preloader/FinishPreloadingTask.java        |  21 +-
 .../dht/preloader/GridDhtPartitionDemander.java    |  85 ++-
 .../preloader/GridDhtPartitionsExchangeFuture.java |  87 +--
 .../dht/preloader/GridDhtPreloader.java            |   4 +-
 .../msg/PartitionCountersNeighborcastRequest.java  | 173 -----
 .../msg/PartitionCountersNeighborcastResponse.java | 141 ----
 .../cache/persistence/DataRegionMetricsImpl.java   |  10 +
 .../GridCacheDatabaseSharedManager.java            |  74 +-
 .../IgniteCacheDatabaseSharedManager.java          |  11 +-
 .../cache/persistence/checkpoint/Checkpointer.java |  24 +
 .../file/FileVersionCheckingFactory.java           |   2 +-
 .../cache/persistence/wal/SegmentRouter.java       |   8 +-
 .../wal/reader/StandaloneGridKernalContext.java    |   6 +
 .../cache/transactions/IgniteTxHandler.java        |  59 +-
 .../cache/transactions/IgniteTxManager.java        |  49 +-
 .../PartitionCountersNeighborcastFuture.java       | 237 -------
 .../processors/cluster/ClusterProcessor.java       |   7 +
 .../cluster/GridClusterStateProcessor.java         |   2 +
 .../processors/datastreamer/DataStreamerImpl.java  |  41 +-
 .../datastructures/AtomicDataStructureProxy.java   |   2 +-
 .../processors/diagnostic/DiagnosticProcessor.java | 222 +++---
 .../diagnostic/PageHistoryDiagnoster.java          | 350 ----------
 .../processors/failure/FailureProcessor.java       |   2 +-
 .../internal/processors/job/GridJobWorker.java     |   5 +
 .../localtask/DurableBackgroundTasksProcessor.java |  72 +-
 .../processors/metric/GridMetricManager.java       |  10 +-
 .../internal/processors/metric/MetricRegistry.java |   8 +-
 .../ClientListenerAbstractConnectionContext.java   |  42 +-
 .../processors/odbc/ClientListenerNioListener.java |  12 +-
 .../odbc/jdbc/JdbcConnectionContext.java           |   7 +-
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |   4 +-
 .../odbc/odbc/OdbcConnectionContext.java           |   9 +-
 .../processors/odbc/odbc/OdbcRequestHandler.java   |  13 +-
 .../FilePerformanceStatisticsReader.java           |  57 ++
 .../FilePerformanceStatisticsWriter.java           |  68 ++
 .../performancestatistics/OperationType.java       |  18 +-
 .../PerformanceStatisticsHandler.java              |  44 ++
 .../PerformanceStatisticsProcessor.java            | 117 +++-
 .../platform/client/ClientConnectionContext.java   |   6 +-
 .../cache/ClientCacheSqlFieldsQueryRequest.java    |   2 +
 .../platform/utils/PlatformConfigurationUtils.java |  40 ++
 .../processors/query/GridQueryIndexing.java        |   6 +-
 .../processors/query/GridQueryProcessor.java       | 152 ++--
 .../processors/query/GridRunningQueryInfo.java     |  15 +-
 .../processors/query/IndexRebuildAware.java        | 145 ++++
 .../internal/processors/query/QueryEntityEx.java   |  26 +-
 .../internal/processors/query/QueryUtils.java      |   2 +-
 .../processors/query/RunningQueryManager.java      |  11 +-
 .../processors/security/SecurityUtils.java         |   2 +-
 .../apache/ignite/internal/sql/SqlParserUtils.java |   2 +-
 .../apache/ignite/internal/util/GridCleaner.java   |   2 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |   2 +-
 .../internal/util/future/IgniteFutureImpl.java     |  24 +-
 .../internal/util/nio/GridNioSessionImpl.java      |   2 +-
 .../ignite/internal/util/worker/CycleThread.java   |   2 +-
 .../checkpoint/sharedfs/SharedFsCheckpointSpi.java |   2 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java       |  65 +-
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |  26 +-
 .../tcp/internal/TcpDiscoveryStatistics.java       |  12 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java    | 104 +--
 .../ignite/spi/systemview/view/SqlQueryView.java   |   6 +
 .../main/resources/META-INF/classnames.properties  |   2 +
 .../test/java/org/apache/ignite/GridTestJob.java   |   2 +-
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |  12 +-
 .../org/apache/ignite/client/ReliabilityTest.java  |  14 -
 .../internal/GridNodeMetricsLogSelfTest.java       |   1 +
 ...ientCheckClusterGroupLocalIdAfterReconnect.java | 142 ++++
 .../client/thin/AbstractThinClientTest.java        |  22 +
 .../client/thin/CacheEntryListenersTest.java       | 774 +++++++++++++++++++++
 .../internal/client/thin/ComputeTaskTest.java      |  29 +-
 .../internal/client/thin/ReliableChannelTest.java  |  10 +-
 .../IgniteTopologyPrintFormatSelfTest.java         | 212 ++++--
 .../ignite/internal/metric/MetricsSelfTest.java    |  14 +-
 .../ignite/internal/metric/SystemMetricsTest.java  |  66 ++
 .../cache/CacheAsyncContinuationExecutorTest.java  | 254 +++++++
 ...eAsyncContinuationSynchronousExecutorTest.java} |  26 +-
 .../cache/CacheSerializableTransactionsTest.java   |  15 +-
 .../ClientFastReplyCoordinatorFailureTest.java     |   2 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java     |   4 +-
 .../IgniteAbstractDynamicCacheStartFailTest.java   |   6 +-
 .../SetTxTimeoutOnPartitionMapExchangeTest.java    |   2 +-
 .../GridCacheQueueClientDisconnectTest.java        |   2 +-
 ...GridExchangeFreeCellularSwitchAbstractTest.java | 134 +++-
 ...ngeFreeCellularSwitchComplexOperationsTest.java |  76 +-
 ...ridExchangeFreeCellularSwitchIsolationTest.java | 532 ++++++++------
 ...changeFreeCellularSwitchTxContinuationTest.java | 264 +++++++
 ...idExchangeFreeCellularSwitchTxCountersTest.java | 242 +++++++
 .../rebalancing/RebalanceStatisticsTest.java       |   3 +-
 .../CorruptedTreeFailureHandlingTest.java          |  40 +-
 .../IgniteDataStorageMetricsSelfTest.java          |  11 -
 .../IgnitePdsNoSpaceLeftOnDeviceTest.java          |   3 +-
 ...IgnitePdsSpuriousRebalancingOnNodeJoinTest.java |  10 +-
 .../db/CheckpointBufferDeadlockTest.java           |  62 +-
 .../db/SlowCheckpointFileIOFactory.java            |  86 +++
 .../persistence/db/wal/IgniteLocalWalSizeTest.java |  31 +-
 .../persistence/db/wal/IgniteWalRebalanceTest.java | 195 +++++-
 .../db/wal/WriteAheadLogManagerSelfTest.java       |  10 -
 .../db/wal/crc/IgniteDataIntegrityTests.java       |   4 +-
 .../pagemem/BPlusTreePageMemoryImplTest.java       |   7 +-
 .../BPlusTreeReuseListPageMemoryImplTest.java      |   7 +-
 .../IgnitePageMemReplaceDelayedWriteUnitTest.java  |  12 +-
 .../pagemem/IgniteThrottlingUnitTest.java          |  10 +-
 .../pagemem/IndexStoragePageMemoryImplTest.java    |   7 +-
 .../pagemem/PageMemoryImplNoLoadTest.java          |   7 +-
 .../persistence/pagemem/PageMemoryImplTest.java    |   6 +-
 .../pagemem/PagesWriteThrottleSmokeTest.java       |  56 +-
 .../persistence/tree/io/TrackingPageIOTest.java    |   2 +-
 .../persistence/wal/WalArchiveConsistencyTest.java |  10 -
 .../wal/WalEnableDisableWithNodeShutdownTest.java  |  46 +-
 .../wal/WalEnableDisableWithRestartsTest.java      | 203 ++++++
 .../transactions/PartitionUpdateCounterTest.java   |   9 +-
 .../cache/transactions/TxOnCachesStopTest.java     |   2 +-
 .../TxPartitionCounterStateConsistencyTest.java    |   6 +-
 ...ounterStateOnePrimaryTwoBackupsFailAllTest.java |   4 +-
 ...teOnePrimaryTwoBackupsHistoryRebalanceTest.java | 160 +++++
 ...titionCounterStateOnePrimaryTwoBackupsTest.java |  18 +-
 ...titionCounterStateTwoPrimaryTwoBackupsTest.java |   2 +-
 .../TxRecoveryWithConcurrentRollbackTest.java      | 140 +++-
 .../cache/transactions/TxRollbackAsyncTest.java    |  14 +-
 .../transactions/TxRollbackOnTimeoutTest.java      | 101 ++-
 .../TxRollbackOnTopologyChangeTest.java            |   2 +-
 .../ClusterNameBeforeActivation.java}              |  38 +-
 .../processors/database/CacheFreeListSelfTest.java |   9 +-
 .../database/DataRegionMetricsSelfTest.java        |  10 +-
 .../DataStreamerCommunicationSpiExceptionTest.java | 143 ++++
 .../diagnostic/DiagnosticProcessorTest.java        | 313 ++++-----
 .../AbstractPerformanceStatisticsTest.java         |  27 +
 .../performancestatistics/CheckpointTest.java      | 228 ++++++
 .../processors/query/DummyQueryIndexing.java       |   6 +-
 .../compute/ComputePermissionCheckTest.java        |   2 +-
 .../util/future/IgniteCacheFutureImplTest.java     |   2 +-
 .../ignite/platform/PlatformTestExecutor.java}     |  16 +-
 .../ignite/platform/PlatformThreadUtils.java       |   9 +
 ...municationSpiSkipWaitHandshakeOnClientTest.java |   2 +-
 ...cpClientDiscoverySpiFailureTimeoutSelfTest.java |   8 +-
 .../tcp/TcpClientDiscoveryUnresolvedHostTest.java  |   2 +-
 .../tcp/TcpDiscoveryIpFinderFailureTest.java       | 395 +++++++++++
 .../spi/discovery/tcp/TestDynamicIpFinder.java     |  55 ++
 .../vm/TcpDiscoveryVmIpFinderDnsResolveTest.java   | 630 +++++++++++++++++
 .../junits/common/GridCommonAbstractTest.java      | 123 +++-
 .../IgniteBasicWithPersistenceTestSuite.java       |   4 +-
 .../testsuites/IgniteCacheMvccTestSuite5.java      |   4 +
 .../ignite/testsuites/IgniteCacheTestSuite.java    |   6 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |   4 +
 .../ignite/testsuites/IgniteCacheTestSuite9.java   |   6 +-
 .../testsuites/IgniteClientReconnectTestSuite.java |   2 +
 .../ignite/testsuites/IgnitePdsTestSuite.java      |   6 +-
 .../IgniteSpiDiscoverySelfTestSuite.java           |   7 +-
 .../utils/IgniteWalConverterArgumentsTest.java     |  34 +
 .../processors/query/h2/CommandProcessor.java      |  17 +-
 .../processors/query/h2/H2TableDescriptor.java     |   4 +-
 .../processors/query/h2/IgniteH2Indexing.java      |  20 +-
 .../processors/query/h2/QueryDescriptor.java       |  14 +-
 .../internal/processors/query/h2/QueryParser.java  |   3 +-
 .../org/apache/ignite/client/ClientTestSuite.java  |   2 +
 .../processors/cache/index/BasicIndexTest.java     |  54 ++
 .../cache/index/ForceRebuildIndexTest.java         | 317 +++++++++
 .../cache/index/IndexesRebuildTaskEx.java          | 207 ++++++
 .../cache/index/StopRebuildIndexTest.java          | 191 +----
 .../IgnitePdsIndexingDefragmentationTest.java      |   5 +-
 .../db/LongDestroyDurableBackgroundTaskTest.java   |  88 ++-
 .../testsuites/IgnitePdsWithIndexingTestSuite.java |   4 +-
 .../KubernetesDiscoveryAbstractTest.java}          |  64 +-
 .../discovery/TestClusterClientConnection.java     |  52 ++
 .../TestKubernetesIpFinderDisconnection.java       | 123 ++++
 .../testsuites/IgniteKubernetesTestSuite.java      |   4 +-
 .../cpp/examples/include/ignite/examples/person.h  |   2 +-
 .../examples/query-example/src/query_example.cpp   |   4 +-
 .../Cache/CacheTestAsyncAwait.cs                   | 115 +++
 .../Cache/Query/Linq/CacheLinqTest.Base.cs         |  31 +
 .../Cache/Query/Linq/CacheLinqTest.Strings.cs      |  71 ++
 .../Client/Cache/CacheTestAsyncAwait.cs            |   2 +-
 .../Compute/CancellationTest.cs                    |   2 +-
 .../Compute/ComputeApiTest.cs                      |   6 +-
 .../ComputeTestAsyncAwait.cs}                      |  29 +-
 .../Config/full-config.xml                         |   2 +-
 .../Config/spring-test.xml                         |   4 +
 .../IgniteConfigurationSerializerTest.cs           |   5 +-
 .../IgniteConfigurationTest.cs                     |   2 +
 .../Apache.Ignite.Core.Tests/ProjectFilesTest.cs   |  16 +-
 .../Services/PlatformTestService.cs                |   1 +
 .../Apache.Ignite.Core.Tests/TestUtilsJni.cs       |  21 +
 .../Apache.Ignite.Core/Apache.Ignite.Core.csproj   |   1 +
 .../Configuration/AsyncContinuationExecutor.cs     |  60 ++
 .../Apache.Ignite.Core/IgniteConfiguration.cs      |  17 +-
 .../IgniteConfigurationSection.xsd                 |  12 +
 .../Impl/Compute/ComputeTaskHolder.cs              |  20 +-
 .../Apache.Ignite.Core/Impl/Unmanaged/Jni/Env.cs   |   2 +-
 .../Apache.Ignite.Linq/Impl/MethodVisitor.cs       |  54 ++
 modules/platforms/dotnet/DEVNOTES.txt              |   6 +-
 modules/platforms/dotnet/build.ps1                 |   2 +-
 modules/platforms/dotnet/release/verify-nuget.ps1  |   2 +-
 .../org/apache/ignite/spark/impl/QueryHelper.scala |   2 +-
 .../org/apache/ignite/spark/impl/QueryHelper.scala |   2 +-
 .../jdbc/NativeJavaApiPutRemoveBenchmark.java      |   2 +-
 .../jdbc/NativeSqlInsertDeleteBenchmark.java       |   2 +-
 .../zk/internal/ZookeeperDiscoveryStatistics.java  |  18 +-
 parent/pom.xml                                     |   4 +-
 pom.xml                                            |   1 +
 291 files changed, 11654 insertions(+), 3252 deletions(-)
 create mode 100644 modules/azure/README.txt
 create mode 100644 modules/azure/pom.xml
 create mode 100644 modules/azure/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/TcpDiscoveryAzureBlobStoreIpFinder.java
 copy modules/{core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteFinishedCacheFutureImpl.java => azure/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/package-info.java} (69%)
 create mode 100644 modules/azure/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/TcpDiscoveryAzureBlobStoreIpFinderSelfTest.java
 copy modules/{core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteFinishedCacheFutureImpl.java => azure/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/azure/package-info.java} (69%)
 create mode 100644 modules/azure/src/test/java/org/apache/ignite/testsuites/IgniteAzureTestSuite.java
 create mode 100644 modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheAsyncListenBenchmark.java
 create mode 100644 modules/clients/src/test/java/org/apache/ignite/common/RunningQueryInfoCheckInitiatorTest.java
 create mode 100644 modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcCursorLeaksTest.java
 copy modules/core/src/main/java/org/apache/ignite/{internal/client/thin/NotificationListener.java => client/ClientDisconnectListener.java} (55%)
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/client/thin/ClientCacheEntryListenerHandler.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/client/thin/ClientCacheEntryListenersRegistry.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/client/thin/ClientContinuousQueryCursor.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/client/thin/ClientJCacheAdapter.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/client/thin/ClientJCacheEntryListenerAdapter.java
 copy modules/core/src/main/java/org/apache/ignite/internal/client/thin/{NotificationListener.java => ClientNotificationType.java} (52%)
 copy modules/core/src/main/java/org/apache/ignite/internal/{processors/cache/IgniteFinishedCacheFutureImpl.java => jdbc2/JdbcCloseCursorTask.java} (57%)
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/jdbc2/JdbcQueryMultipleStatementsTaskV3.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cache/PartitionUpdateCounterErrorWrapper.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/msg/PartitionCountersNeighborcastRequest.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/msg/PartitionCountersNeighborcastResponse.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/PartitionCountersNeighborcastFuture.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/diagnostic/PageHistoryDiagnoster.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/query/IndexRebuildAware.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/IgniteClientCheckClusterGroupLocalIdAfterReconnect.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/client/thin/CacheEntryListenersTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/metric/SystemMetricsTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheAsyncContinuationExecutorTest.java
 copy modules/core/src/{main/java/org/apache/ignite/internal/processors/cache/IgniteFinishedCacheFutureImpl.java => test/java/org/apache/ignite/internal/processors/cache/CacheAsyncContinuationSynchronousExecutorTest.java} (52%)
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridExchangeFreeCellularSwitchTxContinuationTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridExchangeFreeCellularSwitchTxCountersTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/SlowCheckpointFileIOFactory.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/WalEnableDisableWithRestartsTest.java
 rename modules/core/src/test/java/org/apache/ignite/internal/processors/{cache/CacheReadBeforeActivationTest.java => cluster/ClusterNameBeforeActivation.java} (72%)
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerCommunicationSpiExceptionTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/performancestatistics/CheckpointTest.java
 copy modules/core/src/{main/java/org/apache/ignite/internal/processors/cache/IgniteFinishedCacheFutureImpl.java => test/java/org/apache/ignite/platform/PlatformTestExecutor.java} (70%)
 create mode 100644 modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryIpFinderFailureTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TestDynamicIpFinder.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/vm/TcpDiscoveryVmIpFinderDnsResolveTest.java
 create mode 100644 modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/ForceRebuildIndexTest.java
 create mode 100644 modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/IndexesRebuildTaskEx.java
 rename modules/kubernetes/src/test/java/org/apache/ignite/{client/TestClusterClientConnection.java => kubernetes/discovery/KubernetesDiscoveryAbstractTest.java} (73%)
 create mode 100644 modules/kubernetes/src/test/java/org/apache/ignite/kubernetes/discovery/TestClusterClientConnection.java
 create mode 100644 modules/kubernetes/src/test/java/org/apache/ignite/kubernetes/discovery/TestKubernetesIpFinderDisconnection.java
 create mode 100644 modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheTestAsyncAwait.cs
 copy modules/platforms/dotnet/Apache.Ignite.Core.Tests/{Client/Cache/CacheTestAsyncAwait.cs => Compute/ComputeTestAsyncAwait.cs} (54%)
 create mode 100644 modules/platforms/dotnet/Apache.Ignite.Core/Configuration/AsyncContinuationExecutor.cs