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/03/23 10:50:53 UTC

[ignite] branch ignite-cdc updated (4723bd6 -> d0ebc48)

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 4723bd6  IGNITE-13878 Fixed Allocated RAM metric for IM region on persistent node.
     add 034d196  IGNITE-14361 WhiteSpace after checkstyle rule (#8907)
     add 8ab281b  IGNITE-14373 Fix race between auto rollover WAL segment and deactivate of WAL (#8912)
     add d0ebc48  IGNITE-14160 Issue warning if SSL handshake is too long - Fixes #8792.

No new revisions were added by this update.

Summary of changes:
 checkstyle/checkstyle.xml                          |   8 ++
 .../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 +-
 .../persistence/FoldersReuseCompatibilityTest.java |   2 +-
 .../AbstractPageCompressionIntegrationTest.java    |   2 +-
 .../compress/CompressionConfigurationTest.java     |   4 +-
 .../compress/CompressionProcessorTest.java         |   6 +-
 .../DiskPageCompressionIntegrationTest.java        |  10 +-
 .../WalPageCompressionIntegrationTest.java         |   4 +-
 .../internal/commandline/query/KillCommand.java    |   2 +-
 .../commandline/CommandHandlerParsingTest.java     |   2 +-
 .../util/GridCommandHandlerClusterByClassTest.java |   4 +-
 .../apache/ignite/util/GridCommandHandlerTest.java |   2 +-
 .../java/org/apache/ignite/cache/QueryEntity.java  |   2 +-
 .../sorted/SortedEvictionPolicyFactory.java        |   2 +-
 .../ignite/configuration/CacheConfiguration.java   |   4 +-
 .../events/CacheConsistencyViolationEvent.java     |   4 +-
 .../ignite/internal/GridEventConsumeHandler.java   |   2 +-
 .../internal/client/thin/TcpClientChannel.java     |   2 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java       |   2 +-
 .../managers/discovery/GridDiscoveryManager.java   |   2 +-
 .../processors/cache/CacheEvictableEntryImpl.java  |   2 +-
 .../processors/cache/GridCacheIoManager.java       |   2 +-
 .../processors/cache/GridCacheMapEntry.java        |   4 +-
 .../processors/cache/GridCacheProcessor.java       |   2 +-
 .../binary/CacheObjectBinaryProcessorImpl.java     |   6 +-
 .../dht/topology/GridClientPartitionTopology.java  |   2 +-
 .../dht/topology/GridDhtPartitionsReservation.java |   4 +-
 .../cache/distributed/near/GridNearGetFuture.java  |   2 +-
 .../cache/distributed/near/GridNearLockFuture.java |   2 +-
 .../GridCacheDatabaseSharedManager.java            |   2 +-
 .../cache/persistence/GridCacheOffheapManager.java |   2 +-
 .../cache/persistence/RecoveryDebug.java           |   2 +-
 .../cache/persistence/tree/BPlusTree.java          |   6 +-
 .../persistence/wal/FileWriteAheadLogManager.java  | 143 +++++++++++++++------
 .../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 +-
 .../processors/cache/verify/IdleVerifyUtility.java |   2 +-
 .../processors/datastreamer/DataStreamerImpl.java  |   2 +-
 .../datastructures/AtomicDataStructureProxy.java   |   2 +-
 .../datastructures/DataStructuresProcessor.java    |   2 +-
 .../datastructures/GridCacheLockImpl.java          |   2 +-
 .../datastructures/GridCacheSemaphoreState.java    |   4 +-
 .../internal/processors/odbc/SqlListenerUtils.java |   2 +-
 .../cache/ClientCacheSqlFieldsQueryRequest.java    |   2 +-
 .../platform/cluster/PlatformClusterGroup.java     |   2 +-
 .../internal/processors/query/QueryUtils.java      |   8 +-
 .../org/apache/ignite/internal/util/GridDebug.java |   4 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |   2 +-
 .../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 +-
 .../java/org/apache/ignite/lang/IgniteBiTuple.java |   2 +-
 .../priorityqueue/PriorityQueueCollisionSpi.java   |   2 +-
 .../apache/ignite/spi/indexing/IndexingSpi.java    |   2 +-
 .../ignite/spi/indexing/noop/NoopIndexingSpi.java  |   2 +-
 .../apache/ignite/stream/StreamTransformer.java    |   2 +-
 .../java/org/jsr166/ConcurrentLinkedHashMap.java   |   8 +-
 .../store/StoreResourceInjectionSelfTest.java      |   4 +-
 .../TestJdbcPojoStoreFactoryWithHangWriteAll.java  |   2 +-
 .../failure/FailureHandlerTriggeredTest.java       |   2 +-
 .../GridMultithreadedJobStealingSelfTest.java      |  12 +-
 ...ectByteBufferStreamImplV2ByteOrderSelfTest.java |  18 +--
 .../optimized/OptimizedMarshallerTest.java         |  12 +-
 ...InterceptorPartitionCounterLocalSanityTest.java |  12 +-
 .../processors/cache/CacheRebalancingSelfTest.java |   2 +-
 .../cache/CacheStopAndDestroySelfTest.java         |  20 +--
 .../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 +-
 .../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 +-
 .../GridCacheRebalancingSyncSelfTest.java          |   2 +-
 ...teCacheStoreSessionWriteBehindAbstractTest.java |   4 +-
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |   2 +-
 .../cache/mvcc/CacheMvccAbstractTest.java          |   6 +-
 .../mvcc/CacheMvccConfigurationValidationTest.java |   6 +-
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |   2 +-
 .../IgnitePdsCacheRebalancingAbstractTest.java     |   2 +-
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |   2 +-
 .../IgnitePdsSporadicDataRecordsOnBackupTest.java  |   2 +-
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |   2 +-
 .../db/file/IgnitePdsThreadInterruptionTest.java   |   2 +-
 .../db/wal/WalDeletionArchiveAbstractTest.java     |   4 +-
 .../db/wal/WriteAheadLogManagerSelfTest.java       | 128 ++++++++++++++++--
 .../pagelocktracker/log/PageLockLogTest.java       |   6 +-
 .../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 +-
 .../processors/database/BPlusTreeSelfTest.java     |  24 ++--
 .../IgniteDataStreamerPerformanceTest.java         |   2 +-
 .../IgniteMessagingConfigVariationFullApiTest.java |   6 +-
 .../ignite/internal/util/GridArraysSelfTest.java   |  20 +--
 .../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 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java      |   2 +-
 .../tcp/TcpDiscoveryNodeJoinAndFailureTest.java    |   2 +-
 .../apache/ignite/testframework/GridTestUtils.java |   2 +-
 .../testframework/junits/GridAbstractTest.java     |   6 +-
 .../testframework/test/VariationsIteratorTest.java |  10 +-
 .../testsuites/IgniteCacheMvccTestSuite7.java      |   4 +-
 .../apache/ignite/util/GridLongListSelfTest.java   |  10 +-
 .../development/utils/IgniteWalConverterTest.java  |   8 +-
 .../ignite/tests/p2p/AlwaysTruePredicate.java      |   2 +-
 .../cache/hibernate/HibernateCacheProxy.java       |   4 +-
 .../processors/query/h2/database/H2TreeIndex.java  |   2 +-
 .../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 +-
 .../query/h2/sql/GridSqlQuerySplitter.java         |  14 +-
 .../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 +-
 .../visor/verify/ValidateIndexesClosure.java       |   2 +-
 .../cache/BinaryTypeMismatchLoggingTest.java       |   2 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java    |   4 +-
 .../processors/cache/GridCacheOffHeapSelfTest.java |   2 +-
 .../cache/GridCacheQuerySimpleBenchmark.java       |   4 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java    |   2 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java    |   4 +-
 .../cache/IgniteCacheCollocatedQuerySelfTest.java  |   8 +-
 .../cache/IgniteCacheDistributedJoinTest.java      |  12 +-
 .../IgniteCacheFieldsQueryNoDataSelfTest.java      |   2 +-
 .../cache/IgniteCacheLargeResultSelfTest.java      |   2 +-
 .../cache/IgniteCacheOffheapEvictQueryTest.java    |   4 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java     |   2 +-
 .../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 +-
 ...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 +-
 .../IgniteDbSingleNodeWithIndexingPutGetTest.java  |  14 +-
 .../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 +-
 .../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 +-
 .../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 +-
 .../opencensus/OpenCensusSqlNativeTracingTest.java |   4 +-
 .../GridSpringResourceInjectionSelfTest.java       |   2 +-
 .../scanners/file/UriDeploymentFileScanner.java    |   2 +-
 .../cache/IgniteCacheAbstractBenchmark.java        |   2 +-
 .../spi/discovery/zk/internal/ZkIgnitePaths.java   |   2 +-
 .../zk/ZookeeperDiscoverySpiTestUtil.java          |   4 +-
 246 files changed, 783 insertions(+), 586 deletions(-)