You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by ji...@apache.org on 2022/03/23 03:29:17 UTC

[iotdb] branch rocksdb/dev-2 updated (0e08e8b -> 168c97a)

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

jianyun pushed a change to branch rocksdb/dev-2
in repository https://gitbox.apache.org/repos/asf/iotdb.git.


 discard 0e08e8b  spotless apply
 discard 19b7d95  [RocksDB] fix unit tests
 discard c99b537  [RocksDB] rename classes name
 discard d88e76e  resolve conflict
 discard c76c1e9  resolve an issue where schemaEngine is empty in test scenarios
 discard 5657a93  use metaManager
 discard 4bc3212  add tags info when show timeseries
 discard 00e8bf1  merge master conflict resolve - 2
 discard 7473847  fix conflicts
 discard fa29d92  Merge branch 'master' into rocksdb/real
 discard 9d5edd2  Optimize rocksdb
 discard 768c004  fix bug of the incorrect number by counting nodes
 discard 857a7e1  print exception info
 discard 21ec140  support show child
 discard a405608  delete unused method
 discard 590c2bf  update
 discard 301d416  fix npe when query aligned timeseries
 discard 1d6757b  fix bug of creating aligned timeseries
 discard 6582efa  Fix the bug that path in PathNotExistException is incomplete when do insert
 discard 5472316  fix npe when init sgMNode
 discard 909135d  [RocksDB] code refine
 discard ffad17e  use max value replace magic number
 discard 5ae627af fix the bug of deleting storage groups
 discard 5b9a801  update exception info
 discard 40e0980  fix a bug where storage groups could not be created automatically
 discard aaa650d  enhance ut
 discard 97e7b5e  modify data transfer task
 discard 186a1d9  remove test info
 discard f81925a  fix a bug in wildcard processing
 discard fc14440  Fix a bug where the result is invalid
 discard 60aa088  fix npe when getBelongedToSG
 discard a0ee06e  fix some bugs
 discard 6b9fc11  spotless apply
 discard 90217e6  [rocksdb] fix the bug that upsert alias fail, refine delete timeseries logic
 discard 9fd80db  [RcoksDB] refine delete timeseries logic
 discard efc1d8f  fix incorrect storagegroup name in show timeseries
 discard 23854f8  implement show devices
 discard e36a52b  update the exception information in the log
 discard bd7b7fa  incorrect response to set storage group
 discard c0125cf  fix timeout issue when obtaining lock
 discard a290872  change the parameter type in function
 discard 4596420  update the way of getting measurementPath
 discard b037f43  support showTimeseries
 discard 4b54e2c  update the method of getting the schema
 discard 8c4fe12  [rocksdb] refine key exist check logic
 discard 7f295bf  spotless apply
 discard 8b07856  [rocksdb] complete data transfer
 discard d21ba8c  [rocksdb] complete metadata transfer from mmanage to mrockdb
 discard 8de94d0  fix bug of full path query
 discard 5bd78e7  fix a bug where the number of nodes is incorrect
 discard 39acb47  traverser changed to concurrency
 discard 0d0ea99  updated the matched interface
 discard 5bc2983  [rocksdb] refine some query interfaces
 discard 5bd8d72  use wildcard to query
 discard 137bd56  fix issue with calculating length
 discard defddc5  replace multi wildcard to single
 discard 1397077  Support * path pattern match
 discard 9917269  [RocksDB] fix the bug that update ttl does't work correctly
 discard 50ba5e3  [RocksDB] improve insert data process
 discard 36f33bb  fix the bug that StorageGroup won't create automactically when do insert
 discard c39ba7b  [RocksDB] update method call as some method signature changed
 discard 4fc7621  update
 discard 5714360  [RocksDB] Change MManager in IoTDB to IMetaManager interface
 discard 8247a2a  implement and update RMNode interfaces
 discard b19ea49  [RocksDB] support metadata transfer
 discard ea41226  implements RMNode
 discard f0aae29  add unit test and fix bug of matching path
 discard f270715  add belongedTo
 discard 020ba8f  change MNode to RMNode
 discard 236c31a  fix bug of getting path,and add the method of belonged to specified node type
 discard 0266fce  Lock whole write of timeseries while delete by storage group
 discard 51c5f0f  [RocksDB] add delete timeseries and delete storage group support
 discard c7add69  implement prefix matching related interface
 discard 8f1d765  implements getMeasurementPaths
 discard aff6b46  fix prefixed match
 discard d2f26b1  change the node type to char and fix bugs of using getLevelName
 discard d98e532  [rocksdb] optimize lock
 discard e6d4afa  [rocksdb] implement tags and attributes update
 discard 102322c  [rcoskdb] add mnode classes for rocksdb
 discard 264f212  update
 discard 4c5b3c9  add comment and implements some interface
 discard a7cc525  apply spotless
 discard 7c67ee4  merge forQuery to manager
 discard da827eb  merge codes
 discard 70c6fef  [rocksdb] add UT and fix write bugs
 discard e877f0b  add some unit tests for rocksdb write
 discard 570e082  [RocksDB] add integration test
 discard e3e1889  change the way of parsing key
 discard 0a4d64c  remove some useless code
 discard 9bb3e3a  Support aligned timeseries create
 discard f2512b4  create aligned timeseries
 discard bac1af6  complete write normal timeseries node logic
 discard 9593763  implement write - 1
 discard fd88f5d  get nodeType by key
 discard 57f6004  add name parser and query utils
 discard df6cfc9  update
 discard 07229c9  Rewrite part of the query interface
 discard 49544c2  Apply new value definition
 discard cd55bd5  Fix build error
 discard e5b8fda  add common constants
 discard a923380  extract IMetaManager for MManager and init rocksdb module
    omit 0d8e3fb  Fix flink-tsfile-connector error
    omit 14c0bf7  add 0.13.0 dockerfile
    omit fbd7963  [To rel/0.13][IOTDB-2749]Fix isPathExist check on MTree (#5259)
    omit a90f490  [IOTDB-1593] Fix generated files in client-py have unapproved license (#5257)
    omit 8ce9a7e  Enhance check statement before writing mlog (#5252)
    omit b0d0af3  [IOTDB-2723] Fix sequence inner space compaction loses data (#5249)
    omit 963b754  [To rel/0.13][IOTDB-2614]Fix inserting tablet with null value in TsFileWriter (#5245)
    omit 2662204  Modify cross priority param to upper case in doc (#5243)
    omit 31dc01c  [IOTDB-2742] Hide IDTable configurations (#5236)
    omit 2fddb64  [IOTDB-2734] Correct result type name in ResultMetadata (#5213) (#5221)
    omit fbbc115  Rel/0.13-update UserGuide about Administration (#5218)
    omit 64fa140  [IOTDB-2732] Reject inserting an invalid infinity float value (#5210) (#5217)
    omit 9496027  [IOTDB-2728] fix influxdb-protocol yaml (#5206)
    omit b87ea56  [IOTDB-2735] Remove the redundant code in Tablet (#5212)
    omit 3cb08ef  update 0.12.5 release note
    omit 9358c92  update docker and jdbc info
    omit eff3479  Update release note
     add ffd79dd  extract IMetaManager for MManager and init rocksdb module
     add 626b693  add common constants
     add cd40871  Fix build error
     add 474cedb  Apply new value definition
     add 3ac71f4  Rewrite part of the query interface
     add db897c5  update
     add 87a8b84  add name parser and query utils
     add 305a00a  get nodeType by key
     add af89119  implement write - 1
     add ff8f4f6  complete write normal timeseries node logic
     add b61ad71  create aligned timeseries
     add d4205bc  Support aligned timeseries create
     add e492101  remove some useless code
     add 78f44f7  change the way of parsing key
     add 0711cc4  [RocksDB] add integration test
     add c44ec14  add some unit tests for rocksdb write
     add 04e01b0  [rocksdb] add UT and fix write bugs
     add c154c01  merge codes
     add 98d4a3e  merge forQuery to manager
     add d99248c  apply spotless
     add 46808d9  add comment and implements some interface
     add 2805244  update
     add 90cbd43  [rcoskdb] add mnode classes for rocksdb
     add 8216bec0 [rocksdb] implement tags and attributes update
     add ffd8229  [rocksdb] optimize lock
     add 0fc5d67  change the node type to char and fix bugs of using getLevelName
     add 27dbf8c  fix prefixed match
     add c8b4259  implements getMeasurementPaths
     add 0a5399c  implement prefix matching related interface
     add f473f25  [RocksDB] add delete timeseries and delete storage group support
     add 9a46246  Lock whole write of timeseries while delete by storage group
     add 1ad6fa7  fix bug of getting path,and add the method of belonged to specified node type
     add 8e104ef  change MNode to RMNode
     add 49df75e  add belongedTo
     add e150bf5  add unit test and fix bug of matching path
     add ed006c7  implements RMNode
     add fb4bfdc  [RocksDB] support metadata transfer
     add 27e3fa9  implement and update RMNode interfaces
     add 6c9d21d  [RocksDB] Change MManager in IoTDB to IMetaManager interface
     add fda6ddd  update
     add fbebf0d  [RocksDB] update method call as some method signature changed
     add b310db7  spotless apply
     add 8fa37c8  fix the bug that StorageGroup won't create automactically when do insert
     add b48bb58  [RocksDB] improve insert data process
     add 6f57335  [RocksDB] fix the bug that update ttl does't work correctly
     add 9566c85  Support * path pattern match
     add 1017830  replace multi wildcard to single
     add 8e03209  fix issue with calculating length
     add cdffc18  use wildcard to query
     add 167dbe8  [rocksdb] refine some query interfaces
     add 2d36d04  updated the matched interface
     add e95e9a6  traverser changed to concurrency
     add d280510  fix a bug where the number of nodes is incorrect
     add 5a75e55  fix bug of full path query
     add 654a227  [rocksdb] complete metadata transfer from mmanage to mrockdb
     add 407f39e  [rocksdb] complete data transfer
     add 815ad02  spotless apply
     add e2f4332  [rocksdb] refine key exist check logic
     add b1c4e9b  update the method of getting the schema
     add 766ac9d  support showTimeseries
     add c2b07bb  update the way of getting measurementPath
     add 9afb46d  change the parameter type in function
     add ade0535  fix timeout issue when obtaining lock
     add 4da944f  incorrect response to set storage group
     add 6eddeaa  update the exception information in the log
     add 1c82067  implement show devices
     add 92f9e26  fix incorrect storagegroup name in show timeseries
     add 7914892  [RcoksDB] refine delete timeseries logic
     add 389b945  [rocksdb] fix the bug that upsert alias fail, refine delete timeseries logic
     add ea97ca9  spotless apply
     add 35e9814  fix some bugs
     add 19c0b9d  fix npe when getBelongedToSG
     add aee1e15  Fix a bug where the result is invalid
     add 4928fca  fix a bug in wildcard processing
     add 38f97ba  remove test info
     add 5ee9680  modify data transfer task
     add 48b994a  enhance ut
     add 08d60d6  fix a bug where storage groups could not be created automatically
     add 353acd7  update exception info
     add 6379c13  fix the bug of deleting storage groups
     add 0c3cc0c  use max value replace magic number
     add b35213b  [RocksDB] code refine
     add 82a5453  fix npe when init sgMNode
     add 18568c3  Fix the bug that path in PathNotExistException is incomplete when do insert
     add 516b332  fix bug of creating aligned timeseries
     add 05ea4d4  fix npe when query aligned timeseries
     add d217340  update
     add 1b0f281  delete unused method
     add f3ffbcb  support show child
     add ccfdd63  print exception info
     add 79f22c1  fix bug of the incorrect number by counting nodes
     add 5d86ecf  Optimize rocksdb
     add dd480fe  [IOTDB-2305]Library anomaly (Modification) (#5318)
     add cb4aa6e  [IOTDB-2686] Region allocation policy (#5308)
     add 717bab3  [IOTDB-2776] Improve the TsFileWriter's method: write(Tablet tablet) (#5310)
     add 3dca44a  [IOTDB-2786][Dependency] remove iotdb-session dependent on iotdb-server(test) (#5319)
     add c719742  Merge remote-tracking branch 'upstream/master' into rocksdb/dev3
     add eb09f8b  fix conflicts
     add c680035  merge master conflict resolve - 2
     add ee3c3db  add tags info when show timeseries
     add 1ca580d  use metaManager
     add 6387eed  resolve an issue where schemaEngine is empty in test scenarios
     add f4e1210  resolve conflict
     add 6f2af01  [RocksDB] rename classes name
     add f29f17d  [RocksDB] fix unit tests
     add 168c97a  spotless apply

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (0e08e8b)
            \
             N -- N -- N   refs/heads/rocksdb/dev-2 (168c97a)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

Summary of changes:
 RELEASE_NOTES.md                                   |  60 -------
 confignode/pom.xml                                 |   5 +
 .../resources/conf/iotdb-confignode.properties     |  60 ++++---
 .../iotdb/confignode/conf/ConfigNodeConf.java      |  28 ++++
 .../confignode/conf/ConfigNodeDescriptor.java      |  15 ++
 .../consensus/response/DataNodesInfoDataSet.java   |  29 ++--
 .../response/StorageGroupSchemaDataSet.java        |  23 ++-
 .../statemachine/PartitionRegionStateMachine.java  |  57 +++++--
 .../physical/UnknownPhysicalPlanTypeException.java |  10 +-
 .../iotdb/confignode/manager/ConfigManager.java    |  55 +++++--
 .../iotdb/confignode/partition/DataNodeInfo.java   |  88 +++++++++++
 .../confignode/partition/DataPartitionInfo.java    |  80 ++++++++++
 .../iotdb/confignode/partition/PartitionTable.java | 152 +++++++++++++++---
 ...artitionTable.java => SchemaPartitionInfo.java} |  45 +++---
 .../confignode/partition/StorageGroupSchema.java   |  77 +++++++++
 .../iotdb/confignode/physical/PhysicalPlan.java    |  97 ++++++++++++
 .../confignode/physical/PhysicalPlanType.java      |  16 +-
 .../physical/sys/DeleteStorageGroupPlan.java       |  22 +--
 .../physical/sys/QueryDataNodeInfoPlan.java        |  53 ++++---
 .../physical/sys/QueryStorageGroupSchemaPlan.java  |  21 +--
 .../physical/sys/RegisterDataNodePlan.java         |  65 ++++++++
 .../physical/sys/SetStorageGroupPlan.java          |  47 +++---
 .../service/basic/ConfigServiceProvider.java       |  24 ---
 .../confignode/service/executor/PlanExecutor.java  |  87 ++++++++++
 .../service/thrift/server/ConfigNodeRPCServer.java |   2 +-
 .../server/ConfigNodeRPCServerProcessor.java       |  87 ++++++++--
 .../server/ConfigNodeRPCServerProcessorTest.java   | 123 ++++++++++++++
 .../apache/iotdb/consensus/common/Endpoint.java    |   5 +
 .../apache/iotdb/consensus/common/GroupType.java   |   2 +-
 .../standalone/StandAloneConsensusTest.java        |   2 +-
 docker/src/main/Dockerfile-0.12.3-cluster          |  53 -------
 docker/src/main/Dockerfile-0.12.3-grafana          |  41 -----
 docker/src/main/Dockerfile-0.12.3-node             |  45 ------
 docker/src/main/Dockerfile-0.12.4-cluster          |  53 -------
 docker/src/main/Dockerfile-0.12.4-grafana          |  41 -----
 docker/src/main/Dockerfile-0.12.4-node             |  45 ------
 docker/src/main/Dockerfile-0.12.5-cluster          |  53 -------
 docker/src/main/Dockerfile-0.12.5-grafana          |  41 -----
 docker/src/main/Dockerfile-0.12.5-node             |  45 ------
 docker/src/main/Dockerfile-0.13.0-cluster          |  53 -------
 docker/src/main/Dockerfile-0.13.0-grafana          |  41 -----
 docker/src/main/Dockerfile-0.13.0-node             |  45 ------
 docs/zh/UserGuide/Library-UDF/Anomaly Detection.md |  21 +++
 integration/pom.xml                                |   7 +
 .../session/IoTDBSessionDisableMemControlIT.java   |   0
 .../session/IoTDBSessionVectorABDeviceIT.java      |   0
 .../session/IoTDBSessionVectorAggregationIT.java   |   0
 .../IoTDBSessionVectorAggregationWithUnSeqIT.java  |   0
 .../iotdb/session/IoTDBSessionVectorInsertIT.java  |   0
 .../java/org/apache/iotdb/session/SessionTest.java |   0
 .../apache/iotdb/session/pool/SessionPoolTest.java |   0
 .../apache/iotdb/session/template/TemplateUT.java  |   0
 jdbc/src/main/feature/feature.xml                  |   2 +-
 .../resources/conf/iotdb-engine.properties         |   8 +
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  |  26 ++-
 .../iotdb/db/metadata/mlog/MLogUpgraderTest.java   | 176 +++++++++++++++++++++
 session/pom.xml                                    |  13 --
 .../src/main/thrift/confignode.thrift              |  52 +++---
 .../chunk/NonAlignedChunkGroupWriterImpl.java      |  26 +--
 59 files changed, 1412 insertions(+), 912 deletions(-)
 copy consensus/src/main/java/org/apache/iotdb/consensus/statemachine/EmptyStateMachine.java => confignode/src/main/java/org/apache/iotdb/confignode/consensus/response/DataNodesInfoDataSet.java (62%)
 copy server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowTTLPlan.java => confignode/src/main/java/org/apache/iotdb/confignode/consensus/response/StorageGroupSchemaDataSet.java (64%)
 copy server/src/main/java/org/apache/iotdb/db/consensus/statemachine/BaseStateMachine.java => confignode/src/main/java/org/apache/iotdb/confignode/consensus/statemachine/PartitionRegionStateMachine.java (55%)
 copy server/src/main/java/org/apache/iotdb/db/exception/StorageGroupNotReadyException.java => confignode/src/main/java/org/apache/iotdb/confignode/exception/physical/UnknownPhysicalPlanTypeException.java (68%)
 create mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/partition/DataNodeInfo.java
 create mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/partition/DataPartitionInfo.java
 copy confignode/src/main/java/org/apache/iotdb/confignode/partition/{PartitionTable.java => SchemaPartitionInfo.java} (55%)
 create mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/partition/StorageGroupSchema.java
 create mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/physical/PhysicalPlan.java
 copy cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/SnapshotFactory.java => confignode/src/main/java/org/apache/iotdb/confignode/physical/PhysicalPlanType.java (80%)
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/MetadataIndexEntryV2.java => confignode/src/main/java/org/apache/iotdb/confignode/physical/sys/DeleteStorageGroupPlan.java (64%)
 copy cluster/src/test/java/org/apache/iotdb/cluster/log/HardStateTest.java => confignode/src/main/java/org/apache/iotdb/confignode/physical/sys/QueryDataNodeInfoPlan.java (52%)
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/EmptyDataSet.java => confignode/src/main/java/org/apache/iotdb/confignode/physical/sys/QueryStorageGroupSchemaPlan.java (63%)
 create mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/physical/sys/RegisterDataNodePlan.java
 copy server/src/main/java/org/apache/iotdb/db/qp/strategy/LogicalChecker.java => confignode/src/main/java/org/apache/iotdb/confignode/physical/sys/SetStorageGroupPlan.java (51%)
 delete mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/service/basic/ConfigServiceProvider.java
 create mode 100644 confignode/src/main/java/org/apache/iotdb/confignode/service/executor/PlanExecutor.java
 create mode 100644 confignode/src/test/java/org/apache/iotdb/confignode/service/thrift/server/ConfigNodeRPCServerProcessorTest.java
 delete mode 100644 docker/src/main/Dockerfile-0.12.3-cluster
 delete mode 100644 docker/src/main/Dockerfile-0.12.3-grafana
 delete mode 100644 docker/src/main/Dockerfile-0.12.3-node
 delete mode 100644 docker/src/main/Dockerfile-0.12.4-cluster
 delete mode 100644 docker/src/main/Dockerfile-0.12.4-grafana
 delete mode 100644 docker/src/main/Dockerfile-0.12.4-node
 delete mode 100644 docker/src/main/Dockerfile-0.12.5-cluster
 delete mode 100644 docker/src/main/Dockerfile-0.12.5-grafana
 delete mode 100644 docker/src/main/Dockerfile-0.12.5-node
 delete mode 100644 docker/src/main/Dockerfile-0.13.0-cluster
 delete mode 100644 docker/src/main/Dockerfile-0.13.0-grafana
 delete mode 100644 docker/src/main/Dockerfile-0.13.0-node
 rename {session => integration}/src/test/java/org/apache/iotdb/session/IoTDBSessionDisableMemControlIT.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/IoTDBSessionVectorABDeviceIT.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/IoTDBSessionVectorAggregationIT.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/IoTDBSessionVectorAggregationWithUnSeqIT.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/IoTDBSessionVectorInsertIT.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/SessionTest.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/pool/SessionPoolTest.java (100%)
 rename {session => integration}/src/test/java/org/apache/iotdb/session/template/TemplateUT.java (100%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/mlog/MLogUpgraderTest.java