You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by ha...@apache.org on 2021/07/29 01:42:33 UTC

[iotdb] branch mqtt_example updated (58fa267 -> 9fe4f6f)

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

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


    from 58fa267  ignore apache rat header
     add 25f7f55  [IOTDB-1506] CI fails because of JDBC connection exceptions (#3577)
     add 56ea509  Optimize the implementation of singleton (#3585)
     add df46873  add checkDeviceIdExist method to ITimeIndex (#3562)
     add 2797007  [IOTDB-1459] Unify integration test class names (#3588)
     add 2bff46a  [IOTDB-1492] Fix mLogParser.sh cannot parse the device template (#3573)
     add ed6d848  Add Google Analytics (#3592)
     add 31bf7e9  Wordings improvement of website nav bar (#3591)
     add af567ee  [IOTDB-1456] Fix Error occurred while executing delete timeseries statement (#3474)
     add 534bb93  Update Google Analytics tag id (#3594)
     add 7a09ecb  Add privacy disclosure (#3597)
     add 9ecb7a0  [IOTDB-1491] UDTF query supported in cluster mode (#3565)
     add 18e5ff7  add SessionConcurrentExample & fix template restart PathNotExistException (#3595)
     add 79e50d6  fix recover TsFileResource time interval bug (#3604)
     add c8edbcf  improve mlog compatibility from 0.12.2 to 0.13.0 (#3553)
     add 6e9f340  [IOTDB-1059] Support sql statement insert without timestamp (#3067)
     add 5a348a4  [IOTDB-1478]The whole IoTDB can not read/write if any one sg is not ready (#3554)
     add 3c6925c  [IOTDB-959]Add createStorageGroup Grammar (#3608)
     add 0791e07  mod note (#3615)
     add 72799f3  [IOTDB-1503] 1 node crash causes whole cluster cannot work (#3579)
     add 469f78b  Remove path registration in IoTDBSink (#3620)
     add 511d5f4  Update ContributeGuide.md (#3611)
     add 2ba8c78  [IOTDB-1509] show timeseries throw a bug (#3556)
     add e0ce236  remove unnecessary testcontainer IT (#3625)
     add c05a7c5  [IOTDB-1528] CQ IT unstable: sometimes fails on checkCQExecutionResult() (#3624)
     add 4fcd755  [IOTDB-1500] Remove current dynamic query memory control (#3563)
     add 9437339  Fix compile error in assignQueryId (#3629)
     add 47fa594  [IoTDB-1499] Remove series registeration using IoTDBSink -> master (#3574)
     add d984fe8  [IOTDB-1496] Timed flush memtable (#3610)
     add de1a622  [IOTDB-1524] Support SELECT ... INTO ... clause (#3614)
     add 716710c  [IOTDB-1519]add metadata checking option and change grammar for loading tsfile (#3576)
     add 95e3b69  [IOTDB-1529]Fix mlog recover idx bug and synchronize setStorageGroup (#3635)
     add d1729ea  [IOTDB-1530] Make documents style better by adding a space between full-corner and half-corner characters (#3632)
     add 1d0b6ff  [IOTDB-1477] Optimize code logic of generateAlignByDevicePlan() (#3607)
     add 0b2d0af  make sure memtable flush task has submitted before check (#3641)
     add 9fe4f6f  Merge branch 'master' into mqtt_example

No new revisions were added by this update.

Summary of changes:
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4   |  73 ++-
 .../iotdb/cluster/log/applier/BaseApplier.java     |  17 +-
 .../apache/iotdb/cluster/metadata/CMManager.java   | 151 ++----
 .../apache/iotdb/cluster/metadata/MetaPuller.java  |  27 +-
 .../cluster/query/ClusterPhysicalGenerator.java    |  18 +-
 .../iotdb/cluster/query/ClusterPlanExecutor.java   |  40 +-
 .../apache/iotdb/cluster/query/ClusterPlanner.java |  17 +-
 .../iotdb/cluster/query/ClusterQueryRouter.java    |  40 ++
 .../cluster/query/ClusterUDTFQueryExecutor.java    |  12 +-
 .../iotdb/cluster/query/LocalQueryExecutor.java    |  32 +-
 .../cluster/query/aggregate/ClusterAggregator.java |   9 +-
 .../cluster/query/fill/ClusterPreviousFill.java    |  10 +-
 .../query/groupby/RemoteGroupByExecutor.java       |  27 +-
 .../query/last/ClusterLastQueryExecutor.java       |  26 +-
 .../cluster/query/manage/ClusterQueryManager.java  |   8 +-
 .../cluster/query/reader/ClusterReaderFactory.java |   9 +-
 .../cluster/query/reader/ClusterTimeGenerator.java |  14 +-
 .../iotdb/cluster/query/reader/DataSourceInfo.java |  28 +-
 .../reader/RemoteSeriesReaderByTimestamp.java      |   3 +
 .../query/reader/RemoteSimpleSeriesReader.java     |   3 +
 .../query/reader/mult/MultDataSourceInfo.java      |   8 +-
 .../query/reader/mult/RemoteMultSeriesReader.java  |  10 +-
 .../apache/iotdb/cluster/server/ClientServer.java  |  44 +-
 .../cluster/server/heartbeat/HeartbeatThread.java  |   6 +
 .../cluster/server/member/MetaGroupMember.java     |   3 +-
 .../org/apache/iotdb/cluster/common/IoTDBTest.java |   3 +-
 .../cluster/log/snapshot/FileSnapshotTest.java     |   2 +-
 .../query/ClusterAggregateExecutorTest.java        |   4 +-
 .../query/ClusterDataQueryExecutorTest.java        |  10 +-
 .../cluster/query/ClusterFillExecutorTest.java     |   4 +-
 .../query/ClusterPhysicalGeneratorTest.java        |   3 +-
 .../cluster/query/ClusterPlanExecutorTest.java     |   4 +-
 .../cluster/query/ClusterQueryRouterTest.java      |  44 +-
 .../query/ClusterUDTFQueryExecutorTest.java        | 116 +++++
 .../iotdb/cluster/query/LoadConfigurationTest.java |   2 +-
 .../ClusterGroupByNoVFilterDataSetTest.java        |   2 +-
 .../groupby/ClusterGroupByVFilterDataSetTest.java  |   2 +-
 .../query/groupby/MergeGroupByExecutorTest.java    |   4 +-
 .../query/groupby/RemoteGroupByExecutorTest.java   |   4 +-
 .../query/manage/ClusterQueryManagerTest.java      |  12 +-
 .../query/reader/ClusterReaderFactoryTest.java     |   2 +-
 .../query/reader/ClusterTimeGeneratorTest.java     |   4 +-
 .../cluster/server/member/DataGroupMemberTest.java |   2 +-
 .../cluster/server/member/MetaGroupMemberTest.java |   4 +-
 docs/Development/ContributeGuide.md                |  37 +-
 docs/SystemDesign/SchemaManager/SchemaManager.md   |  37 +-
 docs/UserGuide/Advanced-Features/Select-Into.md    | 235 +++++++++
 .../UserGuide/Ecosystem Integration/Flink IoTDB.md |   3 +-
 .../DDL-Data-Definition-Language.md                |   6 +-
 .../UserGuide/System-Tools/Load-External-Tsfile.md |  32 +-
 docs/zh/Community/Community-Powered By.md          |  41 +-
 docs/zh/Community/Feedback.md                      |  18 +-
 docs/zh/Development/Committer.md                   |  38 +-
 docs/zh/Development/ContributeGuide.md             |  59 +--
 docs/zh/Development/HowToCommit.md                 |  40 +-
 docs/zh/Development/VoteRelease.md                 |   7 +-
 docs/zh/Download/README.md                         |  73 ++-
 docs/zh/SystemDesign/Architecture/Architecture.md  |   1 -
 docs/zh/SystemDesign/Client/RPC.md                 |   3 -
 docs/zh/SystemDesign/Connector/Hive-TsFile.md      |  11 +-
 docs/zh/SystemDesign/Connector/Spark-IOTDB.md      |  39 +-
 docs/zh/SystemDesign/Connector/Spark-TsFile.md     |  25 +-
 docs/zh/SystemDesign/DataQuery/AggregationQuery.md |  31 +-
 .../SystemDesign/DataQuery/AlignByDeviceQuery.md   |  12 +-
 docs/zh/SystemDesign/DataQuery/FillFunction.md     |  30 +-
 docs/zh/SystemDesign/DataQuery/GroupByFillQuery.md |  37 +-
 docs/zh/SystemDesign/DataQuery/GroupByQuery.md     |  48 +-
 docs/zh/SystemDesign/DataQuery/LastQuery.md        |  22 +-
 docs/zh/SystemDesign/DataQuery/OrderByTimeQuery.md |  75 ++-
 .../zh/SystemDesign/DataQuery/QueryFundamentals.md |  58 +--
 docs/zh/SystemDesign/DataQuery/RawDataQuery.md     |  62 ++-
 docs/zh/SystemDesign/DataQuery/SeriesReader.md     |  24 +-
 docs/zh/SystemDesign/QueryEngine/Planner.md        |   1 -
 .../QueryEngine/ResultSetConstruction.md           |   2 +-
 .../zh/SystemDesign/SchemaManager/SchemaManager.md | 188 ++++---
 docs/zh/SystemDesign/StorageEngine/Compaction.md   |  40 +-
 .../SystemDesign/StorageEngine/DataManipulation.md |  41 +-
 .../zh/SystemDesign/StorageEngine/DataPartition.md |  24 +-
 docs/zh/SystemDesign/StorageEngine/FileLists.md    |  39 +-
 docs/zh/SystemDesign/StorageEngine/FlushManager.md |   4 +-
 docs/zh/SystemDesign/StorageEngine/MergeManager.md |  22 +-
 docs/zh/SystemDesign/StorageEngine/Recover.md      |  29 +-
 .../zh/SystemDesign/StorageEngine/StorageEngine.md |   2 +-
 docs/zh/SystemDesign/StorageEngine/WAL.md          |   4 +-
 docs/zh/SystemDesign/Tools/Sync.md                 | 105 ++--
 docs/zh/SystemDesign/TsFile/Format.md              | 140 +++--
 docs/zh/SystemDesign/TsFile/Read.md                | 110 ++--
 docs/zh/SystemDesign/TsFile/TsFile.md              |   1 -
 docs/zh/SystemDesign/TsFile/Write.md               |   3 +-
 .../zh/UserGuide/API/Programming-Cpp-Native-API.md |  87 ++--
 docs/zh/UserGuide/API/Programming-Go-Native-API.md |  18 +-
 docs/zh/UserGuide/API/Programming-JDBC.md          |  14 +-
 .../UserGuide/API/Programming-Java-Native-API.md   |  59 +--
 .../UserGuide/API/Programming-Python-Native-API.md |  70 +--
 docs/zh/UserGuide/API/Programming-TsFile-API.md    | 137 +++--
 docs/zh/UserGuide/API/Time-zone.md                 |   1 -
 .../Administration-Management/Administration.md    |  35 +-
 docs/zh/UserGuide/Advanced-Features/Alerting.md    |  15 +-
 .../Advanced-Features/Continuous-Query.md          |  17 +-
 docs/zh/UserGuide/Advanced-Features/Select-Into.md | 234 +++++++++
 docs/zh/UserGuide/Advanced-Features/Triggers.md    | 170 ++-----
 .../Advanced-Features/UDF-User-Defined-Function.md | 225 +++-----
 docs/zh/UserGuide/Appendix/Config-Manual.md        | 139 +++--
 docs/zh/UserGuide/Appendix/SQL-Reference.md        | 160 +++---
 docs/zh/UserGuide/Appendix/Status-Codes.md         |  19 +-
 docs/zh/UserGuide/CLI/Command-Line-Interface.md    | 123 +++--
 docs/zh/UserGuide/Cluster/Cluster-Setup-Example.md |  12 +-
 docs/zh/UserGuide/Cluster/Cluster-Setup.md         |  67 ++-
 .../Collaboration-of-Edge-and-Cloud/Sync-Tool.md   |  40 +-
 .../Programming-MQTT.md                            |  63 ++-
 .../Programming-Thrift.md                          |  30 +-
 docs/zh/UserGuide/Comparison/TSDB-Comparison.md    | 201 +++-----
 docs/zh/UserGuide/Data-Concept/Compression.md      |  12 +-
 .../Data-Concept/Data-Model-and-Terminology.md     |  59 ++-
 docs/zh/UserGuide/Data-Concept/Data-Type.md        |   4 +-
 docs/zh/UserGuide/Data-Concept/Encoding.md         |  22 +-
 docs/zh/UserGuide/Data-Concept/SDT.md              |  30 +-
 docs/zh/UserGuide/Ecosystem Integration/DBeaver.md |  20 +-
 .../UserGuide/Ecosystem Integration/Flink IoTDB.md |   5 +-
 .../Ecosystem Integration/Flink TsFile.md          |  17 +-
 docs/zh/UserGuide/Ecosystem Integration/Grafana.md |  72 ++-
 .../UserGuide/Ecosystem Integration/Hive TsFile.md |  55 +-
 .../Ecosystem Integration/MapReduce TsFile.md      |  39 +-
 .../UserGuide/Ecosystem Integration/Spark IoTDB.md |  17 +-
 .../Ecosystem Integration/Spark TsFile.md          |  88 ++--
 .../Ecosystem Integration/Writing Data on HDFS.md  |  46 +-
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  51 +-
 .../zh/UserGuide/FAQ/Frequently-asked-questions.md |  33 +-
 .../UserGuide/IoTDB-Introduction/Architecture.md   |  14 +-
 docs/zh/UserGuide/IoTDB-Introduction/Features.md   |   8 +-
 .../zh/UserGuide/IoTDB-Introduction/Publication.md |   2 +-
 docs/zh/UserGuide/IoTDB-Introduction/Scenario.md   |  20 +-
 .../UserGuide/IoTDB-Introduction/What-is-IoTDB.md  |   4 +-
 .../DDL-Data-Definition-Language.md                |  72 ++-
 .../DML-Data-Manipulation-Language.md              | 364 +++++++------
 .../IoTDB-SQL-Language/Maintenance-Command.md      |  10 +-
 docs/zh/UserGuide/QuickStart/Files.md              |  17 +-
 docs/zh/UserGuide/QuickStart/QuickStart.md         |  78 ++-
 docs/zh/UserGuide/QuickStart/ServerFileList.md     |  64 +--
 docs/zh/UserGuide/QuickStart/WayToGetIoTDB.md      |  43 +-
 docs/zh/UserGuide/System-Tools/CSV-Tool.md         |  24 +-
 docs/zh/UserGuide/System-Tools/JMX-Tool.md         |  24 +-
 .../UserGuide/System-Tools/Load-External-Tsfile.md |  58 ++-
 docs/zh/UserGuide/System-Tools/MLogParser-Tool.md  |   7 +-
 .../System-Tools/Monitor-and-Log-Tools.md          |  96 ++--
 docs/zh/UserGuide/System-Tools/NodeTool.md         | 117 +++--
 .../Query-History-Visualization-Tool.md            |   6 +-
 docs/zh/UserGuide/System-Tools/Watermark-Tool.md   |  34 +-
 docs/zh/UserGuide/UserGuideReadme.md               |   9 +-
 .../org/apache/iotdb/flink/FlinkIoTDBSink.java     |  26 +-
 .../org/apache/iotdb/SessionConcurrentExample.java | 199 ++++++++
 .../main/java/org/apache/iotdb/SessionExample.java |  14 +
 .../java/org/apache/iotdb/flink/IoTDBSink.java     |  26 +-
 .../iotdb/flink/options/IoTDBSinkOptions.java      |  11 -
 ...tITCase.java => RowTSRecordOutputFormatIT.java} |   2 +-
 ...rmatITCase.java => RowTsFileInputFormatIT.java} |   2 +-
 .../resources/conf/iotdb-engine.properties         |  24 +
 .../org/apache/iotdb/db/auth/AuthorityChecker.java |   1 +
 .../java/org/apache/iotdb/db/conf/IoTDBConfig.java |  50 ++
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  |  43 +-
 .../apache/iotdb/db/cq/ContinuousQueryTask.java    |   6 +-
 .../org/apache/iotdb/db/engine/StorageEngine.java  | 167 +++---
 .../level/LevelCompactionTsFileManagement.java     |   2 +-
 .../iotdb/db/engine/memtable/AbstractMemTable.java |   7 +
 .../apache/iotdb/db/engine/memtable/IMemTable.java |   2 +
 .../selectinto/InsertTabletPlanGenerator.java      | 229 +++++++++
 .../selectinto/InsertTabletPlansIterator.java      | 139 +++++
 .../engine/storagegroup/StorageGroupProcessor.java | 172 ++++---
 .../db/engine/storagegroup/TsFileProcessor.java    |  10 +-
 .../db/engine/storagegroup/TsFileResource.java     |  10 +-
 .../storagegroup/timeindex/DeviceTimeIndex.java    |  13 +-
 .../storagegroup/timeindex/FileTimeIndex.java      |   5 +
 .../engine/storagegroup/timeindex/ITimeIndex.java  |   8 +
 .../storagegroup/timeindex/TimeIndexLevel.java     |  10 -
 .../virtualSg/VirtualStorageGroupManager.java      | 106 ++--
 .../exception/query/PathNumOverLimitException.java |  13 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  30 +-
 .../java/org/apache/iotdb/db/metadata/MTree.java   |  25 +-
 .../iotdb/db/metadata/MetadataOperationType.java   |   4 +
 .../db/metadata/{ => logfile}/MLogTxtWriter.java   |  71 ++-
 .../db/metadata/{ => logfile}/TagLogFile.java      |   2 +-
 .../org/apache/iotdb/db/monitor/StatMonitor.java   |   2 +-
 .../main/java/org/apache/iotdb/db/qp/Planner.java  |  51 +-
 .../apache/iotdb/db/qp/constant/SQLConstant.java   |   4 +
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  |  36 ++
 .../org/apache/iotdb/db/qp/logical/Operator.java   |   2 +
 .../iotdb/db/qp/logical/crud/QueryOperator.java    | 185 +++----
 .../db/qp/logical/crud/SelectIntoOperator.java     | 110 ++++
 .../iotdb/db/qp/logical/sys/LoadFilesOperator.java |  25 +-
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |  22 +-
 .../db/qp/physical/crud/AlignByDevicePlan.java     |  57 +--
 .../iotdb/db/qp/physical/crud/MeasurementInfo.java |  75 +++
 .../iotdb/db/qp/physical/crud/SelectIntoPlan.java  | 113 +++++
 .../iotdb/db/qp/physical/sys/OperateFilePlan.java  |  23 +-
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    | 191 ++++---
 .../iotdb/db/qp/strategy/LogicalChecker.java       |   5 +
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |  24 +-
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |   8 +-
 .../qp/strategy/optimizer/ILogicalOptimizer.java   |   3 +-
 .../apache/iotdb/db/qp/utils/WildcardsRemover.java |  28 +-
 .../db/query/control/QueryResourceManager.java     |  48 +-
 .../iotdb/db/query/control/QueryTimeManager.java   |  14 +
 .../iotdb/db/query/control/SessionManager.java     |  10 +-
 .../db/query/dataset/AlignByDeviceDataSet.java     |  20 +-
 .../apache/iotdb/db/rescon/MemTableManager.java    |   4 +
 .../apache/iotdb/db/rescon/TVListAllocator.java    |  12 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java | 309 +++++------
 .../org/apache/iotdb/db/service/UpgradeSevice.java |   9 +-
 .../org/apache/iotdb/db/tools/mlog/MLogParser.java |  19 +-
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |  18 -
 .../writelog/recover/TsFileRecoverPerformer.java   |  26 +-
 .../storagegroup/StorageGroupProcessorTest.java    |  75 ++-
 .../engine/storagegroup/TsFileProcessorTest.java   |  14 +-
 .../iotdb/db/integration/IoTDBAlignByDeviceIT.java |   3 +-
 .../org/apache/iotdb/db/integration/IoTDBAsIT.java |   2 +-
 .../db/integration/IoTDBContinuousQueryIT.java     | 147 +++---
 .../db/integration/IoTDBCreateStorageGroupIT.java  | 128 +++++
 ...ltiRowIT.java => IoTDBInsertWithoutTimeIT.java} |  52 +-
 .../db/integration/IoTDBLoadExternalTsfileIT.java  | 121 ++++-
 .../db/integration/IoTDBQueryMemoryControlIT.java  |  20 +-
 .../iotdb/db/integration/IoTDBRestartIT.java       |  48 ++
 .../iotdb/db/integration/IoTDBSelectIntoIT.java    | 564 +++++++++++++++++++++
 .../db/integration/IoTDBSequenceDataQueryIT.java   |  12 +-
 .../iotdb/db/integration/IoTDBSeriesReaderIT.java  |  11 +-
 .../db/integration/IoTDBTriggerExecutionIT.java    |  43 +-
 .../iotdb/db/qp/logical/LogicalPlanSmallTest.java  |   2 +-
 .../iotdb/db/qp/physical/PhysicalPlanTest.java     |  83 +--
 .../org/apache/iotdb/db/tools/MLogParserTest.java  |  71 ++-
 .../apache/iotdb/db/utils/EnvironmentUtils.java    |  11 +-
 .../iotdb/db/utils/TsFileRewriteToolTest.java      |   4 +-
 site/README.md                                     |   2 +-
 site/src/main/.vuepress/config.js                  |  31 +-
 site/src/main/.vuepress/theme/components/Page.vue  |  15 +-
 .../apache/iotdb/spark/db/EnvironmentUtils.java    | 111 ++--
 .../test/java/org/apache/iotdb/db/sql/Cases.java   | 178 +++----
 .../java/org/apache/iotdb/tsfile/utils/BitMap.java |   5 +
 236 files changed, 6643 insertions(+), 4291 deletions(-)
 copy server/src/main/java/org/apache/iotdb/db/query/executor/UDTFQueryExecutor.java => cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterUDTFQueryExecutor.java (91%)
 create mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterUDTFQueryExecutorTest.java
 create mode 100644 docs/UserGuide/Advanced-Features/Select-Into.md
 create mode 100644 docs/zh/UserGuide/Advanced-Features/Select-Into.md
 create mode 100644 example/session/src/main/java/org/apache/iotdb/SessionConcurrentExample.java
 rename flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/{RowTSRecordOutputFormatITCase.java => RowTSRecordOutputFormatIT.java} (95%)
 rename flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/{RowTsFileInputFormatITCase.java => RowTsFileInputFormatIT.java} (97%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/engine/selectinto/InsertTabletPlanGenerator.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/engine/selectinto/InsertTabletPlansIterator.java
 rename server/src/main/java/org/apache/iotdb/db/metadata/{ => logfile}/MLogTxtWriter.java (80%)
 rename server/src/main/java/org/apache/iotdb/db/metadata/{ => logfile}/TagLogFile.java (99%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/SelectIntoOperator.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/MeasurementInfo.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/SelectIntoPlan.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCreateStorageGroupIT.java
 copy server/src/test/java/org/apache/iotdb/db/integration/{IoTDBInsertMultiRowIT.java => IoTDBInsertWithoutTimeIT.java} (69%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSelectIntoIT.java