You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by am...@apache.org on 2022/10/25 17:04:29 UTC

[ignite-3] branch ignite-17748 updated (6b0e3fc0fd -> 3dedf3a71f)

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

amashenkov pushed a change to branch ignite-17748
in repository https://gitbox.apache.org/repos/asf/ignite-3.git


    from 6b0e3fc0fd Add TODO.
     add a8a8bf3c45 IGNITE-17941 Add learners to Raft API (#1236)
     add 707ad51875 IGNITE-17954 Make inspections and codestyle IDEA config apply by default. Create default checkstyle IDEA config. (#1242)
     add 469c3ea81f IGNITE-17960 .NET: Migrate code analysis settings from RuleSet to EditorConfig (#1243)
     add 8ffe0420d7 IGNITE-17612 Fix TableScanNode data propagation - Fixes #1224.
     add 99f3cdf7a1 IGNITE-17893 Implement RAFT snapshot streaming sender for MV data (#1226)
     add 88c5fa3401 IGNITE-17260 IgniteTransactions and Transaction interfaces enriched with RO related methods (#1230)
     add 3dedf3a71f Merge branch 'main' into ignite-17748

No new revisions were added by this update.

Summary of changes:
 .gitignore                                         |    4 +
 .idea/checkstyle-idea.xml                          |   27 +
 .idea/codeStyles/Project.xml                       |  596 ++
 .idea/codeStyles/codeStyleConfig.xml               |    2 +-
 .../inspectionProfiles/Project_Default.xml         |   19 +-
 DEVNOTES.md                                        |    6 -
 check-rules/checkstyle-suppressions.xml            |    1 +
 idea/intellij-java-google-style.xml                |  606 --
 .../org/apache/ignite/tx/IgniteTransactions.java   |    7 +
 .../java/org/apache/ignite/tx/Transaction.java     |   15 +
 .../org/apache/ignite/tx/TransactionException.java |   11 +
 .../internal/client/tx/ClientTransaction.java      |   15 +
 .../internal/client/tx/ClientTransactions.java     |    6 +
 .../org/apache/ignite/client/fakes/FakeIgnite.java |   17 +
 .../ignite/client/fakes/FakeInternalTable.java     |   31 +
 .../internal/cluster/management/MockNode.java      |    2 +-
 .../management/raft/ItCmgRaftServiceTest.java      |    2 +-
 .../management/ClusterManagementGroupManager.java  |    1 +
 .../ignite/{ => internal}/hlc/HybridClock.java     |    2 +-
 .../ignite/{ => internal}/hlc/HybridTimestamp.java |    4 +-
 .../apache/ignite/internal/lock/AutoLockup.java}   |   24 +-
 .../ignite/internal/lock/ReusableLockLockup.java}  |   42 +-
 .../java/org/apache/ignite/lang/ErrorGroups.java   |    7 +
 .../ignite/{hlc => internal}/HybridClockTest.java  |    4 +-
 .../{hlc => internal}/HybridClockTestUtils.java    |    2 +-
 .../{hlc => internal}/HybridTimestampTest.java     |    4 +-
 .../internal/lock/ReusableLockLockupTest.java      |   54 +
 .../CompletableFutureExceptionMatcher.java         |  102 +
 .../matchers/CompletableFutureMatcher.java         |    2 +-
 modules/platforms/dotnet/.editorconfig             |   60 +
 .../dotnet/Apache.Ignite.Benchmarks/.editorconfig  |   26 +
 .../Apache.Ignite.Benchmarks.csproj                |    1 -
 .../.editorconfig                                  |   25 +
 .../Apache.Ignite.Internal.Generators.csproj       |    1 -
 .../GeneratorUtils.cs                              |   10 +
 .../platforms/dotnet/Apache.Ignite.Tests.ruleset   |   62 -
 .../dotnet/Apache.Ignite.Tests/.editorconfig       |   42 +
 .../Apache.Ignite.Tests/Apache.Ignite.Tests.csproj |    1 -
 .../Proto/ClientOpExtensionsTest.cs                |    5 +-
 .../dotnet/Apache.Ignite.Tests/Table/PocoStruct.cs |    2 +-
 modules/platforms/dotnet/Apache.Ignite.ruleset     |   66 -
 modules/platforms/dotnet/Apache.Ignite.sln         |    3 +-
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj      |    4 +-
 .../Internal/Buffers/PooledArrayBufferWriter.cs    |    3 +-
 .../Apache.Ignite/Internal/Buffers/PooledBuffer.cs |    5 +
 .../Apache.Ignite/Internal/ClientFailoverSocket.cs |    2 +
 .../Apache.Ignite/Internal/Compute/Compute.cs      |    2 +
 .../Apache.Ignite/Internal/Proto/ClientDataType.cs |    6 +
 .../Internal/Proto/ClientMessagePackType.cs        |   11 +-
 .../Apache.Ignite/Internal/Proto/ClientOp.cs       |    3 +
 .../Internal/Proto/MessagePackWriterExtensions.cs  |    6 +-
 .../Apache.Ignite/Internal/Proto/UuidSerializer.cs |    6 +-
 .../Apache.Ignite/Internal/Table/KeyValueView.cs   |   34 +-
 .../Apache.Ignite/Internal/Table/RecordView.cs     |    9 +-
 .../Table/Serialization/ObjectSerializerHandler.cs |    4 +
 modules/platforms/dotnet/Apache.Ignite/Option.cs   |    4 +-
 .../dotnet/Apache.Ignite/Sql/SqlStatement.cs       |    3 +-
 .../dotnet/Apache.Ignite/Table/IgniteTuple.cs      |    2 +
 modules/platforms/dotnet/DEVNOTES.md               |    2 +-
 modules/platforms/dotnet/Directory.Build.props     |    2 +
 .../raft/client/service/RaftGroupService.java      |   16 +-
 .../ignite/internal/raft/ItLearnersTest.java       |  355 +
 .../apache/ignite/internal/raft/ItLozaTest.java    |    2 +-
 .../internal/raft/ItRaftGroupServiceTest.java      |    2 +-
 .../apache/ignite/raft/jraft/core/ItNodeTest.java  |    2 +-
 .../ignite/raft/server/ItJraftHlcServerTest.java   |    2 +-
 .../java/org/apache/ignite/internal/raft/Loza.java |  136 +-
 .../ignite/internal/raft/server/RaftServer.java    |   25 +-
 .../internal/raft/server/impl/JraftServerImpl.java |   15 +-
 .../apache/ignite/raft/jraft/core/NodeImpl.java    |    5 +-
 .../ignite/raft/jraft/option/NodeOptions.java      |    2 +-
 .../apache/ignite/raft/jraft/rpc/RpcRequests.java  |    2 +-
 .../raft/jraft/rpc/impl/RaftGroupServiceImpl.java  |   22 +-
 .../org/apache/ignite/internal/raft/LozaTest.java  |    2 +-
 .../apache/ignite/raft/jraft/core/TestCluster.java |    2 +-
 .../ignite/raft/jraft/rpc/AbstractRpcTest.java     |    1 +
 .../ignite/raft/jraft/rpc/TestIgniteRpcServer.java |    1 +
 .../{jraft/rpc => messages}/TestMessageGroup.java  |    4 +-
 .../internal/raft/server/impl/RaftServerImpl.java  |    5 +-
 .../ignite/internal/replicator/ReplicaManager.java |    4 +-
 .../ignite/internal/replicator/ReplicaService.java |    2 +-
 .../replicator/message/TimestampAware.java         |    2 +-
 .../ItDistributedConfigurationPropertiesTest.java  |    2 +-
 .../ItDistributedConfigurationStorageTest.java     |    2 +-
 .../storage/ItRebalanceDistributedTest.java        |    6 +-
 .../runner/app/ItIgniteNodeRestartTest.java        |    6 +-
 .../runner/app/PlatformTestNodeRunner.java         |    4 +
 .../app/client/ItThinClientTransactionsTest.java   |   11 +
 .../internal/sql/engine/ItIndexSpoolTest.java      |   31 +-
 .../select1/select1_hashed_results.test_slow       | 7774 --------------------
 .../sql/sqlite/select1/select1_p1.test             |  275 -
 .../sql/sqlite/select1/select1_p2.test             |  191 -
 .../sql/sqlite/select1/select1_p3.test_ignored     |  859 ---
 .../sql/sqlite/select1/select1_p4.test_ignored     |  441 --
 .../sql/sqlite/select1/select1_p5.test_ignored     |  551 --
 .../sql/sqlite/select1/select1_p6.test_ignored     |  212 -
 .../sql/sqlite/select1/select1_p7.test_ignored     |  333 -
 .../sql/sqlite/select1/select1_p8.test_ignored     |  485 --
 .../sqlite/select1/select1_results.test_ignored    | 1070 ---
 ...ts.test_ignored => select2_hashed_results.test} |    2 -
 ...2_results.test_ignored => select2_results.test} |    2 -
 .../test_uncorrelated_any_subquery.test_ignored    |    2 +-
 .../org/apache/ignite/internal/app/IgniteImpl.java |   11 +-
 .../sql/engine/exec/rel/TableScanNode.java         |   12 +-
 .../internal/sql/engine/IgniteSqlApiTest.java      |   11 +
 .../sql/engine/exec/MockedStructuresTest.java      |    8 +-
 .../engine/exec/rel/TableScanExecutionTest.java    |  186 +
 .../engine/exec/rel/TableSpoolExecutionTest.java   |    2 +-
 modules/storage-api/build.gradle                   |    1 +
 modules/storage-api/pom.xml                        |    6 +
 .../internal/storage/MvPartitionStorage.java       |    2 +-
 .../internal/storage/PartitionTimestampCursor.java |    2 +-
 .../apache/ignite/internal/storage/ReadResult.java |    6 +-
 .../org/apache/ignite/internal/storage/RowId.java  |    9 +
 .../storage/AbstractMvPartitionStorageTest.java    |    4 +-
 .../storage/AbstractMvTableStorageTest.java        |    2 +-
 .../storage/impl/TestMvPartitionStorage.java       |    2 +-
 .../mv/AbstractPageMemoryMvPartitionStorage.java   |    2 +-
 .../storage/pagememory/mv/HybridTimestamps.java    |    4 +-
 .../storage/pagememory/mv/ReadRowVersion.java      |    2 +-
 .../internal/storage/pagememory/mv/RowVersion.java |    4 +-
 .../storage/pagememory/mv/RowVersionFreeList.java  |    2 +-
 .../storage/pagememory/mv/io/RowVersionDataIo.java |    2 +-
 .../AbstractPageMemoryMvPartitionStorageTest.java  |    2 +-
 ...PersistentPageMemoryMvPartitionStorageTest.java |    2 +-
 .../storage/rocksdb/RocksDbMvPartitionStorage.java |    4 +-
 .../storage/rocksdb/RocksDbMvTableStorageTest.java |    2 +-
 ...t.java => ItAbstractInternalTableScanTest.java} |   41 +-
 .../ItInternalTableReadOnlyOperationsTest.java     |  260 +
 .../ItInternalTableReadOnlyScanTest.java           |   51 +
 .../ItInternalTableReadWriteScanTest.java}         |   27 +-
 .../ignite/distributed/ItTablePersistenceTest.java |    8 +-
 .../distributed/ItTxDistributedTestSingleNode.java |   28 +-
 ...butedTestThreeNodesThreeReplicasCollocated.java |    4 +-
 .../distributed/TestPartitionDataStorage.java      |   99 +
 .../ignite/internal/table/ItColocationTest.java    |    2 +-
 .../ignite/internal/table/InternalTable.java       |   49 +
 .../internal/table/distributed/TableManager.java   |   44 +-
 .../table/distributed/command/FinishTxCommand.java |    2 +-
 .../distributed/command/TxCleanupCommand.java      |    2 +-
 .../distributed/command/UpdateAllCommand.java      |    2 +-
 .../distributed/raft/PartitionDataStorage.java     |  145 +
 .../table/distributed/raft/PartitionListener.java  |   12 +-
 .../distributed/raft/snapshot/PartitionAccess.java |   31 +
 .../raft/snapshot/PartitionAccessImpl.java         |   71 +
 .../distributed/raft/snapshot/PartitionKey.java    |   80 +
 .../snapshot/message/SnapshotMvDataRequest.java    |    7 +
 .../snapshot/message/SnapshotMvDataResponse.java   |    5 +-
 .../raft/snapshot/outgoing/OutgoingSnapshot.java   |  316 +-
 .../snapshot/outgoing/OutgoingSnapshotReader.java  |   10 +-
 .../OutgoingSnapshotRegistry.java}                 |   22 +-
 .../outgoing/OutgoingSnapshotsManager.java         |  139 +-
 .../raft/snapshot/outgoing/PartitionSnapshots.java |   42 +
 .../PartitionsSnapshots.java}                      |   15 +-
 .../SnapshotAwarePartitionDataStorage.java         |  144 +
 .../request/ReadOnlyReplicaRequest.java            |    7 +-
 .../ReadOnlyScanRetrieveBatchReplicaRequest.java   |    2 +
 .../replicator/PartitionReplicaListener.java       |  135 +-
 .../distributed/storage/InternalTableImpl.java     |  235 +-
 .../ignite/internal/table/TxAbstractTest.java      |  120 +
 .../apache/ignite/internal/table/TxLocalTest.java  |    2 +-
 .../table/distributed/TableManagerTest.java        |    4 +-
 .../PartitionRaftCommandsSerializationTest.java    |    2 +-
 .../raft/PartitionCommandListenerTest.java         |    7 +-
 .../raft/snapshot/PartitionAccessImplTest.java     |   86 +
 .../snapshot/outgoing/OutgoingSnapshotTest.java    |  447 ++
 .../outgoing/OutgoingSnapshotsManagerTest.java     |   81 +
 .../SnapshotAwarePartitionDataStorageTest.java     |  277 +
 .../replication/PartitionReplicaListenerTest.java  |   19 +-
 .../table/impl/DummyInternalTableImpl.java         |   13 +-
 .../ignite/internal/tx/InternalTransaction.java    |    1 +
 .../org/apache/ignite/internal/tx/TxManager.java   |   13 +-
 .../java/org/apache/ignite/internal/tx/TxMeta.java |    2 +-
 .../tx/impl/IgniteAbstractTransactionImpl.java     |  107 +
 .../internal/tx/impl/IgniteTransactionsImpl.java   |   23 +-
 .../internal/tx/impl/ReadOnlyTransactionImpl.java  |  101 +
 ...tionImpl.java => ReadWriteTransactionImpl.java} |   95 +-
 .../ignite/internal/tx/impl/TxManagerImpl.java     |   12 +-
 .../tx/message/TxCleanupReplicaRequest.java        |    2 +-
 .../tx/message/TxFinishReplicaRequest.java         |    2 +-
 .../internal/tx/message/TxStateReplicaRequest.java |    2 +-
 .../apache/ignite/internal/tx/TxManagerTest.java   |    2 +-
 .../storage/state/TxStateStorageAbstractTest.java  |    2 +-
 183 files changed, 5144 insertions(+), 13500 deletions(-)
 create mode 100644 .idea/checkstyle-idea.xml
 create mode 100644 .idea/codeStyles/Project.xml
 rename idea/ignite_inspections.xml => .idea/inspectionProfiles/Project_Default.xml (99%)
 delete mode 100644 idea/intellij-java-google-style.xml
 rename modules/core/src/main/java/org/apache/ignite/{ => internal}/hlc/HybridClock.java (98%)
 rename modules/core/src/main/java/org/apache/ignite/{ => internal}/hlc/HybridTimestamp.java (95%)
 copy modules/{replicator/src/main/java/org/apache/ignite/internal/replicator/message/TimestampAware.java => core/src/main/java/org/apache/ignite/internal/lock/AutoLockup.java} (57%)
 copy modules/core/src/{test/java/org/apache/ignite/hlc/HybridClockTestUtils.java => main/java/org/apache/ignite/internal/lock/ReusableLockLockup.java} (50%)
 rename modules/core/src/test/java/org/apache/ignite/{hlc => internal}/HybridClockTest.java (96%)
 rename modules/core/src/test/java/org/apache/ignite/{hlc => internal}/HybridClockTestUtils.java (97%)
 rename modules/core/src/test/java/org/apache/ignite/{hlc => internal}/HybridTimestampTest.java (93%)
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/lock/ReusableLockLockupTest.java
 create mode 100644 modules/core/src/testFixtures/java/org/apache/ignite/internal/testframework/matchers/CompletableFutureExceptionMatcher.java
 create mode 100644 modules/platforms/dotnet/.editorconfig
 create mode 100644 modules/platforms/dotnet/Apache.Ignite.Benchmarks/.editorconfig
 create mode 100644 modules/platforms/dotnet/Apache.Ignite.Internal.Generators/.editorconfig
 delete mode 100644 modules/platforms/dotnet/Apache.Ignite.Tests.ruleset
 create mode 100644 modules/platforms/dotnet/Apache.Ignite.Tests/.editorconfig
 delete mode 100644 modules/platforms/dotnet/Apache.Ignite.ruleset
 create mode 100644 modules/raft/src/integrationTest/java/org/apache/ignite/internal/raft/ItLearnersTest.java
 rename modules/raft/src/test/java/org/apache/ignite/raft/{jraft/rpc => messages}/TestMessageGroup.java (92%)
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_hashed_results.test_slow
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p1.test
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p2.test
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p3.test_ignored
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p4.test_ignored
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p5.test_ignored
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p6.test_ignored
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p7.test_ignored
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_p8.test_ignored
 delete mode 100644 modules/runner/src/integrationTest/sql/sqlite/select1/select1_results.test_ignored
 rename modules/runner/src/integrationTest/sql/sqlite/select2/{select2_hashed_results.test_ignored => select2_hashed_results.test} (99%)
 rename modules/runner/src/integrationTest/sql/sqlite/select2/{select2_results.test_ignored => select2_results.test} (99%)
 create mode 100644 modules/sql-engine/src/test/java/org/apache/ignite/internal/sql/engine/exec/rel/TableScanExecutionTest.java
 rename modules/table/src/integrationTest/java/org/apache/ignite/distributed/{ItInternalTableScanTest.java => ItAbstractInternalTableScanTest.java} (92%)
 create mode 100644 modules/table/src/integrationTest/java/org/apache/ignite/distributed/ItInternalTableReadOnlyOperationsTest.java
 create mode 100644 modules/table/src/integrationTest/java/org/apache/ignite/distributed/ItInternalTableReadOnlyScanTest.java
 copy modules/{replicator/src/main/java/org/apache/ignite/internal/replicator/message/TimestampAware.java => table/src/integrationTest/java/org/apache/ignite/distributed/ItInternalTableReadWriteScanTest.java} (57%)
 create mode 100644 modules/table/src/integrationTest/java/org/apache/ignite/distributed/TestPartitionDataStorage.java
 create mode 100644 modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/PartitionDataStorage.java
 create mode 100644 modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/snapshot/PartitionAccessImpl.java
 create mode 100644 modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/snapshot/PartitionKey.java
 copy modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/snapshot/{PartitionAccess.java => outgoing/OutgoingSnapshotRegistry.java} (63%)
 create mode 100644 modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/snapshot/outgoing/PartitionSnapshots.java
 copy modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/snapshot/{PartitionAccess.java => outgoing/PartitionsSnapshots.java} (67%)
 create mode 100644 modules/table/src/main/java/org/apache/ignite/internal/table/distributed/raft/snapshot/outgoing/SnapshotAwarePartitionDataStorage.java
 create mode 100644 modules/table/src/test/java/org/apache/ignite/internal/table/distributed/raft/snapshot/PartitionAccessImplTest.java
 create mode 100644 modules/table/src/test/java/org/apache/ignite/internal/table/distributed/raft/snapshot/outgoing/OutgoingSnapshotTest.java
 create mode 100644 modules/table/src/test/java/org/apache/ignite/internal/table/distributed/raft/snapshot/outgoing/OutgoingSnapshotsManagerTest.java
 create mode 100644 modules/table/src/test/java/org/apache/ignite/internal/table/distributed/raft/snapshot/outgoing/SnapshotAwarePartitionDataStorageTest.java
 create mode 100644 modules/transactions/src/main/java/org/apache/ignite/internal/tx/impl/IgniteAbstractTransactionImpl.java
 create mode 100644 modules/transactions/src/main/java/org/apache/ignite/internal/tx/impl/ReadOnlyTransactionImpl.java
 rename modules/transactions/src/main/java/org/apache/ignite/internal/tx/impl/{TransactionImpl.java => ReadWriteTransactionImpl.java} (73%)