You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by lt...@apache.org on 2021/06/03 18:22:56 UTC

[iotdb] branch cluster_scalability updated (57cdff5 -> 3458a8e)

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

lta pushed a change to branch cluster_scalability
in repository https://gitbox.apache.org/repos/asf/iotdb.git.


    from 57cdff5  fix a bug of replca num = 1 and update partition table before applyRemoveNode when exiling
     add 3458a8e  This commit fix following issues: 1. Replaced all Node header,int raftId with RaftNode raftNode 2. Remove raft from the methods: readFile and removeHardLink 3. Remove useless codes 4. Add necessary comments

No new revisions were added by this update.

Summary of changes:
 .../cluster/client/sync/SyncClientAdaptor.java     |  77 ++--
 .../iotdb/cluster/coordinator/Coordinator.java     |   9 +-
 .../apache/iotdb/cluster/log/LogDispatcher.java    |   1 -
 .../iotdb/cluster/log/applier/BaseApplier.java     |   4 +-
 .../iotdb/cluster/log/catchup/CatchUpTask.java     |   6 +-
 .../iotdb/cluster/log/catchup/LogCatchUpTask.java  |   2 -
 .../cluster/log/catchup/SnapshotCatchUpTask.java   |   1 -
 .../manage/FilePartitionedSnapshotLogManager.java  |   8 +-
 .../log/manage/MetaSingleSnapshotLogManager.java   |  18 -
 .../iotdb/cluster/log/manage/RaftLogManager.java   |   3 +
 .../iotdb/cluster/log/snapshot/FileSnapshot.java   |  14 +-
 .../cluster/log/snapshot/PartitionedSnapshot.java  |   2 +-
 .../cluster/log/snapshot/PullSnapshotTask.java     |   1 -
 .../apache/iotdb/cluster/metadata/CMManager.java   |  49 +--
 .../apache/iotdb/cluster/metadata/MetaPuller.java  |   6 +-
 .../iotdb/cluster/partition/PartitionGroup.java    |   5 +-
 .../iotdb/cluster/partition/PartitionTable.java    |  10 +-
 .../iotdb/cluster/partition/slot/SlotManager.java  |   5 +-
 .../cluster/partition/slot/SlotPartitionTable.java |  16 +-
 .../cluster/query/ClusterDataQueryExecutor.java    |   5 +-
 .../iotdb/cluster/query/ClusterPlanExecutor.java   |  30 +-
 .../iotdb/cluster/query/LocalQueryExecutor.java    |  11 +-
 .../iotdb/cluster/query/RemoteQueryContext.java    |   4 +-
 .../cluster/query/aggregate/ClusterAggregator.java |   4 +-
 .../cluster/query/fill/ClusterPreviousFill.java    |   1 -
 .../query/groupby/RemoteGroupByExecutor.java       |  16 +-
 .../query/last/ClusterLastQueryExecutor.java       |   4 +-
 .../cluster/query/reader/ClusterReaderFactory.java |  54 +--
 .../cluster/query/reader/ClusterTimeGenerator.java |   5 +-
 .../iotdb/cluster/query/reader/DataSourceInfo.java |   9 +-
 .../reader/RemoteSeriesReaderByTimestamp.java      |   8 +-
 .../query/reader/RemoteSimpleSeriesReader.java     |   6 +-
 .../query/reader/mult/MultDataSourceInfo.java      |   9 +-
 .../query/reader/mult/RemoteMultSeriesReader.java  |  10 +-
 .../apache/iotdb/cluster/server/ClientServer.java  |  10 +-
 .../iotdb/cluster/server/DataClusterServer.java    | 408 +++++++++------------
 .../iotdb/cluster/server/MetaClusterServer.java    |  38 +-
 .../cluster/server/PullSnapshotHintService.java    |   8 +-
 .../iotdb/cluster/server/StoppedMemberManager.java |   2 +-
 .../cluster/server/heartbeat/HeartbeatThread.java  |   2 -
 .../cluster/server/member/DataGroupMember.java     |  37 +-
 .../cluster/server/member/MetaGroupMember.java     |  24 +-
 .../iotdb/cluster/server/member/RaftMember.java    |  24 +-
 .../iotdb/cluster/server/monitor/NodeReport.java   |  12 +-
 .../cluster/server/service/BaseAsyncService.java   |  17 +-
 .../cluster/server/service/BaseSyncService.java    |  13 +-
 .../cluster/server/service/DataAsyncService.java   |  51 +--
 .../cluster/server/service/DataSyncService.java    |  43 +--
 .../cluster/client/async/AsyncDataClientTest.java  |   3 +-
 .../cluster/client/async/AsyncMetaClientTest.java  |   3 +-
 .../cluster/client/sync/SyncClientAdaptorTest.java |  83 ++---
 .../iotdb/cluster/common/TestAsyncDataClient.java  |  58 ++-
 .../org/apache/iotdb/cluster/common/TestUtils.java |   5 +
 .../cluster/log/applier/DataLogApplierTest.java    |   8 +-
 .../iotdb/cluster/log/catchup/CatchUpTaskTest.java |  10 +-
 .../cluster/log/catchup/LogCatchUpTaskTest.java    |   5 +-
 .../log/catchup/SnapshotCatchUpTaskTest.java       |   5 +-
 .../cluster/log/snapshot/DataSnapshotTest.java     |  11 +-
 .../cluster/log/snapshot/PullSnapshotTaskTest.java |   4 +-
 .../cluster/partition/SlotPartitionTableTest.java  |   6 +-
 .../reader/RemoteSeriesReaderByTimestampTest.java  |   4 +-
 .../query/reader/RemoteSimpleSeriesReaderTest.java |   6 +-
 .../mult/AssignPathManagedMergeReaderTest.java     |   4 +-
 .../reader/mult/RemoteMultSeriesReaderTest.java    |   6 +-
 .../iotdb/cluster/server/member/BaseMember.java    |  11 +-
 .../cluster/server/member/DataGroupMemberTest.java |  67 ++--
 .../cluster/server/member/MetaGroupMemberTest.java |  15 +-
 thrift-cluster/src/main/thrift/cluster.thrift      | 131 +++----
 68 files changed, 628 insertions(+), 919 deletions(-)