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

[iotdb] 08/13: Merge remote-tracking branch 'origin/master' into lmh/fileScan

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

hui pushed a commit to branch lmh/fileScan
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit d53bd3d3bffc0aadc97689ab23f9efc6d72e3f68
Merge: 79e4a1cb5a 94ac27b57f
Author: Minghui Liu <li...@foxmail.com>
AuthorDate: Tue Mar 21 09:43:14 2023 +0800

    Merge remote-tracking branch 'origin/master' into lmh/fileScan

 README.md                                          |    4 +-
 .../org/apache/iotdb/db/qp/sql/IdentifierParser.g4 |    1 +
 .../org/apache/iotdb/db/qp/sql/IoTDBSqlParser.g4   |    1 +
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlLexer.g4  |    4 +
 .../client/async/AsyncDataNodeClientPool.java      |   14 +
 .../confignode/conf/ConfigNodeDescriptor.java      |    2 +-
 .../confignode/conf/ConfigNodeStartupCheck.java    |   40 +-
 .../consensus/request/ConfigPhysicalPlan.java      |   16 +
 .../write/pipe/plugin/CreatePipePluginPlan.java    |    4 +
 .../statemachine/ConfigRegionStateMachine.java     |    3 +-
 .../iotdb/confignode/manager/ConfigManager.java    |    5 +
 .../apache/iotdb/confignode/manager/IManager.java  |    8 +
 .../iotdb/confignode/manager/ProcedureManager.java |   46 +
 .../manager/consensus/ConsensusManager.java        |   63 +-
 .../iotdb/confignode/manager/node/NodeManager.java |    9 +
 .../manager/pipe/PipePluginCoordinator.java        |  120 +-
 .../procedure/env/ConfigNodeProcedureEnv.java      |   31 +
 .../pipe/plugin/CreatePipePluginProcedure.java     |  306 +
 .../impl/pipe/plugin/DropPipePluginProcedure.java  |  251 +
 .../state/pipe/plugin/CreatePipePluginState.java   |   13 +-
 .../state/pipe/plugin/DropPipePluginState.java     |   13 +-
 .../procedure/store/ProcedureFactory.java          |   12 +
 .../confignode/procedure/store/ProcedureType.java  |    6 +-
 .../iotdb/confignode/service/ConfigNode.java       |   17 +-
 .../confignode/service/ConfigNodeCommandLine.java  |    7 +-
 .../thrift/ConfigNodeRPCServiceProcessor.java      |    5 +
 .../impl/pipe/CreatePipePluginProcedureTest.java   |   60 +
 .../impl/pipe/DropPipePluginProcedureTest.java     |   53 +
 .../confignode1conf/iotdb-common.properties        |    1 +
 .../confignode2conf/iotdb-common.properties        |    1 +
 .../confignode3conf/iotdb-common.properties        |    1 +
 .../iotdb/consensus/config/ConsensusConfig.java    |   15 -
 .../ratis/ApplicationStateMachineProxy.java        |   35 +-
 .../iotdb/consensus/ratis/RatisConsensus.java      |   31 +-
 .../org/apache/iotdb/consensus/ratis/Utils.java    |   15 +
 .../ratis/metrics/IoTDBMetricRegistry.java         |   65 +-
 .../ratis/metrics/MetricRegistryManager.java       |   13 +-
 .../consensus/ratis/metrics/RatisMetricSet.java    |   79 +-
 .../ratis/metrics/RatisMetricsManager.java         |   89 +
 .../iotdb/consensus/simple/SimpleConsensus.java    |   26 +-
 .../apache/iotdb/consensus/iot/ReplicateTest.java  |    2 -
 .../apache/iotdb/consensus/iot/StabilityTest.java  |    2 -
 .../iotdb/consensus/ratis/RatisConsensusTest.java  |    2 -
 .../apache/iotdb/consensus/ratis/SnapshotTest.java |   11 +-
 .../iotdb/consensus/simple/RecoveryTest.java       |    2 -
 docs/Community/Materials.md                        |  329 +-
 .../Apache-IoTDB-ConfigNode-Dashboard.json         | 4184 ++++++-------
 .../Apache-IoTDB-DataNode-Dashboard.json           | 6615 +++++++++++---------
 ...rd.json => Apache-IoTDB-Disk-IO-Dashboard.json} |  486 +-
 .../Apache-IoTDB-Network-Dashboard.json            |    7 +-
 docs/UserGuide/Monitor-Alert/Metric-Tool.md        |   99 +-
 docs/UserGuide/Operators-Functions/Aggregation.md  |   32 +-
 docs/UserGuide/Operators-Functions/Mathematical.md |   65 +-
 docs/zh/UserGuide/Monitor-Alert/Metric-Tool.md     |   79 +-
 .../UserGuide/Operators-Functions/Aggregation.md   |    2 +-
 .../UserGuide/Operators-Functions/Mathematical.md  |   63 +-
 docs/zh/UserGuide/Operators-Functions/Overview.md  |   44 +-
 grafana-plugin/yarn.lock                           |    6 +-
 .../itbase/constant/BuiltinScalarFunctionEnum.java |    1 +
 .../BuiltinTimeSeriesGeneratingFunctionEnum.java   |    1 -
 .../apache/iotdb/itbase/constant/TestConstant.java |    4 +
 .../it/cluster/IoTDBClusterNodeErrorStartUpIT.java |   47 +
 .../iotdb/db/it/aggregation/IoTDBModeIT.java       |  160 +
 .../scalar/IoTDBRoundFunctionIT.java               |  327 +
 .../iotdb/libudf/it/dprofile/DProfileIT.java       |    3 +-
 library-udf/src/assembly/tools/register-UDF.bat    |    1 -
 library-udf/src/assembly/tools/register-UDF.sh     |    1 -
 .../apache/iotdb/library/dprofile/UDAFMode.java    |  178 -
 .../apache/iotdb/metrics/config/MetricConfig.java  |    7 +-
 .../iotdb/metrics/metricsets/disk/DiskMetrics.java |   30 +-
 .../resources/conf/iotdb-common.properties         |   13 +
 .../service/PipePluginClassLoaderManager.java      |    2 +-
 .../task/meta/PipeTaskMetaAccessor.java}           |   10 +-
 .../iotdb/commons/service/StartupChecks.java       |   33 +-
 .../iotdb/commons/service/metric/enums/Metric.java |    2 +
 .../udf/builtin/BuiltinAggregationFunction.java    |    5 +-
 .../commons/udf/builtin/BuiltinScalarFunction.java |    1 +
 .../BuiltinTimeSeriesGeneratingFunction.java       |    1 -
 .../commons/udf/service/UDFManagementService.java  |    2 +-
 server/src/main/codegen/dataModel/AllDataType.tdd  |   24 +-
 .../src/main/codegen/templates/ModeAccumulator.ftl |  179 +
 .../apache/iotdb/db/client/ConfigNodeClient.java   |   16 +
 .../apache/iotdb/db/conf/DataNodeStartupCheck.java |   69 +
 .../java/org/apache/iotdb/db/conf/IoTDBConfig.java |   34 +
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  |   18 +-
 .../db/consensus/DataRegionConsensusImpl.java      |    2 -
 .../db/consensus/SchemaRegionConsensusImpl.java    |    2 -
 .../statemachine/DataRegionStateMachine.java       |    3 +-
 .../org/apache/iotdb/db/constant/SqlConstant.java  |    5 +-
 .../execute/task/CrossSpaceCompactionTask.java     |    7 +-
 .../execute/task/InnerSpaceCompactionTask.java     |  264 +-
 .../readchunk/AlignedSeriesCompactionExecutor.java |    3 +-
 .../db/metadata/metric/SchemaEngineMemMetric.java  |   16 +-
 .../db/metadata/metric/SchemaRegionMemMetric.java  |   34 +
 .../db/metadata/mtree/MTreeBelowSGCachedImpl.java  |   28 +-
 .../db/metadata/mtree/MTreeBelowSGMemoryImpl.java  |   15 +-
 .../mtree/snapshot/MemMTreeSnapshotUtil.java       |   12 +-
 .../db/metadata/mtree/store/MemMTreeStore.java     |    4 +-
 .../metadata/rescon/ISchemaEngineStatistics.java   |    2 +
 .../metadata/rescon/ISchemaRegionStatistics.java   |    4 +
 .../metadata/rescon/MemSchemaEngineStatistics.java |   26 +-
 .../metadata/rescon/MemSchemaRegionStatistics.java |   36 +-
 .../schemaregion/SchemaRegionMemoryImpl.java       |    5 +
 .../schemaregion/SchemaRegionSchemaFileImpl.java   |    5 +
 .../metadata/template/ClusterTemplateManager.java  |    7 +
 .../iotdb/db/metadata/template/Template.java       |    4 +
 .../db/mpp/aggregation/AccumulatorFactory.java     |   21 +
 .../SlidingWindowAggregatorFactory.java            |    2 +
 .../iotdb/db/mpp/execution/driver/Driver.java      |   13 +-
 .../execution/exchange/MPPDataExchangeManager.java |   67 +-
 .../mpp/execution/exchange/SharedTsBlockQueue.java |    6 +-
 .../db/mpp/execution/exchange/sink/ISink.java      |    4 +
 .../mpp/execution/exchange/sink/ISinkHandle.java   |    3 +
 .../execution/exchange/sink/LocalSinkChannel.java  |    7 +
 .../execution/exchange/sink/ShuffleSinkHandle.java |   24 +-
 .../mpp/execution/exchange/sink/SinkChannel.java   |   11 +-
 .../execution/exchange/source/SourceHandle.java    |   59 +-
 .../execution/executor/RegionWriteExecutor.java    |  164 +-
 .../iotdb/db/mpp/execution/operator/Operator.java  |   10 +-
 .../process/AbstractConsumeAllOperator.java        |    4 +-
 .../operator/process/AbstractIntoOperator.java     |    7 +-
 .../operator/process/AggregationOperator.java      |    6 +-
 .../operator/process/DeviceMergeOperator.java      |    6 +-
 .../operator/process/DeviceViewOperator.java       |   17 +-
 .../execution/operator/process/FillOperator.java   |    6 +-
 .../operator/process/FilterAndProjectOperator.java |    6 +-
 .../execution/operator/process/LimitOperator.java  |    6 +-
 .../operator/process/LinearFillOperator.java       |    8 +-
 .../operator/process/MergeSortOperator.java        |    8 +-
 .../execution/operator/process/OffsetOperator.java |    6 +-
 .../process/RawDataAggregationOperator.java        |    9 +-
 .../operator/process/SingleDeviceViewOperator.java |    6 +-
 .../process/SingleInputAggregationOperator.java    |    6 +-
 .../process/SlidingWindowAggregationOperator.java  |    4 +-
 .../execution/operator/process/SortOperator.java   |    6 +-
 .../operator/process/TagAggregationOperator.java   |    8 +-
 .../operator/process/TransformOperator.java        |   16 +-
 .../process/join/HorizontallyConcatOperator.java   |    8 +-
 .../process/join/RowBasedTimeJoinOperator.java     |   11 +-
 .../operator/process/join/TimeJoinOperator.java    |    9 +-
 .../last/AbstractUpdateLastCacheOperator.java      |    4 +-
 .../last/AlignedUpdateLastCacheOperator.java       |    2 +-
 .../process/last/LastQueryCollectOperator.java     |    6 +-
 .../process/last/LastQueryMergeOperator.java       |   12 +-
 .../operator/process/last/LastQueryOperator.java   |    7 +-
 .../process/last/LastQuerySortOperator.java        |    7 +-
 .../process/last/UpdateLastCacheOperator.java      |    2 +-
 .../schema/CountGroupByLevelMergeOperator.java     |    6 +-
 .../schema/CountGroupByLevelScanOperator.java      |    6 +-
 .../operator/schema/CountMergeOperator.java        |    7 +-
 .../schema/NodeManageMemoryMergeOperator.java      |    6 +-
 .../operator/schema/NodePathsConvertOperator.java  |    6 +-
 .../operator/schema/NodePathsCountOperator.java    |    6 +-
 .../operator/schema/SchemaCountOperator.java       |    6 +-
 .../operator/schema/SchemaFetchMergeOperator.java  |    6 +-
 .../operator/schema/SchemaFetchScanOperator.java   |    6 +-
 .../operator/schema/SchemaQueryMergeOperator.java  |    6 +-
 .../schema/SchemaQueryOrderByHeatOperator.java     |    6 +-
 .../operator/schema/SchemaQueryScanOperator.java   |    6 +-
 .../operator/sink/IdentitySinkOperator.java        |   35 +-
 .../operator/sink/ShuffleHelperOperator.java       |   39 +-
 .../AbstractSeriesAggregationScanOperator.java     |    6 +-
 .../operator/source/AlignedSeriesScanOperator.java |    6 +-
 .../operator/source/ExchangeOperator.java          |    6 +-
 .../operator/source/LastCacheScanOperator.java     |    6 +-
 .../operator/source/SeriesScanOperator.java        |    6 +-
 .../operator/source/ShowQueriesOperator.java       |    6 +-
 .../plan/expression/multi/FunctionExpression.java  |    2 +-
 .../multi/builtin/BuiltInScalarFunctionHelper.java |    4 +-
 .../BuiltInScalarFunctionHelperFactory.java        |    3 +
 .../multi/builtin/helper/RoundFunctionHelper.java  |   84 +
 .../iotdb/db/mpp/plan/parser/ASTVisitor.java       |   15 +
 .../planner/distribution/DistributionPlanner.java  |   21 +
 .../metedata/write/CreateMultiTimeSeriesNode.java  |    6 +-
 .../plan/node/metedata/write/MeasurementGroup.java |   36 +-
 .../db/mpp/plan/scheduler/AsyncPlanNodeSender.java |   34 +
 .../scheduler/FragmentInstanceDispatcherImpl.java  |   32 +-
 .../db/mpp/transformation/api/YieldableReader.java |    6 +-
 .../scalar/RoundFunctionColumnTransformer.java     |   72 +
 .../transformation/dag/input/IUDFInputDataSet.java |    2 +-
 .../dag/input/QueryDataSetInputLayer.java          |    4 +-
 .../dag/input/TsBlockInputDataSet.java             |    2 +-
 .../MultiInputColumnIntermediateLayer.java         |   10 +-
 ...InputColumnMultiReferenceIntermediateLayer.java |   12 +-
 ...nputColumnSingleReferenceIntermediateLayer.java |   10 +-
 .../dag/transformer/Transformer.java               |    4 +-
 .../dag/transformer/binary/BinaryTransformer.java  |    4 +-
 .../transformer/binary/LogicBinaryTransformer.java |    2 +-
 .../multi/MappableUDFQueryRowTransformer.java      |    2 +-
 .../transformer/multi/UDFQueryRowTransformer.java  |    2 +-
 .../multi/UDFQueryRowWindowTransformer.java        |    2 +-
 .../multi/UniversalUDFQueryTransformer.java        |    4 +-
 .../transformer/ternary/TernaryTransformer.java    |    4 +-
 .../dag/transformer/unary/IsNullTransformer.java   |    2 +-
 .../dag/transformer/unary/UnaryTransformer.java    |    2 +-
 .../unary/scalar/DiffFunctionTransformer.java      |    2 +-
 .../unary/scalar/RoundFunctionTransformer.java     |   72 +
 .../db/mpp/transformation/dag/udf/UDTFContext.java |    3 +
 .../transformation/dag/util/LayerCacheUtils.java   |   10 +-
 .../org/apache/iotdb/db/pipe/agent/PipeAgent.java  |   74 +
 .../pipe/agent/{ => plugin}/PipePluginAgent.java   |   29 +-
 .../db/pipe/agent/runtime/HeartbeatScheduler.java  |   11 +-
 .../db/pipe/agent/runtime/MetaSyncScheduler.java   |   10 +-
 .../db/pipe/agent/runtime/PipeRuntimeAgent.java    |   23 +-
 .../iotdb/db/pipe/agent/task/PipeTaskAgent.java    |   23 +-
 .../db/pipe/agent/task/PipeTaskRegionAgent.java    |   10 +-
 .../collector/PipeCollectorEventPendingQueue.java  |   10 +-
 .../core/collector/PipeCollectorEventSelector.java |   10 +-
 .../historical/PipeHistoricalCollector.java        |   10 +-
 .../collector/realtime/PipeRealtimeCollector.java  |   10 +-
 .../realtime/cache/PipeRealtimeEventCache.java     |   10 +-
 .../realtime/listener/IoTLogListerner.java         |   10 +-
 .../realtime/listener/RatisLogListener.java        |   10 +-
 .../realtime/listener/SimpleLogListener.java       |   10 +-
 .../listener/TsFileGenerationListener.java         |   10 +-
 .../pipe/core/collector/realtime/matcher/Rule.java |   10 +-
 .../realtime/matcher/RulePrefixMatchTree.java      |   10 +-
 .../collector/realtime/recorder/TsFileEpoch.java   |   10 +-
 .../realtime/recorder/TsFileEpochRecorder.java     |   10 +-
 .../core/connector/PipeConnectorContainer.java     |   10 +-
 .../pipe/core/connector/PipeConnectorManager.java  |   10 +-
 .../PipeConnectorPluginRuntimeWrapper.java         |   13 +-
 .../pipe/core/event/PipeTabletInsertionEvent.java  |   26 +-
 .../pipe/core/event/PipeTsFileInsertionEvent.java  |   16 +-
 .../iotdb/db/pipe/core/event/access/PipeRow.java   |  102 +
 .../core/event/access/PipeRowIterator.java}        |   39 +-
 .../core/event/collector/PipeEventCollector.java}  |   18 +-
 .../core/event/collector/PipeRowCollector.java}    |   10 +-
 .../pipe/core/event/indexer/PipeEventIndexer.java  |   10 +-
 .../core/event/indexer/PipeIoTEventIndexer.java    |   10 +-
 .../core/event/indexer/PipeRatisEventIndexer.java  |   10 +-
 .../core/event/indexer/PipeSimpleEventIndexer.java |   10 +-
 .../core/event/indexer/PipeTsFileEventIndexer.java |   10 +-
 .../PipeProcessorPluginRuntimeWrapper.java         |   13 +-
 .../executor/PipeAssignerSubtaskExecutor.java      |   10 +-
 .../executor/PipeConnectorSubtaskExecutor.java     |   10 +-
 .../executor/PipeProcessorSubtaskExecutor.java     |   10 +-
 .../execution/executor/PipeSubtaskExecutor.java    |   10 +-
 .../pipe/execution/executor/PipeTaskExecutor.java  |   49 +
 .../scheduler/PipeAssignerSubtaskScheduler.java    |   18 +-
 .../scheduler/PipeConnectorSubtaskScheduler.java   |   18 +-
 .../scheduler/PipeProcessorSubtaskScheduler.java   |   18 +-
 .../execution/scheduler/PipeSubtaskScheduler.java} |   14 +-
 .../execution/scheduler/PipeTaskScheduler.java     |   60 +
 .../iotdb/db/pipe/resource/PipeFileManager.java    |   10 +-
 .../iotdb/db/pipe/resource/PipeRaftlogHolder.java  |   10 +-
 .../iotdb/db/pipe/resource/PipeTsFileHolder.java   |   10 +-
 .../iotdb/db/pipe/resource/PipeWALHolder.java      |   10 +-
 .../task/PipeTask.java}                            |   30 +-
 .../apache/iotdb/db/pipe/task/PipeTaskBuilder.java |   11 +-
 .../pipe/task/metrics/PipeTaskRuntimeRecorder.java |   10 +-
 .../db/pipe/task/runnable/PipeAssignerSubtask.java |   12 +-
 .../pipe/task/runnable/PipeConnectorSubtask.java   |   12 +-
 .../pipe/task/runnable/PipeProcessorSubtask.java   |   12 +-
 .../iotdb/db/pipe/task/runnable/PipeSubtask.java   |   21 +-
 .../db/pipe/task/stage/PipeTaskCollectorStage.java |   19 +-
 .../db/pipe/task/stage/PipeTaskConnectorStage.java |   19 +-
 .../db/pipe/task/stage/PipeTaskProcessorStage.java |   19 +-
 .../task/stage/PipeTaskStage.java}                 |   37 +-
 .../java/org/apache/iotdb/db/service/DataNode.java |  154 +-
 .../db/service/ResourcesInformationHolder.java     |   12 +
 .../metrics/IoTDBInternalLocalReporter.java        |   37 +
 .../impl/DataNodeInternalRPCServiceImpl.java       |    6 +-
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |    2 +
 .../apache/iotdb/db/utils/TypeInferenceUtils.java  |    3 +
 .../schemaRegion/SchemaStatisticsTest.java         |   86 +
 .../iotdb/db/mpp/execution/exchange/StubSink.java  |    5 +
 .../operator/AggregationOperatorTest.java          |   26 +-
 .../AlignedSeriesAggregationScanOperatorTest.java  |   38 +-
 .../operator/AlignedSeriesScanOperatorTest.java    |    6 +-
 .../operator/DeviceMergeOperatorTest.java          |  565 --
 .../execution/operator/DeviceViewOperatorTest.java |    3 +-
 .../mpp/execution/operator/FillOperatorTest.java   |   16 +-
 .../operator/HorizontallyConcatOperatorTest.java   |    2 +-
 .../operator/LastQueryMergeOperatorTest.java       |   38 +-
 .../execution/operator/LastQueryOperatorTest.java  |    4 +-
 .../operator/LastQuerySortOperatorTest.java        |    5 +-
 .../mpp/execution/operator/LimitOperatorTest.java  |    2 +-
 .../execution/operator/LinearFillOperatorTest.java |   56 +-
 .../execution/operator/MergeSortOperatorTest.java  |   38 +-
 .../mpp/execution/operator/OffsetOperatorTest.java |    6 +-
 .../operator/RawDataAggregationOperatorTest.java   |   54 +-
 .../SeriesAggregationScanOperatorTest.java         |   65 +-
 .../execution/operator/SeriesScanOperatorTest.java |    2 +-
 .../operator/SingleDeviceViewOperatorTest.java     |    3 +-
 .../SlidingWindowAggregationOperatorTest.java      |    3 +-
 .../execution/operator/TimeJoinOperatorTest.java   |    6 +-
 .../operator/UpdateLastCacheOperatorTest.java      |    6 +-
 .../operator/schema/SchemaCountOperatorTest.java   |    4 +-
 .../schema/SchemaQueryScanOperatorTest.java        |    4 +-
 .../datanode1conf/iotdb-common.properties          |    3 +-
 .../datanode2conf/iotdb-common.properties          |    3 +-
 .../datanode3conf/iotdb-common.properties          |    3 +-
 site/src/main/.vuepress/styles/config.scss         |    1 +
 thrift-commons/src/main/thrift/common.thrift       |    3 +-
 .../src/main/thrift/confignode.thrift              |    6 +
 thrift/src/main/thrift/datanode.thrift             |   12 +-
 .../iotdb/tsfile/utils/ReadWriteIOUtils.java       |    7 +
 298 files changed, 11274 insertions(+), 7512 deletions(-)