You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ti...@apache.org on 2023/01/09 14:02:58 UTC

[ignite] branch IGNITE-17177_inc_snapshots updated (8e94c73b6f0 -> 9e862bb4050)

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

timoninmaxim pushed a change to branch IGNITE-17177_inc_snapshots
in repository https://gitbox.apache.org/repos/asf/ignite.git


    from 8e94c73b6f0 Merge branch 'master' into IGNITE-17177_inc_snapshots
     add a6e1d845058 IGNITE-18355 Removal of DataRegionMetricsMXBean (#10427)
     add 8cfa8b046a1 IGNITE-18198 Implement snapshots of caches with disk page compression. (#10430)
     add 098e0911793 IGNITE-18348 Replaced deprecated Ignite.active() by Ignite.cluster().state() (#10440)
     add 708d77f6570 IGNITE-18282 SQL Calcite: Improve dynamic parameters type inference - Fixes #10458.
     add defb30d7ad9 IGNITE-17724 .NET: Fix TestPrimaryNodeLeaveClearsPlatformCache flakiness (#10457)
     add 6e221e90b57 IGNITE-5713 Remove redundant ignite-indexing module dependencies - Fixes #10459.
     add 23e55d3d205 IGNITE-18459 [ducktests] Run extra setup script on all docker nodes (#10461)
     add 4ef3889eb8a IGNITE-18460 [ducktests] Bump python packages and LATEST ignite versions (#10460)
     add 220f59f9b7b IGNITE-18463 Fixed snapshot cancel if one path is configured for several nodes (#10462)
     add db7758ce66b IGNITE-18427 .NET: Fix platform cache invalidation on client nodes with near cache (#10465)
     add e9dbca192e3 IGNITE-18473 Add InterruptedException handling in CdcCommandLineStartup#main (#10466)
     add 6c9f56c838f IGNITE-18458 SQL Calcite: Fix NPE on DML on non-existed table - Fixes #10464.
     add 9e862bb4050 Merge remote-tracking branch 'upstream/master' into IGNITE-17177_inc_snapshots

No new revisions were added by this update.

Summary of changes:
 docs/_docs/persistence/native-persistence.adoc     |   2 +-
 .../persistentstore/PersistentStoreExample.java    |   3 +-
 .../jol/FileStoreHeapUtilizationJolBenchmark.java  |   5 +-
 .../query/calcite/CalciteQueryProcessor.java       |  32 +-
 .../calcite/exec/exp/ExpressionFactoryImpl.java    |   7 +
 .../processors/query/calcite/prepare/CacheKey.java |  20 +-
 .../query/calcite/prepare/IgnitePlanner.java       |   2 +-
 .../query/calcite/prepare/IgniteSqlValidator.java  |  23 +-
 .../query/calcite/prepare/IgniteTypeCoercion.java  | 135 +++++++-
 .../processors/query/calcite/QueryChecker.java     |   2 +-
 .../integration/AbstractBasicIntegrationTest.java  |   6 +-
 .../DynamicParametersIntegrationTest.java          | 112 ++++++
 .../query/calcite/integration/FunctionsTest.java   |  12 -
 .../integration/TableDmlIntegrationTest.java       |  34 ++
 .../ignite/testsuites/IntegrationTestSuite.java    |   4 +-
 .../common/RunningQueryInfoCheckInitiatorTest.java |   3 +-
 .../rest/ChangeStateCommandHandlerTest.java        |   8 +-
 .../rest/JettyRestProcessorAbstractSelfTest.java   |   4 +-
 ...ttyRestProcessorAuthenticationAbstractTest.java |   3 +-
 .../rest/JettyRestProcessorBaselineSelfTest.java   |   3 +-
 .../JdbcThinAuthenticateConnectionSelfTest.java    |   3 +-
 .../thin/JdbcThinMissingLongArrayResultsTest.java  |   3 +-
 ...nsactionFinishOnDeactivatedClusterSelfTest.java |   5 +-
 modules/compress/pom.xml                           |  14 +
 .../compress/CompressionProcessorImpl.java         |  34 ++
 .../snapshot/SnapshotCompressionBasicTest.java     | 385 +++++++++++++++++++++
 .../DiskPageCompressionConfigValidationTest.java   |   3 +-
 .../DiskPageCompressionIntegrationTest.java        |   7 +-
 .../WalPageCompressionIntegrationTest.java         |   4 +-
 .../testsuites/IgnitePdsCompressionTestSuite.java  |  12 +
 .../apache/ignite/events/BaselineEventsTest.java   |  17 +-
 .../indexreader/IgniteIndexReaderTest.java         |   5 +-
 .../util/GridCommandHandlerBrokenIndexTest.java    |   3 +-
 ...idCommandHandlerCheckIndexesInlineSizeTest.java |   3 +-
 ...idCommandHandlerClusterByClassAbstractTest.java |   3 +-
 .../GridCommandHandlerIndexForceRebuildTest.java   |   3 +-
 .../util/GridCommandHandlerIndexListTest.java      |   3 +-
 .../GridCommandHandlerIndexRebuildStatusTest.java  |   3 +-
 .../util/GridCommandHandlerIndexingTest.java       |   2 +-
 .../GridCommandHandlerInterruptCommandTest.java    |   7 +-
 .../ignite/util/GridCommandHandlerSslTest.java     |   6 +-
 .../apache/ignite/util/GridCommandHandlerTest.java | 104 +++---
 .../java/org/apache/ignite/DataRegionMetrics.java  |   8 +-
 .../src/main/java/org/apache/ignite/Ignite.java    |   5 +-
 .../main/java/org/apache/ignite/MemoryMetrics.java |   8 +-
 .../configuration/DataRegionConfiguration.java     |   5 +-
 .../configuration/MemoryPolicyConfiguration.java   |   5 +-
 .../org/apache/ignite/configuration/WALMode.java   |   5 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |   4 +-
 .../apache/ignite/internal/IgniteMXBeanImpl.java   |   2 +-
 .../org/apache/ignite/internal/IgnitionEx.java     |   2 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |   3 +-
 .../managers/discovery/GridDiscoveryManager.java   |   2 +-
 .../managers/encryption/GridEncryptionManager.java |   4 +-
 .../IgniteAuthenticationProcessor.java             |   2 +-
 .../cache/CacheAffinitySharedManager.java          |   2 +-
 .../processors/cache/CacheCompressionManager.java  | 102 ------
 .../processors/cache/CacheGroupContext.java        |  15 +-
 .../processors/cache/ClusterCachesInfo.java        |   4 +-
 .../processors/cache/GridCacheContext.java         |  14 -
 .../processors/cache/GridCacheMapEntry.java        |  14 +-
 .../processors/cache/GridCacheProcessor.java       |  16 +-
 .../persistence/DataRegionMetricsMXBeanImpl.java   | 210 -----------
 .../GridCacheDatabaseSharedManager.java            |   6 -
 .../IgniteCacheDatabaseSharedManager.java          |  98 ------
 .../CachePartitionDefragmentationManager.java      |   3 +-
 .../pagemem/PageReadWriteManagerImpl.java          |   9 +-
 .../snapshot/IgniteSnapshotManager.java            | 112 ++++--
 .../persistence/snapshot/SnapshotFutureTask.java   |  21 +-
 .../persistence/snapshot/SnapshotMetadata.java     |  35 +-
 .../snapshot/SnapshotPartitionsVerifyHandler.java  |  67 +++-
 .../snapshot/SnapshotRestoreProcess.java           |  23 ++
 .../wal/reader/StandaloneGridKernalContext.java    |  26 +-
 .../processors/cache/verify/IdleVerifyUtility.java |  23 ++
 .../processors/compress/CompressionHandler.java    | 130 +++++++
 .../platform/cluster/PlatformClusterGroup.java     |   5 +-
 .../handlers/cache/GridCacheCommandHandler.java    |   2 +-
 .../cluster/GridBaselineCommandHandler.java        |   2 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |   4 +-
 .../internal/visor/baseline/VisorBaselineTask.java |   2 +-
 .../visor/baseline/VisorBaselineViewTask.java      |   2 +-
 .../ignite/mxbean/DataRegionMetricsMXBean.java     | 198 -----------
 .../apache/ignite/mxbean/MemoryMetricsMXBean.java  | 134 -------
 .../startup/cmdline/CdcCommandLineStartup.java     |   3 +
 .../apache/ignite/cache/CircledRebalanceTest.java  |   3 +-
 .../ClientCreateCacheGroupOnJoinNodeMapsTest.java  |   5 +-
 .../ignite/cache/NotOptimizedRebalanceTest.java    |   3 +-
 .../RebalanceAfterResettingLostPartitionTest.java  |   3 +-
 .../ignite/cache/RebalanceCancellationTest.java    |   4 +-
 .../cache/RebalanceCompleteDuringExchangeTest.java |   3 +-
 .../ignite/cache/ResetLostPartitionTest.java       |   7 +-
 .../ignite/cache/store/StoreArrayKeyTest.java      |   3 +-
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |   7 +-
 .../events/ClusterActivationStartedEventTest.java  |  20 +-
 .../failure/FailureHandlingConfigurationTest.java  |  11 +-
 .../ignite/failure/IoomFailureHandlerTest.java     |   3 +-
 .../ClusterBaselineNodesMetricsSelfTest.java       |   3 +-
 .../DiagnosticLogForPartitionStatesTest.java       |   3 +-
 .../org/apache/ignite/internal/GridMBeansTest.java |   1 -
 .../internal/GridNodeMetricsLogPdsSelfTest.java    |   3 +-
 .../ignite/internal/ThreadNameValidationTest.java  |   3 +-
 .../internal/cluster/IgniteClusterIdTagTest.java   |   7 +-
 .../encryption/AbstractEncryptionTest.java         |   3 +-
 .../encryption/EncryptedCacheCreateTest.java       |   3 +-
 .../encryption/EncryptedCacheGroupCreateTest.java  |   3 +-
 .../encryption/EncryptedCacheNodeJoinTest.java     |  14 +-
 .../internal/encryption/EncryptionMXBeanTest.java  |  11 +-
 .../internal/encryption/MasterKeyChangeTest.java   |   5 +-
 .../GridIoManagerFileTransmissionSelfTest.java     |   5 +-
 .../internal/metric/IoStatisticsCacheSelfTest.java |   3 +-
 .../ignite/internal/metric/JmxExporterSpiTest.java |   2 +-
 .../internal/metric/MetricsConfigurationTest.java  |   4 +-
 .../ignite/internal/metric/SystemViewSelfTest.java |   2 +-
 .../wal/record/WALRecordSerializationTest.java     |   5 +-
 .../processors/DeadLockOnNodeLeftExchangeTest.java |   3 +-
 .../Authentication1kUsersNodeRestartTest.java      |   3 +-
 .../AuthenticationConfigurationClusterTest.java    |   3 +-
 .../AuthenticationOnNotActiveClusterTest.java      |   3 +-
 .../AuthenticationProcessorNodeRestartTest.java    |   3 +-
 .../AuthenticationProcessorSelfTest.java           |   3 +-
 ...tadataRegistrationInsideEntryProcessorTest.java |   3 +-
 .../cache/CacheDataRegionConfigurationTest.java    |  11 +-
 .../processors/cache/CacheGroupMetricsTest.java    |   4 +-
 .../processors/cache/CacheMetricsManageTest.java   |   9 +-
 .../cache/CacheValidatorMetricsTest.java           |   3 +-
 ...heWithDifferentDataRegionConfigurationTest.java |   7 +-
 .../processors/cache/ClusterStateTestUtils.java    |   2 +-
 ...teDynamicCacheStartFailWithPersistenceTest.java |   3 +-
 .../cache/IgniteMarshallerCacheFSRestoreTest.java  |   3 +-
 ...NonAffinityCoordinatorDynamicStartStopTest.java |   3 +-
 .../PartitionsExchangeCoordinatorFailoverTest.java |   5 +-
 .../RebalanceWithDifferentThreadPoolSizeTest.java  |   3 +-
 .../cache/WalModeChangeAbstractSelfTest.java       |   3 +-
 .../binary/BinaryMetadataMoveLegacyFolderTest.java |   3 +-
 .../BinaryMetadataRemoveWithPersistenceTest.java   |   3 +-
 .../IgniteSequenceInternalCleanupTest.java         |   5 +-
 .../OutOfMemoryVolatileRegionTest.java             |   3 +-
 .../cache/distributed/Cache64kPartitionsTest.java  |   3 +-
 .../distributed/CacheBaselineTopologyTest.java     |  38 +-
 .../distributed/CacheBlockOnReadAbstractTest.java  |   5 +-
 .../CacheDataLossOnPartitionMoveTest.java          |   3 +-
 .../distributed/CachePageWriteLockUnlockTest.java  |   7 +-
 .../cache/distributed/CacheParallelStartTest.java  |   5 +-
 .../CachePartitionLossWithPersistenceTest.java     |   7 +-
 .../CachePartitionLossWithRestartsTest.java        |   3 +-
 ...CachePartitionLostAfterSupplierHasLeftTest.java |   9 +-
 .../distributed/CacheRentingStateRepairTest.java   |   5 +-
 .../CacheResultIsNotNullOnPartitionLossTest.java   |   3 +-
 .../FailBackupOnAtomicOperationTest.java           |   3 +-
 .../GridCachePartitionNotLoadedEventSelfTest.java  |   9 +-
 .../distributed/GridExchangeFreeSwitchTest.java    |   2 +-
 .../IgniteCachePartitionLossPolicySelfTest.java    |   3 +-
 .../dht/CacheGetReadFromBackupFailoverTest.java    |   3 +-
 .../distributed/dht/GracefulShutdownTest.java      |   9 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java    |  13 +-
 .../dht/GridCacheDhtPreloadWaitForBackupsTest.java |  31 +-
 .../GridCachePartitionsStateValidationTest.java    |   5 +-
 .../dht/IgniteCacheStartWithLoadTest.java          |   3 +-
 .../GridCacheRebalancingPartitionCountersTest.java |   7 +-
 .../GridCacheRebalancingWithAsyncClearingTest.java |   5 +-
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |   7 +-
 .../rebalancing/RebalanceStatisticsTest.java       |   3 +-
 .../PageEvictionMultinodeMixedRegionsTest.java     |   3 +-
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |   3 +-
 .../mvcc/CacheMvccConfigurationValidationTest.java |   5 +-
 ...acheMvccPartitionedCoordinatorFailoverTest.java |   7 +-
 .../mvcc/CacheMvccProcessorLazyStartTest.java      |   5 +-
 .../cache/mvcc/CacheMvccProcessorTest.java         |   5 +-
 .../cache/mvcc/CacheMvccTransactionsTest.java      |   3 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |   7 +-
 .../processors/cache/mvcc/CacheMvccVacuumTest.java |  21 +-
 .../persistence/CleanupRestoredCachesSlowTest.java |   3 +-
 .../CommonPoolStarvationCheckpointTest.java        |   3 +-
 ...niteBaselineAffinityTopologyActivationTest.java |  87 ++---
 .../IgniteDataStorageMetricsSelfTest.java          |   3 +-
 ...gniteLostPartitionsOnLeaveBaselineSelfTest.java |   3 +-
 .../IgnitePdsBinaryMetadataAsyncWritingTest.java   |  16 +-
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java |  33 +-
 .../IgnitePdsBinarySortObjectFieldsTest.java       |   3 +-
 ...CacheConfigurationFileConsistencyCheckTest.java |   7 +-
 .../IgnitePdsCacheEntriesExpirationTest.java       |   3 +-
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |   3 +-
 .../IgnitePdsCacheRebalancingAbstractTest.java     |  13 +-
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |   3 +-
 ...nitePdsConsistencyOnDelayedPartitionOwning.java |   3 +-
 .../IgnitePdsContinuousRestartTest.java            |   3 +-
 .../persistence/IgnitePdsCorruptedIndexTest.java   |   5 +-
 .../persistence/IgnitePdsCorruptedStoreTest.java   |  27 +-
 .../IgnitePdsDestroyCacheAbstractTest.java         |   5 +-
 .../persistence/IgnitePdsDestroyCacheTest.java     |  10 +-
 ...gnitePdsDestroyCacheWithoutCheckpointsTest.java |   5 +-
 ...IgnitePdsDiscoDataHandlingInNewClusterTest.java |   3 +-
 .../persistence/IgnitePdsDynamicCacheTest.java     |   9 +-
 .../IgnitePdsExchangeDuringCheckpointTest.java     |   5 +-
 ...PdsMarshallerMappingRestoreOnNodeStartTest.java |   5 +-
 .../IgnitePdsNoSpaceLeftOnDeviceTest.java          |   3 +-
 .../cache/persistence/IgnitePdsPageSizesTest.java  |   3 +-
 .../IgnitePdsPartitionFilesDestroyTest.java        |  11 +-
 .../IgnitePdsPartitionsStateRecoveryTest.java      |   5 +-
 .../IgnitePdsRemoveDuringRebalancingTest.java      |   3 +-
 ...tePdsRestartAfterFailedToWriteMetaPageTest.java |   3 +-
 .../IgnitePdsSporadicDataRecordsOnBackupTest.java  |   5 +-
 ...IgnitePdsSpuriousRebalancingOnNodeJoinTest.java |   3 +-
 .../persistence/IgnitePdsTaskCancelingTest.java    |   3 +-
 .../IgnitePersistentStoreCacheGroupsTest.java      |  19 +-
 .../IgnitePersistentStoreDataStructuresTest.java   |  31 +-
 ...gniteRebalanceScheduleResendPartitionsTest.java |   3 +-
 .../persistence/SingleNodePersistenceSslTest.java  |   5 +-
 .../persistence/WalPreloadingConcurrentTest.java   |   3 +-
 .../ClientAffinityAssignmentWithBaselineTest.java  |  15 +-
 .../IgniteAbsentEvictionNodeOutOfBaselineTest.java |   3 +-
 ...gniteAllBaselineNodesOnlineFullApiSelfTest.java |   4 +-
 ...hangingBaselineDownCachePutAllFailoverTest.java |   3 +-
 ...hangingBaselineDownCacheRemoveFailoverTest.java |   3 +-
 ...eChangingBaselineUpCachePutAllFailoverTest.java |   3 +-
 ...eChangingBaselineUpCacheRemoveFailoverTest.java |   3 +-
 .../IgniteOfflineBaselineNodeFullApiSelfTest.java  |   4 +-
 ...niteOnlineNodeOutOfBaselineFullApiSelfTest.java |   4 +-
 ...gniteStableBaselineCachePutAllFailoverTest.java |   3 +-
 ...gniteStableBaselineCacheRemoveFailoverTest.java |   3 +-
 .../db/CheckpointBufferDeadlockTest.java           |   3 +-
 .../db/FullHistRebalanceOnClientStopTest.java      |   3 +-
 .../persistence/db/IgniteLogicalRecoveryTest.java  |  15 +-
 .../persistence/db/IgnitePdsCacheRestoreTest.java  |   3 +-
 ...IgnitePdsCacheWalDisabledOnRebalancingTest.java |   3 +-
 .../db/IgnitePdsDataRegionMetricsTest.java         |   9 +-
 .../db/IgnitePdsMultiNodePutGetRestartTest.java    |   4 +-
 .../persistence/db/IgnitePdsPageEvictionTest.java  |   3 +-
 ...PdsPageReplacementDuringPartitionClearTest.java |   3 +-
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |   7 +-
 .../db/IgnitePdsStartWIthEmptyArchive.java         |   5 +-
 .../db/IgnitePdsTransactionsHangTest.java          |   3 +-
 .../db/IgnitePdsWholeClusterRestartTest.java       |   5 +-
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |   3 +-
 .../db/IgniteSequentialNodeCrashRecoveryTest.java  |   3 +-
 .../SlowHistoricalRebalanceSmallHistoryTest.java   |   3 +-
 .../CheckpointFailBeforeWriteMarkTest.java         |   5 +-
 .../db/checkpoint/CheckpointFreeListTest.java      |  11 +-
 .../CheckpointListenerForRegionTest.java           |   3 +-
 .../db/checkpoint/CheckpointStartLoggingTest.java  |   3 +-
 .../IgniteCheckpointDirtyPagesForLowLoadTest.java  |   3 +-
 .../db/checkpoint/IgniteMassLoadSandboxTest.java   |  13 +-
 .../db/checkpoint/LightweightCheckpointTest.java   |   5 +-
 .../DefaultPageSizeBackwardsCompatibilityTest.java |   5 +-
 .../IgnitePdsCacheDestroyDuringCheckpointTest.java |   3 +-
 .../db/file/IgnitePdsCacheIntegrationTest.java     |   7 +-
 ...CheckpointSimulationWithRealCpDisabledTest.java |  19 +-
 .../db/file/IgnitePdsDiskErrorsRecoveringTest.java |  17 +-
 .../db/file/IgnitePdsNoActualWalHistoryTest.java   |   5 +-
 .../db/file/IgnitePdsPageReplacementTest.java      |   3 +-
 .../IgniteUidAsConsistentIdMigrationTest.java      |  25 +-
 .../db/wal/FsyncWalRolloverDoesNotBlockTest.java   |   3 +-
 .../db/wal/HistoricalReservationTest.java          |  13 +-
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |   3 +-
 ...ailIsReachedDuringIterationOverArchiveTest.java |   3 +-
 .../db/wal/IgniteWalFlushFailoverTest.java         |   3 +-
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |   5 +-
 .../db/wal/IgniteWalFormatFileFailoverTest.java    |   3 +-
 .../db/wal/IgniteWalHistoryReservationsTest.java   |  15 +-
 .../db/wal/IgniteWalRebalanceLoggingTest.java      |   3 +-
 .../persistence/db/wal/IgniteWalRebalanceTest.java |   3 +-
 .../db/wal/IgniteWalRecoveryPPCTest.java           |   9 +-
 .../wal/IgniteWalRecoverySeveralRestartsTest.java  |  13 +-
 .../db/wal/IgniteWalReplayingAfterRestartTest.java |   7 +-
 .../db/wal/IgniteWalSerializerVersionTest.java     |   3 +-
 .../db/wal/WalCompactionNoArchiverTest.java        |   3 +-
 .../db/wal/WalCompactionSwitchOnTest.java          |   5 +-
 .../persistence/db/wal/WalCompactionTest.java      |  13 +-
 .../db/wal/WalRebalanceRestartTest.java            |   3 +-
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java    |  31 +-
 .../db/wal/WalRolloverRecordLoggingTest.java       |   3 +-
 .../persistence/db/wal/WalRolloverTypesTest.java   |   9 +-
 .../IgniteAbstractWalIteratorInvalidCrcTest.java   |   5 +-
 ...teWithoutArchiverWalIteratorInvalidCrcTest.java |   5 +-
 .../db/wal/reader/IgniteWalReaderTest.java         |  30 +-
 .../persistence/freelist/FreeListCachingTest.java  |   5 +-
 .../metastorage/IgniteMetaStorageBasicTest.java    |  23 +-
 .../pagemem/PageMemoryLazyAllocationTest.java      |   3 +-
 .../PageMemoryLazyAllocationWithPDSTest.java       |   9 +-
 .../pagemem/PagesWriteThrottleSandboxTest.java     |   3 +-
 .../pagemem/PagesWriteThrottleSmokeTest.java       |   3 +-
 .../pagemem/UsedPagesMetricAbstractTest.java       |   3 +-
 .../snapshot/AbstractSnapshotSelfTest.java         |  20 +-
 .../snapshot/IgniteClusterSnapshotCheckTest.java   |  31 +-
 .../snapshot/IgniteClusterSnapshotDeltaTest.java   |   8 +-
 .../snapshot/IgniteClusterSnapshotSelfTest.java    |   6 +-
 .../snapshot/IgniteSnapshotManagerSelfTest.java    |   5 +-
 .../IgniteSnapshotWithMetastorageTest.java         |   6 +-
 .../standbycluster/AbstractNodeJoinTemplate.java   |   9 +-
 .../IgniteChangeGlobalStateAbstractTest.java       |   3 +-
 .../IgniteChangeGlobalStateCacheTest.java          |  27 +-
 .../IgniteChangeGlobalStateDataStreamerTest.java   |  41 +--
 .../IgniteChangeGlobalStateDataStructureTest.java  |  67 ++--
 .../IgniteChangeGlobalStateFailOverTest.java       |  43 +--
 .../IgniteChangeGlobalStateServiceTest.java        |   3 +-
 .../IgniteChangeGlobalStateTest.java               | 329 +++++++++---------
 .../IgniteNoParrallelClusterIsAllowedTest.java     |   7 +-
 .../standbycluster/IgniteStandByClusterTest.java   |  81 ++---
 .../extended/GridActivateExtensionTest.java        |   5 +-
 .../IgniteStandByClientReconnectTest.java          |  95 ++---
 ...niteStandByClientReconnectToNewClusterTest.java |  97 +++---
 .../wal/CpTriggeredWalDeltaConsistencyTest.java    |   3 +-
 .../wal/ExplicitWalDeltaConsistencyTest.java       |  15 +-
 .../wal/SysPropWalDeltaConsistencyTest.java        |   3 +-
 .../wal/WalEnableDisableWithNodeShutdownTest.java  |   7 +-
 .../wal/WalEnableDisableWithRestartsTest.java      |   3 +-
 .../reader/StandaloneWalRecordsIteratorTest.java   |   3 +-
 .../cache/query/CacheDataPageScanQueryTest.java    |   5 +-
 .../AbstractTransactionIntergrityTest.java         |   3 +-
 .../transactions/PartitionUpdateCounterTest.java   |   3 +-
 .../TxCrossCachePartitionConsistencyTest.java      |   3 +-
 .../cache/transactions/TxOnCachesStartTest.java    |   3 +-
 .../cache/transactions/TxOnCachesStopTest.java     |   9 +-
 .../TxPartitionCounterStateAbstractTest.java       |   3 +-
 .../TxPartitionCounterStateConsistencyTest.java    |  20 +-
 ...ounterStateOnePrimaryTwoBackupsFailAllTest.java |   3 +-
 .../cache/transactions/TxRollbackAsyncTest.java    |   3 +-
 .../transactions/TxWithKeyContentionSelfTest.java  |   3 +-
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |   3 +-
 .../cluster/BaselineAutoAdjustInMemoryTest.java    |   3 +-
 .../DistributedConfigurationAbstractTest.java      |   3 +-
 .../DistributedConfigurationPersistentTest.java    |   9 +-
 .../processors/database/IgniteDbAbstractTest.java  |   3 +-
 .../database/IgniteDbDynamicCacheSelfTest.java     |   5 +-
 .../database/IgniteDbPutGetWithCacheStoreTest.java |   9 +-
 .../datastreamer/DataStreamProcessorSelfTest.java  |   5 +-
 .../DistributedMetaStoragePersistentTest.java      |  38 +-
 .../metastorage/DistributedMetaStorageTest.java    |  31 +-
 .../processors/rest/RestProtocolStartTest.java     |   4 +-
 .../AbstractCacheOperationPermissionCheckTest.java |   3 +-
 .../client/AdditionalSecurityCheckTest.java        |   2 +-
 .../client/ThinClientSslPermissionCheckTest.java   |   3 +-
 .../compute/ComputePermissionCheckTest.java        |   3 +-
 .../security/sandbox/AbstractSandboxTest.java      |   3 +-
 .../AccessToClassesInsideInternalPackageTest.java  |   3 +-
 .../sandbox/SecuritySubjectPermissionsTest.java    |   3 +-
 .../service/ServiceDeploymentOnActivationTest.java |   7 +-
 .../ServiceDeploymentOutsideBaselineTest.java      |   7 +-
 .../loadtests/hashmap/GridCacheTestContext.java    |   2 -
 .../GridMarshallerMappingConsistencyTest.java      |   9 +-
 .../ignite/p2p/P2PScanQueryUndeployTest.java       |   3 +-
 .../junits/common/GridCommonAbstractTest.java      |   5 +-
 .../junits/multijvm/JavaVersionCommandParser.java  |   4 +-
 .../multijvm/JavaVersionCommandParserTest.java     |   6 +
 .../ignite/testsuites/IgniteSnapshotTestSuite.java |  54 +--
 .../GridInternalTaskUnusedWalSegmentsTest.java     |   3 +-
 .../ignite/util/mbeans/GridMBeanBaselineTest.java  |   3 +-
 .../modulestest/IgniteLaunchInModularEnvTest.java  |   2 +-
 modules/dev-utils/pom.xml                          |   5 -
 .../utils/IgniteWalConverterSensitiveDataTest.java |   3 +-
 .../development/utils/IgniteWalConverterTest.java  |   3 +-
 modules/direct-io/pom.xml                          |   5 -
 .../file/IgniteNativeIoWithNoPersistenceTest.java  |   3 +-
 modules/ducktests/tests/docker/Dockerfile          |   2 +-
 modules/ducktests/tests/docker/ducker-ignite       |  14 +-
 .../ducktests/tests/docker/requirements-dev.txt    |   2 +-
 modules/ducktests/tests/docker/requirements.txt    |   2 +-
 .../ducktests/tests/ignitetest/utils/version.py    |   6 +-
 modules/ducktests/tests/setup.py                   |   4 +-
 .../processors/query/h2/IgniteH2Indexing.java      |   3 +-
 .../org/apache/ignite/client/SecurityTest.java     |   3 +-
 ...aryMetadataConcurrentUpdateWithIndexesTest.java |   3 +-
 .../CacheGroupMetricsWithIndexBuildFailTest.java   |   5 +-
 .../cache/CacheGroupMetricsWithIndexTest.java      |  13 +-
 ...eckIndexesInlineSizeOnNodeJoinMultiJvmTest.java |   3 +-
 .../IgniteCacheObjectKeyIndexingSelfTest.java      |   3 +-
 .../cache/IgniteDynamicSqlRestoreTest.java         |  35 +-
 .../cache/IgniteErrorOnRebalanceTest.java          |   3 +-
 .../QueryJoinWithDifferentNodeFiltersTest.java     |   3 +-
 .../cache/StartCachesInParallelTest.java           |   5 +-
 .../authentication/SqlUserCommandSelfTest.java     |   3 +-
 .../near/IgniteSqlQueryWithBaselineTest.java       |   7 +-
 .../processors/cache/index/ArrayIndexTest.java     |   9 +-
 .../processors/cache/index/BasicIndexTest.java     |  12 +-
 .../ClientReconnectWithSqlTableConfiguredTest.java |   3 +-
 .../cache/index/H2RowCachePageEvictionTest.java    |   5 +-
 .../index/H2TreeCorruptedTreeExceptionTest.java    |   3 +-
 .../processors/cache/index/IndexMetricsTest.java   |   5 +-
 .../index/IoStatisticsBasicIndexSelfTest.java      |   7 +-
 .../processors/cache/index/LongIndexNameTest.java  |   5 +-
 .../index/OptimizedMarshallerIndexNameTest.java    |   3 +-
 .../processors/cache/index/StaticCacheDdlTest.java |   7 +-
 .../index/StopNodeOnRebuildIndexFailureTest.java   |   3 +-
 .../cache/metric/SqlViewExporterSpiTest.java       |   7 +-
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |   3 +-
 .../persistence/RebuildIndexLogMessageTest.java    |   5 +-
 .../db/IgniteCacheGroupsWithRestartsTest.java      |   3 +-
 .../persistence/db/IgniteTcBotInitNewPageTest.java |   3 +-
 ...xingMultithreadedLoadContinuousRestartTest.java |   3 +-
 .../db/LongDestroyDurableBackgroundTaskTest.java   |   9 +-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |  64 ++--
 ...niteDbSingleNodeWithIndexingWalRestoreTest.java |   9 +-
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |   3 +-
 .../IgnitePersistentStoreSchemaLoadTest.java       |   9 +-
 .../database/IgniteTwoRegionsRebuildIndexTest.java |   3 +-
 .../processors/database/RebuildIndexTest.java      |   3 +-
 .../RebuildIndexWithHistoricalRebalanceTest.java   |   3 +-
 ...eLockPartitionOnAffinityRunAtomicCacheTest.java |   3 +-
 ...elineLockPartitionOnAffinityRunTxCacheTest.java |   3 +-
 ...ngingBaselineCacheQueryNodeRestartSelfTest.java |   3 +-
 ...iteStableBaselineBinObjFieldsQuerySelfTest.java |   3 +-
 ...ableBaselineCacheQueryNodeRestartsSelfTest.java |   3 +-
 .../query/IgniteSqlCustomSchemaWithPdsEnabled.java |   5 +-
 .../processors/query/LocalQueryLazyTest.java       |   5 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  10 +-
 .../SqlTwoCachesInGroupWithSameEntryTest.java      |   3 +-
 .../query/h2/GridIndexRebuildSelfTest.java         |   3 +-
 .../processors/query/h2/GridIndexRebuildTest.java  |   5 +-
 .../processors/query/h2/QueryDataPageScanTest.java |   7 +-
 .../processors/query/oom/AbstractQueryOOMTest.java |   7 +-
 .../IgniteSnapshotWithIndexingTestSuite.java       |  30 +-
 .../PlatformCachePartialClientConnectionTest.cs    | 143 ++++++++
 .../Cache/Platform/PlatformCacheTest.cs            |   5 +-
 .../Platform/PlatformCacheTopologyChangeTest.cs    |   2 +
 .../platforms/dotnet/Apache.Ignite.Core/IIgnite.cs |   1 -
 modules/spring/pom.xml                             |   5 -
 .../java/org/apache/ignite/IgniteSpringBean.java   |   5 +-
 .../SpringEncryptedCacheRestartClientTest.java     |   3 +-
 .../SpringEncryptedCacheRestartTest.java           |   7 +-
 .../ignite/yardstick/IgniteAbstractBenchmark.java  |   5 +-
 .../yardstick/jdbc/AbstractJdbcBenchmark.java      |   3 +-
 ...coverySegmentationAndConnectionRestoreTest.java |   3 +-
 422 files changed, 3218 insertions(+), 2325 deletions(-)
 create mode 100644 modules/calcite/src/test/java/org/apache/ignite/internal/processors/query/calcite/integration/DynamicParametersIntegrationTest.java
 create mode 100644 modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/SnapshotCompressionBasicTest.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheCompressionManager.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/DataRegionMetricsMXBeanImpl.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/compress/CompressionHandler.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/mxbean/DataRegionMetricsMXBean.java
 delete mode 100644 modules/core/src/main/java/org/apache/ignite/mxbean/MemoryMetricsMXBean.java
 create mode 100644 modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/Platform/PlatformCachePartialClientConnectionTest.cs