You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by yu...@apache.org on 2022/03/15 16:34:06 UTC

[iotdb] branch research/separation updated (b5d3ba2 -> f70fdcb)

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

yuyuankang pushed a change to branch research/separation
in repository https://gitbox.apache.org/repos/asf/iotdb.git.


    from b5d3ba2  version
     new ba3dff9  spotless
     new f70fdcb  clear

The 2 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 Jenkinsfile                                        |  210 --
 LICENSE                                            |  236 --
 LICENSE-binary                                     |  306 --
 NOTICE                                             |   24 -
 NOTICE-binary                                      |   24 -
 README.md                                          |   35 -
 README_ZH.md                                       |  374 ---
 RELEASE_NOTES.md                                   |  721 -----
 antlr/pom.xml                                      |   78 -
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4   | 1537 ----------
 asf.header                                         |   16 -
 checkstyle.xml                                     |  230 --
 cli/pom.xml                                        |  165 --
 cli/src/assembly/cli.xml                           |   40 -
 cli/src/assembly/resources/sbin/start-cli.bat      |   74 -
 cli/src/assembly/resources/sbin/start-cli.sh       |   81 -
 cli/src/assembly/resources/tools/export-csv.bat    |   56 -
 cli/src/assembly/resources/tools/export-csv.sh     |   53 -
 cli/src/assembly/resources/tools/import-csv.bat    |   57 -
 cli/src/assembly/resources/tools/import-csv.sh     |   53 -
 .../java/org/apache/iotdb/cli/AbstractCli.java     |  679 -----
 cli/src/main/java/org/apache/iotdb/cli/Cli.java    |  171 --
 cli/src/main/java/org/apache/iotdb/cli/WinCli.java |  178 --
 .../org/apache/iotdb/cli/utils/IoTPrinter.java     |  106 -
 .../apache/iotdb/exception/ArgsErrorException.java |   28 -
 .../org/apache/iotdb/tool/AbstractCsvTool.java     |  191 --
 .../main/java/org/apache/iotdb/tool/ExportCsv.java |  372 ---
 .../main/java/org/apache/iotdb/tool/ImportCsv.java |  458 ---
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |  234 --
 .../java/org/apache/iotdb/cli/AbstractScript.java  |   87 -
 .../org/apache/iotdb/cli/StartClientScriptIT.java  |  112 -
 .../org/apache/iotdb/tool/CsvLineSplitTest.java    |   33 -
 .../org/apache/iotdb/tool/ExportCsvTestIT.java     |  102 -
 .../org/apache/iotdb/tool/ImportCsvTestIT.java     |  102 -
 cli/src/test/resources/logback.xml                 |  122 -
 client-cpp/README.md                               |   63 -
 client-cpp/pom.xml                                 |  388 ---
 client-cpp/src/assembly/client-cpp.xml             |   61 -
 client-cpp/src/main/Session.cpp                    | 1168 --------
 client-cpp/src/main/Session.h                      |  669 -----
 client-cpp/src/test/cpp/sessionIT.cpp              |  294 --
 client-cpp/src/test/main.cpp                       |   40 -
 client-py/.flake8                                  |   33 -
 client-py/.gitignore                               |    5 -
 client-py/README.md                                |  209 --
 client-py/SessionExample.py                        |  177 --
 client-py/SessionTest.py                           |  243 --
 client-py/iotdb/IoTDBContainer.py                  |   51 -
 client-py/iotdb/Session.py                         |  756 -----
 client-py/iotdb/__init__.py                        |   17 -
 client-py/iotdb/utils/Field.py                     |  177 --
 client-py/iotdb/utils/IoTDBConstants.py            |   54 -
 client-py/iotdb/utils/IoTDBRpcDataSet.py           |  271 --
 client-py/iotdb/utils/RowRecord.py                 |   55 -
 client-py/iotdb/utils/SessionDataSet.py            |  181 --
 client-py/iotdb/utils/Tablet.py                    |  131 -
 client-py/iotdb/utils/__init__.py                  |   17 -
 client-py/pom.xml                                  |  123 -
 client-py/pyproject.toml                           |   45 -
 client-py/release.sh                               |   37 -
 client-py/setup.py                                 |   57 -
 client-py/tests/__init__.py                        |   17 -
 client-py/tests/test_dataframe.py                  |   41 -
 cluster/pom.xml                                    |  237 --
 cluster/src/assembly/cluster.xml                   |   31 -
 .../resources/conf/iotdb-cluster.properties        |  173 --
 cluster/src/assembly/resources/sbin/add-node.bat   |  108 -
 cluster/src/assembly/resources/sbin/add-node.sh    |   76 -
 cluster/src/assembly/resources/sbin/nodetool.bat   |   58 -
 cluster/src/assembly/resources/sbin/nodetool.sh    |   48 -
 cluster/src/assembly/resources/sbin/start-node.bat |  133 -
 cluster/src/assembly/resources/sbin/start-node.sh  |   97 -
 cluster/src/assembly/resources/sbin/stop-node.bat  |   27 -
 cluster/src/assembly/resources/sbin/stop-node.sh   |   39 -
 .../java/org/apache/iotdb/cluster/ClientMain.java  |  469 ---
 .../iotdb/cluster/ClusterFileFlushPolicy.java      |   78 -
 .../java/org/apache/iotdb/cluster/ClusterMain.java |  302 --
 .../apache/iotdb/cluster/RemoteTsFileResource.java |  149 -
 .../iotdb/cluster/client/DataClientProvider.java   |   95 -
 .../cluster/client/async/AsyncClientFactory.java   |   65 -
 .../cluster/client/async/AsyncClientPool.java      |  216 --
 .../cluster/client/async/AsyncDataClient.java      |  161 --
 .../client/async/AsyncDataHeartbeatClient.java     |   81 -
 .../cluster/client/async/AsyncMetaClient.java      |  135 -
 .../client/async/AsyncMetaHeartbeatClient.java     |   81 -
 .../cluster/client/sync/SyncClientAdaptor.java     |  516 ----
 .../cluster/client/sync/SyncClientFactory.java     |   40 -
 .../iotdb/cluster/client/sync/SyncClientPool.java  |  169 --
 .../iotdb/cluster/client/sync/SyncDataClient.java  |  116 -
 .../client/sync/SyncDataHeartbeatClient.java       |   77 -
 .../iotdb/cluster/client/sync/SyncMetaClient.java  |   99 -
 .../client/sync/SyncMetaHeartbeatClient.java       |   77 -
 .../apache/iotdb/cluster/config/ClusterConfig.java |  470 ---
 .../iotdb/cluster/config/ClusterConstant.java      |   66 -
 .../iotdb/cluster/config/ClusterDescriptor.java    |  386 ---
 .../iotdb/cluster/config/ConsistencyLevel.java     |   67 -
 .../iotdb/cluster/coordinator/Coordinator.java     |  691 -----
 .../iotdb/cluster/exception/AddSelfException.java  |   28 -
 .../exception/BadSeedUrlFormatException.java       |   30 -
 .../exception/CheckConsistencyException.java       |   37 -
 .../exception/ConfigInconsistentException.java     |   29 -
 .../cluster/exception/EmptyIntervalException.java  |   28 -
 .../cluster/exception/EntryCompactedException.java |   30 -
 .../exception/EntryUnavailableException.java       |   28 -
 .../GetEntriesWrongParametersException.java        |   27 -
 .../cluster/exception/LeaderUnknownException.java  |   31 -
 .../cluster/exception/LogExecutionException.java   |   27 -
 .../cluster/exception/MemberReadOnlyException.java |   33 -
 .../cluster/exception/NoHeaderNodeException.java   |   31 -
 .../cluster/exception/NotInSameGroupException.java |   32 -
 .../cluster/exception/NotManagedSlotException.java |   33 -
 .../PartitionTableUnavailableException.java        |   30 -
 .../iotdb/cluster/exception/PullFileException.java |   34 -
 .../cluster/exception/QueryTimeOutException.java   |   27 -
 .../cluster/exception/ReaderNotFoundException.java |   27 -
 .../cluster/exception/RequestTimeOutException.java |   34 -
 .../exception/SnapshotInstallationException.java   |   37 -
 .../exception/StartUpCheckFailureException.java    |   31 -
 .../exception/TruncateCommittedEntryException.java |   30 -
 .../cluster/exception/UnknownLogTypeException.java |   28 -
 .../exception/UnsupportedPlanException.java        |   29 -
 .../iotdb/cluster/log/CommitLogCallback.java       |   48 -
 .../apache/iotdb/cluster/log/CommitLogTask.java    |   65 -
 .../org/apache/iotdb/cluster/log/HardState.java    |  114 -
 .../java/org/apache/iotdb/cluster/log/Log.java     |  145 -
 .../org/apache/iotdb/cluster/log/LogApplier.java   |   35 -
 .../apache/iotdb/cluster/log/LogDispatcher.java    |  457 ---
 .../org/apache/iotdb/cluster/log/LogParser.java    |  100 -
 .../org/apache/iotdb/cluster/log/Snapshot.java     |   70 -
 .../iotdb/cluster/log/StableEntryManager.java      |   55 -
 .../cluster/log/applier/AsyncDataLogApplier.java   |  302 --
 .../iotdb/cluster/log/applier/BaseApplier.java     |  187 --
 .../iotdb/cluster/log/applier/DataLogApplier.java  |  139 -
 .../iotdb/cluster/log/applier/MetaLogApplier.java  |   69 -
 .../iotdb/cluster/log/catchup/CatchUpTask.java     |  400 ---
 .../iotdb/cluster/log/catchup/LogCatchUpTask.java  |  348 ---
 .../cluster/log/catchup/SnapshotCatchUpTask.java   |  158 --
 .../iotdb/cluster/log/logtypes/AddNodeLog.java     |   92 -
 .../iotdb/cluster/log/logtypes/CloseFileLog.java   |  124 -
 .../cluster/log/logtypes/EmptyContentLog.java      |   63 -
 .../iotdb/cluster/log/logtypes/LargeTestLog.java   |   78 -
 .../cluster/log/logtypes/PhysicalPlanLog.java      |  115 -
 .../iotdb/cluster/log/logtypes/RemoveNodeLog.java  |   87 -
 .../cluster/log/manage/CommittedEntryManager.java  |  289 --
 .../manage/FilePartitionedSnapshotLogManager.java  |  226 --
 .../log/manage/MetaSingleSnapshotLogManager.java   |   85 -
 .../log/manage/PartitionedSnapshotLogManager.java  |  118 -
 .../iotdb/cluster/log/manage/RaftLogManager.java   | 1017 -------
 .../log/manage/UnCommittedEntryManager.java        |  276 --
 .../log/manage/serializable/LogManagerMeta.java    |  143 -
 .../serializable/SyncLogDequeSerializer.java       | 1383 ---------
 .../iotdb/cluster/log/snapshot/FileSnapshot.java   |  641 -----
 .../cluster/log/snapshot/MetaSimpleSnapshot.java   |  301 --
 .../cluster/log/snapshot/PartitionedSnapshot.java  |  216 --
 .../cluster/log/snapshot/PullSnapshotTask.java     |  248 --
 .../log/snapshot/PullSnapshotTaskDescriptor.java   |  134 -
 .../cluster/log/snapshot/SnapshotFactory.java      |   28 -
 .../cluster/log/snapshot/SnapshotInstaller.java    |   32 -
 .../log/snapshot/TimeseriesSchemaSnapshot.java     |   31 -
 .../apache/iotdb/cluster/metadata/CMManager.java   | 1800 ------------
 .../apache/iotdb/cluster/metadata/MetaPuller.java  |  246 --
 .../cluster/partition/NodeAdditionResult.java      |   34 -
 .../iotdb/cluster/partition/NodeRemovalResult.java |   44 -
 .../iotdb/cluster/partition/PartitionGroup.java    |   64 -
 .../iotdb/cluster/partition/PartitionTable.java    |  131 -
 .../iotdb/cluster/partition/slot/SlotManager.java  |  320 ---
 .../partition/slot/SlotNodeAdditionResult.java     |   40 -
 .../partition/slot/SlotNodeRemovalResult.java      |   40 -
 .../cluster/partition/slot/SlotPartitionTable.java |  506 ----
 .../iotdb/cluster/partition/slot/SlotStrategy.java |   33 -
 .../cluster/query/ClusterConcatPathOptimizer.java  |   37 -
 .../cluster/query/ClusterDataQueryExecutor.java    |  326 ---
 .../cluster/query/ClusterPhysicalGenerator.java    |  125 -
 .../iotdb/cluster/query/ClusterPlanExecutor.java   |  639 -----
 .../iotdb/cluster/query/ClusterPlanRouter.java     |  467 ---
 .../apache/iotdb/cluster/query/ClusterPlanner.java |   58 -
 .../iotdb/cluster/query/ClusterQueryRouter.java    |   94 -
 .../iotdb/cluster/query/LocalQueryExecutor.java    |  967 -------
 .../iotdb/cluster/query/RemoteQueryContext.java    |   71 -
 .../query/aggregate/ClusterAggregateExecutor.java  |  102 -
 .../cluster/query/aggregate/ClusterAggregator.java |  283 --
 .../query/dataset/ClusterAlignByDeviceDataSet.java |   61 -
 .../cluster/query/fill/ClusterFillExecutor.java    |   68 -
 .../cluster/query/fill/ClusterLinearFill.java      |   76 -
 .../cluster/query/fill/ClusterPreviousFill.java    |  259 --
 .../cluster/query/fill/PreviousFillArguments.java  |   70 -
 .../iotdb/cluster/query/filter/SlotSgFilter.java   |   47 -
 .../cluster/query/filter/SlotTsFileFilter.java     |   62 -
 .../groupby/ClusterGroupByNoVFilterDataSet.java    |   67 -
 .../groupby/ClusterGroupByVFilterDataSet.java      |   82 -
 .../query/groupby/MergeGroupByExecutor.java        |  144 -
 .../query/groupby/RemoteGroupByExecutor.java       |  162 --
 .../query/last/ClusterLastQueryExecutor.java       |  277 --
 .../cluster/query/manage/ClusterQueryManager.java  |  133 -
 .../cluster/query/manage/QueryCoordinator.java     |   66 -
 .../cluster/query/reader/ClusterReaderFactory.java | 1044 -------
 .../cluster/query/reader/ClusterTimeGenerator.java |  211 --
 .../iotdb/cluster/query/reader/DataSourceInfo.java |  264 --
 .../iotdb/cluster/query/reader/EmptyReader.java    |  172 --
 .../cluster/query/reader/ManagedMergeReader.java   |   94 -
 .../cluster/query/reader/MergedReaderByTime.java   |   47 -
 .../reader/RemoteSeriesReaderByTimestamp.java      |  122 -
 .../query/reader/RemoteSimpleSeriesReader.java     |  167 --
 .../query/reader/mult/AbstractMultPointReader.java |   70 -
 .../reader/mult/AssignPathManagedMergeReader.java  |   92 -
 .../reader/mult/AssignPathPriorityMergeReader.java |   66 -
 .../query/reader/mult/IMultBatchReader.java        |   31 -
 .../cluster/query/reader/mult/MultBatchReader.java |   73 -
 .../query/reader/mult/MultDataSourceInfo.java      |  264 --
 .../cluster/query/reader/mult/MultEmptyReader.java |   52 -
 .../reader/mult/MultSeriesRawDataPointReader.java  |   55 -
 .../query/reader/mult/RemoteMultSeriesReader.java  |  222 --
 .../apache/iotdb/cluster/server/ClientServer.java  |  330 ---
 .../iotdb/cluster/server/DataClusterServer.java    |  966 -------
 .../iotdb/cluster/server/HardLinkCleaner.java      |  110 -
 .../iotdb/cluster/server/MetaClusterServer.java    |  369 ---
 .../apache/iotdb/cluster/server/NodeCharacter.java |   28 -
 .../cluster/server/PullSnapshotHintService.java    |  142 -
 .../apache/iotdb/cluster/server/RaftServer.java    |  263 --
 .../org/apache/iotdb/cluster/server/Response.java  |   58 -
 .../iotdb/cluster/server/StoppedMemberManager.java |  156 -
 .../handlers/caller/AppendGroupEntryHandler.java   |  157 -
 .../handlers/caller/AppendNodeEntryHandler.java    |  185 --
 .../server/handlers/caller/ElectionHandler.java    |  144 -
 .../server/handlers/caller/GenericHandler.java     |   94 -
 .../caller/GetChildNodeNextLevelHandler.java       |   59 -
 .../caller/GetChildNodeNextLevelPathHandler.java   |   60 -
 .../server/handlers/caller/GetDevicesHandler.java  |   60 -
 .../handlers/caller/GetNodesListHandler.java       |   59 -
 .../caller/GetTimeseriesSchemaHandler.java         |   59 -
 .../server/handlers/caller/HeartbeatHandler.java   |  148 -
 .../server/handlers/caller/JoinClusterHandler.java |   65 -
 .../server/handlers/caller/LogCatchUpHandler.java  |  106 -
 .../handlers/caller/LogCatchUpInBatchHandler.java  |  111 -
 .../server/handlers/caller/NodeStatusHandler.java  |   55 -
 .../handlers/caller/PreviousFillHandler.java       |   81 -
 .../caller/PullMeasurementSchemaHandler.java       |   73 -
 .../handlers/caller/PullSnapshotHandler.java       |   81 -
 .../caller/PullTimeseriesSchemaHandler.java        |   73 -
 .../handlers/caller/SnapshotCatchUpHandler.java    |   61 -
 .../server/handlers/caller/package-info.java       |   21 -
 .../handlers/forwarder/ForwardPlanHandler.java     |   68 -
 .../server/heartbeat/DataHeartbeatServer.java      |   83 -
 .../server/heartbeat/DataHeartbeatThread.java      |   74 -
 .../cluster/server/heartbeat/HeartbeatServer.java  |  212 --
 .../cluster/server/heartbeat/HeartbeatThread.java  |  412 ---
 .../server/heartbeat/MetaHeartbeatServer.java      |   91 -
 .../server/heartbeat/MetaHeartbeatThread.java      |   73 -
 .../cluster/server/member/DataGroupMember.java     |  868 ------
 .../cluster/server/member/MetaGroupMember.java     | 1812 ------------
 .../iotdb/cluster/server/member/RaftMember.java    | 1969 -------------
 .../iotdb/cluster/server/member/package-info.java  |   24 -
 .../iotdb/cluster/server/monitor/NodeReport.java   |  265 --
 .../iotdb/cluster/server/monitor/NodeStatus.java   |  118 -
 .../cluster/server/monitor/NodeStatusManager.java  |  183 --
 .../apache/iotdb/cluster/server/monitor/Peer.java  |   70 -
 .../apache/iotdb/cluster/server/monitor/Timer.java |  337 ---
 .../cluster/server/service/BaseAsyncService.java   |  176 --
 .../cluster/server/service/BaseSyncService.java    |  181 --
 .../cluster/server/service/DataAsyncService.java   |  456 ---
 .../cluster/server/service/DataSyncService.java    |  423 ---
 .../cluster/server/service/MetaAsyncService.java   |  209 --
 .../cluster/server/service/MetaSyncService.java    |  201 --
 .../iotdb/cluster/server/service/package-info.java |   24 -
 .../apache/iotdb/cluster/utils/ClientUtils.java    |   70 -
 .../iotdb/cluster/utils/ClusterConsistent.java     |   30 -
 .../apache/iotdb/cluster/utils/ClusterNode.java    |   86 -
 .../iotdb/cluster/utils/ClusterQueryUtils.java     |   68 -
 .../apache/iotdb/cluster/utils/ClusterUtils.java   |  356 ---
 .../org/apache/iotdb/cluster/utils/IOUtils.java    |   88 -
 .../iotdb/cluster/utils/NodeSerializeUtils.java    |   90 -
 .../apache/iotdb/cluster/utils/PartitionUtils.java |  400 ---
 .../apache/iotdb/cluster/utils/PlanSerializer.java |   53 -
 .../apache/iotdb/cluster/utils/StatusUtils.java    |  217 --
 .../cluster/utils/nodetool/ClusterMonitor.java     |  180 --
 .../utils/nodetool/ClusterMonitorMBean.java        |   84 -
 .../iotdb/cluster/utils/nodetool/NodeTool.java     |   43 -
 .../iotdb/cluster/utils/nodetool/Printer.java      |   38 -
 .../cluster/utils/nodetool/function/Host.java      |   77 -
 .../cluster/utils/nodetool/function/LogView.java   |   88 -
 .../utils/nodetool/function/NodeToolCmd.java       |  130 -
 .../cluster/utils/nodetool/function/Partition.java |  102 -
 .../cluster/utils/nodetool/function/Ring.java      |   45 -
 .../cluster/utils/nodetool/function/Status.java    |   48 -
 .../cluster/client/DataClientProviderTest.java     |  242 --
 .../cluster/client/async/AsyncClientPoolTest.java  |  211 --
 .../cluster/client/async/AsyncDataClientTest.java  |   88 -
 .../client/async/AsyncDataHeartbeatClientTest.java |   60 -
 .../cluster/client/async/AsyncMetaClientTest.java  |   88 -
 .../client/async/AsyncMetaHeartbeatClientTest.java |   61 -
 .../cluster/client/sync/SyncClientAdaptorTest.java |  433 ---
 .../cluster/client/sync/SyncClientPoolTest.java    |  167 --
 .../cluster/client/sync/SyncDataClientTest.java    |  126 -
 .../client/sync/SyncDataHeartbeatClientTest.java   |   66 -
 .../cluster/client/sync/SyncMetaClientTest.java    |  114 -
 .../client/sync/SyncMetaHeartbeatClientTest.java   |   66 -
 .../org/apache/iotdb/cluster/common/IoTDBTest.java |  181 --
 .../iotdb/cluster/common/TestAsyncClient.java      |   53 -
 .../cluster/common/TestAsyncClientFactory.java     |   55 -
 .../iotdb/cluster/common/TestAsyncDataClient.java  |  276 --
 .../iotdb/cluster/common/TestAsyncMetaClient.java  |   53 -
 .../iotdb/cluster/common/TestDataGroupMember.java  |   47 -
 .../apache/iotdb/cluster/common/TestException.java |   27 -
 .../org/apache/iotdb/cluster/common/TestLog.java   |   67 -
 .../iotdb/cluster/common/TestLogApplier.java       |   66 -
 .../iotdb/cluster/common/TestLogManager.java       |   39 -
 .../cluster/common/TestManagedSeriesReader.java    |   96 -
 .../iotdb/cluster/common/TestMetaGroupMember.java  |   40 -
 .../cluster/common/TestPartitionedLogManager.java  |   54 -
 .../apache/iotdb/cluster/common/TestSnapshot.java  |  110 -
 .../iotdb/cluster/common/TestSyncClient.java       |   47 -
 .../cluster/common/TestSyncClientFactory.java      |   75 -
 .../org/apache/iotdb/cluster/common/TestUtils.java |  419 ---
 .../cluster/integration/BaseSingleNodeTest.java    |   86 -
 .../iotdb/cluster/integration/SingleNodeTest.java  |   96 -
 .../iotdb/cluster/log/CommitLogCallbackTest.java   |   53 -
 .../iotdb/cluster/log/CommitLogTaskTest.java       |   75 -
 .../apache/iotdb/cluster/log/HardStateTest.java    |   49 -
 .../iotdb/cluster/log/LogDispatcherTest.java       |  268 --
 .../apache/iotdb/cluster/log/LogParserTest.java    |  101 -
 .../log/applier/AsyncDataLogApplierTest.java       |  174 --
 .../cluster/log/applier/DataLogApplierTest.java    |  376 ---
 .../cluster/log/applier/MetaLogApplierTest.java    |  129 -
 .../iotdb/cluster/log/catchup/CatchUpTaskTest.java |  399 ---
 .../cluster/log/catchup/LogCatchUpTaskTest.java    |  305 --
 .../log/catchup/SnapshotCatchUpTaskTest.java       |  286 --
 .../cluster/log/logtypes/SerializeLogTest.java     |  143 -
 .../log/manage/CommittedEntryManagerTest.java      |  625 ----
 .../FilePartitionedSnapshotLogManagerTest.java     |  109 -
 .../manage/MetaSingleSnapshotLogManagerTest.java   |   93 -
 .../cluster/log/manage/RaftLogManagerTest.java     | 1889 -------------
 .../log/manage/UnCommittedEntryManagerTest.java    |  695 -----
 .../serializable/SyncLogDequeSerializerTest.java   |  612 ----
 .../cluster/log/snapshot/DataSnapshotTest.java     |  188 --
 .../cluster/log/snapshot/FileSnapshotTest.java     |  306 --
 .../log/snapshot/MetaSimpleSnapshotTest.java       |  191 --
 .../log/snapshot/PartitionedSnapshotTest.java      |  123 -
 .../snapshot/PullSnapshotTaskDescriptorTest.java   |   64 -
 .../cluster/log/snapshot/PullSnapshotTaskTest.java |  327 ---
 .../iotdb/cluster/log/snapshot/SimpleSnapshot.java |  132 -
 .../iotdb/cluster/partition/MManagerWhiteBox.java  |   54 -
 .../iotdb/cluster/partition/SlotManagerTest.java   |  155 -
 .../cluster/partition/SlotPartitionTableTest.java  |  578 ----
 .../apache/iotdb/cluster/query/BaseQueryTest.java  |  127 -
 .../query/ClusterAggregateExecutorTest.java        |  162 --
 .../query/ClusterDataQueryExecutorTest.java        |  158 --
 .../cluster/query/ClusterFillExecutorTest.java     |  140 -
 .../query/ClusterPhysicalGeneratorTest.java        |   68 -
 .../cluster/query/ClusterPlanExecutorTest.java     |   91 -
 .../iotdb/cluster/query/ClusterPlannerTest.java    |   56 -
 .../cluster/query/ClusterQueryRouterTest.java      |  308 --
 .../iotdb/cluster/query/LoadConfigurationTest.java |  124 -
 .../ClusterGroupByNoVFilterDataSetTest.java        |   93 -
 .../groupby/ClusterGroupByVFilterDataSetTest.java  |  103 -
 .../query/groupby/MergeGroupByExecutorTest.java    |  123 -
 .../query/groupby/RemoteGroupByExecutorTest.java   |  174 --
 .../query/manage/ClusterQueryManagerTest.java      |  186 --
 .../cluster/query/manage/QueryCoordinatorTest.java |  125 -
 .../query/reader/ClusterTimeGeneratorTest.java     |   75 -
 .../cluster/query/reader/DatasourceInfoTest.java   |   87 -
 .../reader/RemoteSeriesReaderByTimestampTest.java  |  248 --
 .../query/reader/RemoteSimpleSeriesReaderTest.java |  224 --
 .../mult/AssignPathManagedMergeReaderTest.java     |  190 --
 .../mult/MultSeriesRawDataPointReaderTest.java     |   67 -
 .../reader/mult/RemoteMultSeriesReaderTest.java    |  286 --
 .../caller/AppendGroupEntryHandlerTest.java        |  187 --
 .../caller/AppendNodeEntryHandlerTest.java         |  174 --
 .../handlers/caller/ElectionHandlerTest.java       |  177 --
 .../server/handlers/caller/GenericHandlerTest.java |   58 -
 .../handlers/caller/HeartbeatHandlerTest.java      |  103 -
 .../handlers/caller/JoinClusterHandlerTest.java    |   67 -
 .../handlers/caller/LogCatchUpHandlerTest.java     |  127 -
 .../caller/PullMeasurementSchemaHandlerTest.java   |   92 -
 .../handlers/caller/PullSnapshotHandlerTest.java   |   84 -
 .../caller/SnapshotCatchUpHandlerTest.java         |   58 -
 .../handlers/forwarder/ForwardPlanHandlerTest.java |   59 -
 .../server/heartbeat/DataHeartbeatThreadTest.java  |  167 --
 .../server/heartbeat/HeartbeatThreadTest.java      |  255 --
 .../server/heartbeat/MetaHeartbeatThreadTest.java  |  223 --
 .../iotdb/cluster/server/member/BaseMember.java    |  315 ---
 .../cluster/server/member/DataGroupMemberTest.java | 1196 --------
 .../cluster/server/member/MetaGroupMemberTest.java | 1373 ---------
 .../cluster/server/member/RaftMemberTest.java      |  245 --
 .../org/apache/iotdb/cluster/utils/Constants.java  |   24 -
 .../iotdb/cluster/utils/SerializeUtilTest.java     |  194 --
 cluster/src/test/resources/logback.xml             |   45 -
 .../resources/node1conf/iotdb-cluster.properties   |   36 -
 .../resources/node1conf/iotdb-engine.properties    |   29 -
 .../resources/node2conf/iotdb-cluster.properties   |   36 -
 .../resources/node2conf/iotdb-engine.properties    |   29 -
 .../resources/node3conf/iotdb-cluster.properties   |   36 -
 .../resources/node3conf/iotdb-engine.properties    |   29 -
 code-coverage/README.md                            |   24 -
 code-coverage/copy-code-coverage-sources.sh        |   30 -
 code-coverage/pom.xml                              |  139 -
 codecov.yml                                        |   49 -
 compile-tools/README.md                            |  183 --
 compile-tools/pom.xml                              |  122 -
 compile-tools/thrift/pom.xml                       |  235 --
 cross-tests/pom.xml                                |  115 -
 .../tests/tools/importCsv/AbstractScript.java      |   99 -
 .../tests/tools/importCsv/ExportCsvTestIT.java     |  221 --
 .../tests/tools/importCsv/ImportCsvTestIT.java     |  335 ---
 .../src/test/resources/iotdb-engine.properties     |   21 -
 distribution/pom.xml                               |  145 -
 distribution/src/assembly/all.xml                  |  102 -
 distribution/src/assembly/cli.xml                  |   54 -
 distribution/src/assembly/client-cpp.xml           |   38 -
 distribution/src/assembly/cluster.xml              |   81 -
 distribution/src/assembly/common-files.xml         |   48 -
 distribution/src/assembly/grafana.xml              |   48 -
 distribution/src/assembly/server.xml               |   80 -
 docker/ReadMe.md                                   |   69 -
 docker/src/main/Dockerfile                         |   43 -
 docker/src/main/Dockerfile-0.10.0                  |   39 -
 docker/src/main/Dockerfile-0.10.1                  |   39 -
 docker/src/main/Dockerfile-0.11.0                  |   39 -
 docker/src/main/Dockerfile-0.11.1                  |   39 -
 docker/src/main/Dockerfile-0.11.2                  |   41 -
 docker/src/main/Dockerfile-0.8.1                   |   40 -
 docker/src/main/Dockerfile-0.9.0                   |   41 -
 docker/src/main/Dockerfile-0.9.1                   |   41 -
 docker/src/main/Dockerfile-0.9.1-jre8              |   41 -
 docs/Blog/Release0_93.md                           |   69 -
 docs/Blog/index.md                                 |   24 -
 docs/Community/Community-Powered By.md             |   52 -
 docs/Community/Community-Project Committers.md     |   22 -
 docs/Community/Feedback.md                         |   50 -
 docs/Community/Materials.md                        |  186 --
 docs/Development/Committer.md                      |   77 -
 docs/Development/ContributeGuide.md                |  153 -
 docs/Development/HowToCommit.md                    |  139 -
 docs/Development/VoteRelease.md                    |  190 --
 docs/Download/README.md                            |  123 -
 docs/README.md                                     |   21 -
 docs/SystemDesign/Architecture/Architecture.md     |   54 -
 docs/SystemDesign/Client/RPC.md                    |   56 -
 docs/SystemDesign/Connector/Hive-TsFile.md         |  114 -
 docs/SystemDesign/Connector/Spark-IOTDB.md         |   87 -
 docs/SystemDesign/Connector/Spark-TsFile.md        |  114 -
 docs/SystemDesign/DataQuery/AggregationQuery.md    |  136 -
 docs/SystemDesign/DataQuery/AlignByDeviceQuery.md  |  272 --
 docs/SystemDesign/DataQuery/DataQuery.md           |   46 -
 docs/SystemDesign/DataQuery/FillFunction.md        |  159 --
 docs/SystemDesign/DataQuery/GroupByFillQuery.md    |  177 --
 docs/SystemDesign/DataQuery/GroupByQuery.md        |  283 --
 docs/SystemDesign/DataQuery/LastQuery.md           |  137 -
 docs/SystemDesign/DataQuery/QueryFundamentals.md   |  161 --
 docs/SystemDesign/DataQuery/RawDataQuery.md        |  303 --
 docs/SystemDesign/DataQuery/SeriesReader.md        |  384 ---
 docs/SystemDesign/QueryEngine/PlanExecutor.md      |   26 -
 docs/SystemDesign/QueryEngine/Planner.md           |   65 -
 docs/SystemDesign/QueryEngine/QueryEngine.md       |   64 -
 .../QueryEngine/ResultSetConstruction.md           |  177 --
 docs/SystemDesign/SchemaManager/SchemaManager.md   |  329 ---
 .../SystemDesign/StorageEngine/DataManipulation.md |  104 -
 docs/SystemDesign/StorageEngine/DataPartition.md   |   86 -
 docs/SystemDesign/StorageEngine/FlushManager.md    |   84 -
 docs/SystemDesign/StorageEngine/MergeManager.md    |  107 -
 docs/SystemDesign/StorageEngine/Recover.md         |  106 -
 docs/SystemDesign/StorageEngine/StorageEngine.md   |   68 -
 docs/SystemDesign/StorageEngine/WAL.md             |   48 -
 docs/SystemDesign/Tools/Sync.md                    |  249 --
 docs/SystemDesign/TsFile/Format.md                 |  587 ----
 docs/SystemDesign/TsFile/Read.md                   |  559 ----
 docs/SystemDesign/TsFile/TsFile.md                 |   30 -
 docs/SystemDesign/TsFile/Write.md                  |  126 -
 docs/UserGuide/API/Programming-JDBC.md             |  203 --
 docs/UserGuide/API/Programming-Native-API.md       |  335 ---
 docs/UserGuide/API/Programming-Other-Languages.md  |  271 --
 docs/UserGuide/API/Programming-TsFile-API.md       |  555 ----
 .../Administration-Management/Administration.md    |  160 --
 docs/UserGuide/Appendix/Config-Manual.md           |  686 -----
 docs/UserGuide/Appendix/SQL-Reference.md           | 1145 --------
 docs/UserGuide/Appendix/Status-Codes.md            |  107 -
 docs/UserGuide/CLI/Command-Line-Interface.md       |  194 --
 docs/UserGuide/Cluster/Cluster-Setup-Example.md    |   47 -
 docs/UserGuide/Cluster/Cluster-Setup.md            |  244 --
 .../Collaboration-of-Edge-and-Cloud/Sync-Tool.md   |  186 --
 .../Programming-MQTT.md                            |  104 -
 .../Programming-Thrift.md                          |  157 -
 docs/UserGuide/Comparison/TSDB-Comparison.md       |  374 ---
 docs/UserGuide/Data-Concept/Compression.md         |   36 -
 .../Data-Concept/Data-Model-and-Terminology.md     |  240 --
 docs/UserGuide/Data-Concept/Data-Type.md           |   44 -
 docs/UserGuide/Data-Concept/Encoding.md            |   71 -
 docs/UserGuide/Data-Concept/SDT.md                 |  111 -
 .../UserGuide/Ecosystem Integration/Flink IoTDB.md |  213 --
 .../Ecosystem Integration/Flink TsFile.md          |  181 --
 docs/UserGuide/Ecosystem Integration/Grafana.md    |  164 --
 .../UserGuide/Ecosystem Integration/Hive TsFile.md |  171 --
 .../Ecosystem Integration/MapReduce TsFile.md      |  199 --
 .../UserGuide/Ecosystem Integration/Spark IoTDB.md |  166 --
 .../Ecosystem Integration/Spark TsFile.md          |  315 ---
 .../Ecosystem Integration/Writing Data on HDFS.md  |  171 --
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  176 --
 docs/UserGuide/FAQ/Frequently-asked-questions.md   |  152 -
 docs/UserGuide/IoTDB-Introduction/Architecture.md  |   38 -
 docs/UserGuide/IoTDB-Introduction/Features.md      |   50 -
 docs/UserGuide/IoTDB-Introduction/Publication.md   |   40 -
 docs/UserGuide/IoTDB-Introduction/Scenario.md      |   76 -
 docs/UserGuide/IoTDB-Introduction/What-is-IoTDB.md |   24 -
 .../DDL-Data-Definition-Language.md                |  544 ----
 .../DML-Data-Manipulation-Language.md              | 1521 ----------
 .../IoTDB-SQL-Language/Maintenance-Command.md      |  102 -
 docs/UserGuide/QuickStart/Files.md                 |   60 -
 docs/UserGuide/QuickStart/QuickStart.md            |  239 --
 docs/UserGuide/QuickStart/ServerFileList.md        |  160 --
 docs/UserGuide/QuickStart/WayToGetIoTDB.md         |  144 -
 docs/UserGuide/System-Tools/CSV-Tool.md            |  144 -
 docs/UserGuide/System-Tools/JMX-Tool.md            |   59 -
 .../UserGuide/System-Tools/Load-External-Tsfile.md |   82 -
 docs/UserGuide/System-Tools/MLogParser-Tool.md     |   38 -
 .../System-Tools/Monitor-and-Log-Tools.md          |  252 --
 docs/UserGuide/System-Tools/NodeTool.md            |  297 --
 .../System-Tools/Performance-Tracing-Tool.md       |   63 -
 .../Query-History-Visualization-Tool.md            |   31 -
 docs/UserGuide/System-Tools/Watermark-Tool.md      |  196 --
 docs/UserGuide/UDF/Triggers.md                     |  100 -
 docs/UserGuide/UDF/UDF-User-Defined-Function.md    |  587 ----
 docs/UserGuide/UserGuideReadme.md                  |   32 -
 docs/zh/Community/Community-Powered By.md          |   61 -
 docs/zh/Community/Community-Project Committers.md  |   22 -
 docs/zh/Community/Feedback.md                      |   46 -
 docs/zh/Development/Committer.md                   |   78 -
 docs/zh/Development/ContributeGuide.md             |  157 -
 docs/zh/Development/HowToCommit.md                 |  139 -
 docs/zh/Development/VoteRelease.md                 |  190 --
 docs/zh/Download/README.md                         |  107 -
 docs/zh/README.md                                  |   21 -
 docs/zh/SystemDesign/Architecture/Architecture.md  |   55 -
 docs/zh/SystemDesign/Client/RPC.md                 |   57 -
 docs/zh/SystemDesign/Connector/Hive-TsFile.md      |  121 -
 docs/zh/SystemDesign/Connector/Spark-IOTDB.md      |   89 -
 docs/zh/SystemDesign/Connector/Spark-TsFile.md     |  125 -
 docs/zh/SystemDesign/DataQuery/AggregationQuery.md |  134 -
 .../SystemDesign/DataQuery/AlignByDeviceQuery.md   |  270 --
 docs/zh/SystemDesign/DataQuery/DataQuery.md        |   48 -
 docs/zh/SystemDesign/DataQuery/FillFunction.md     |  159 --
 docs/zh/SystemDesign/DataQuery/GroupByFillQuery.md |  176 --
 docs/zh/SystemDesign/DataQuery/GroupByQuery.md     |  288 --
 docs/zh/SystemDesign/DataQuery/LastQuery.md        |  133 -
 docs/zh/SystemDesign/DataQuery/OrderByTimeQuery.md |  190 --
 .../zh/SystemDesign/DataQuery/QueryFundamentals.md |  144 -
 docs/zh/SystemDesign/DataQuery/RawDataQuery.md     |  323 ---
 docs/zh/SystemDesign/DataQuery/SeriesReader.md     |  384 ---
 docs/zh/SystemDesign/QueryEngine/PlanExecutor.md   |   26 -
 docs/zh/SystemDesign/QueryEngine/Planner.md        |   63 -
 docs/zh/SystemDesign/QueryEngine/QueryEngine.md    |   64 -
 .../QueryEngine/ResultSetConstruction.md           |  175 --
 .../zh/SystemDesign/SchemaManager/SchemaManager.md |  323 ---
 docs/zh/SystemDesign/StorageEngine/Compaction.md   |  258 --
 .../SystemDesign/StorageEngine/DataManipulation.md |  105 -
 .../zh/SystemDesign/StorageEngine/DataPartition.md |   86 -
 docs/zh/SystemDesign/StorageEngine/FileLists.md    |  156 -
 docs/zh/SystemDesign/StorageEngine/FlushManager.md |   84 -
 docs/zh/SystemDesign/StorageEngine/MergeManager.md |  112 -
 docs/zh/SystemDesign/StorageEngine/Recover.md      |  107 -
 .../zh/SystemDesign/StorageEngine/StorageEngine.md |   67 -
 docs/zh/SystemDesign/StorageEngine/WAL.md          |   48 -
 docs/zh/SystemDesign/Tools/Sync.md                 |  299 --
 docs/zh/SystemDesign/TsFile/Format.md              |  584 ----
 docs/zh/SystemDesign/TsFile/Read.md                |  566 ----
 docs/zh/SystemDesign/TsFile/TsFile.md              |   31 -
 docs/zh/SystemDesign/TsFile/Write.md               |  126 -
 docs/zh/UserGuide/API/Programming-JDBC.md          |  201 --
 docs/zh/UserGuide/API/Programming-Native-API.md    |  238 --
 .../UserGuide/API/Programming-Other-Languages.md   |  320 ---
 docs/zh/UserGuide/API/Programming-TsFile-API.md    |  549 ----
 .../Administration-Management/Administration.md    |  168 --
 docs/zh/UserGuide/Appendix/Config-Manual.md        |  715 -----
 docs/zh/UserGuide/Appendix/SQL-Reference.md        | 1113 --------
 docs/zh/UserGuide/Appendix/Status-Codes.md         |  106 -
 docs/zh/UserGuide/CLI/Command-Line-Interface.md    |  192 --
 docs/zh/UserGuide/Cluster/Cluster-Setup-Example.md |   46 -
 docs/zh/UserGuide/Cluster/Cluster-Setup.md         |  237 --
 .../Collaboration-of-Edge-and-Cloud/Sync-Tool.md   |  187 --
 .../Programming-MQTT.md                            |  106 -
 .../Programming-Thrift.md                          |  157 -
 docs/zh/UserGuide/Data-Concept/Compression.md      |   33 -
 .../Data-Concept/Data-Model-and-Terminology.md     |  236 --
 docs/zh/UserGuide/Data-Concept/Data-Type.md        |   42 -
 docs/zh/UserGuide/Data-Concept/Encoding.md         |   71 -
 docs/zh/UserGuide/Data-Concept/SDT.md              |  106 -
 .../UserGuide/Ecosystem Integration/Flink IoTDB.md |  122 -
 .../Ecosystem Integration/Flink TsFile.md          |  179 --
 docs/zh/UserGuide/Ecosystem Integration/Grafana.md |  164 --
 .../UserGuide/Ecosystem Integration/Hive TsFile.md |  174 --
 .../Ecosystem Integration/MapReduce TsFile.md      |  203 --
 .../UserGuide/Ecosystem Integration/Spark IoTDB.md |  170 --
 .../Ecosystem Integration/Spark TsFile.md          |  327 ---
 .../Ecosystem Integration/Writing Data on HDFS.md  |  171 --
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  179 --
 .../zh/UserGuide/FAQ/Frequently-asked-questions.md |  154 -
 .../UserGuide/IoTDB-Introduction/Architecture.md   |   38 -
 docs/zh/UserGuide/IoTDB-Introduction/Features.md   |   50 -
 .../zh/UserGuide/IoTDB-Introduction/Publication.md |   38 -
 docs/zh/UserGuide/IoTDB-Introduction/Scenario.md   |   76 -
 .../UserGuide/IoTDB-Introduction/What-is-IoTDB.md  |   24 -
 .../DDL-Data-Definition-Language.md                |  550 ----
 .../DML-Data-Manipulation-Language.md              | 1507 ----------
 .../IoTDB-SQL-Language/Maintenance-Command.md      |  101 -
 docs/zh/UserGuide/QuickStart/Files.md              |   61 -
 docs/zh/UserGuide/QuickStart/QuickStart.md         |  271 --
 docs/zh/UserGuide/QuickStart/ServerFileList.md     |  150 -
 docs/zh/UserGuide/QuickStart/WayToGetIoTDB.md      |  157 -
 docs/zh/UserGuide/System-Tools/CSV-Tool.md         |  144 -
 docs/zh/UserGuide/System-Tools/JMX-Tool.md         |   59 -
 .../UserGuide/System-Tools/Load-External-Tsfile.md |   79 -
 docs/zh/UserGuide/System-Tools/MLogParser-Tool.md  |   38 -
 .../System-Tools/Monitor-and-Log-Tools.md          |  286 --
 docs/zh/UserGuide/System-Tools/NodeTool.md         |  294 --
 .../System-Tools/Performance-Tracing-Tool.md       |   63 -
 .../Query-History-Visualization-Tool.md            |   30 -
 docs/zh/UserGuide/System-Tools/Watermark-Tool.md   |  196 --
 docs/zh/UserGuide/UDF/Triggers.md                  |  100 -
 docs/zh/UserGuide/UDF/UDF-User-Defined-Function.md |  591 ----
 docs/zh/UserGuide/UserGuideReadme.md               |   32 -
 docs/zh/chinese-render-template.latex              |  220 --
 example/client-cpp-example/README.md               |   48 -
 example/client-cpp-example/pom.xml                 |  183 --
 example/client-cpp-example/src/SessionExample.cpp  |  308 --
 example/flink/README.md                            |   40 -
 example/flink/pom.xml                              |   83 -
 .../org/apache/iotdb/flink/FlinkIoTDBSink.java     |   94 -
 .../org/apache/iotdb/flink/FlinkIoTDBSource.java   |   94 -
 .../apache/iotdb/flink/FlinkTsFileBatchSink.java   |  123 -
 .../apache/iotdb/flink/FlinkTsFileBatchSource.java |   76 -
 .../apache/iotdb/flink/FlinkTsFileStreamSink.java  |  124 -
 .../iotdb/flink/FlinkTsFileStreamSource.java       |   79 -
 .../java/org/apache/iotdb/flink/TsFileUtils.java   |  107 -
 example/hadoop/pom.xml                             |   39 -
 .../org/apache/iotdb/hadoop/tsfile/Constant.java   |   32 -
 .../iotdb/hadoop/tsfile/TSFMRReadExample.java      |  129 -
 .../iotdb/hadoop/tsfile/TSMRWriteExample.java      |  183 --
 .../apache/iotdb/hadoop/tsfile/TsFileHelper.java   |  141 -
 .../iotdb/hadoop/tsfile/TsFileWriteToHDFS.java     |   78 -
 example/jdbc/pom.xml                               |   43 -
 .../main/java/org/apache/iotdb/JDBCExample.java    |  107 -
 .../org/apache/iotdb/PrepareStatementDemo.java     |   79 -
 example/kafka/pom.xml                              |   49 -
 example/kafka/readme.md                            |   75 -
 .../main/java/org/apache/iotdb/kafka/Constant.java |   63 -
 .../java/org/apache/iotdb/kafka/KafkaConsumer.java |   90 -
 .../apache/iotdb/kafka/KafkaConsumerThread.java    |  104 -
 .../java/org/apache/iotdb/kafka/KafkaProducer.java |   64 -
 example/mqtt/README.md                             |   33 -
 example/mqtt/pom.xml                               |   39 -
 .../java/org/apache/iotdb/mqtt/MQTTClient.java     |   53 -
 example/pom.xml                                    |   91 -
 example/pulsar/pom.xml                             |   45 -
 .../java/org/apache/iotdb/pulsar/Constant.java     |   30 -
 .../org/apache/iotdb/pulsar/PulsarConsumer.java    |  113 -
 .../apache/iotdb/pulsar/PulsarConsumerThread.java  |   72 -
 .../org/apache/iotdb/pulsar/PulsarProducer.java    |   86 -
 example/rocketmq/pom.xml                           |   50 -
 example/rocketmq/readme.md                         |   83 -
 .../java/org/apache/iotdb/rocketmq/Constant.java   |   67 -
 .../apache/iotdb/rocketmq/RocketMQConsumer.java    |  206 --
 .../apache/iotdb/rocketmq/RocketMQProducer.java    |  100 -
 .../main/java/org/apache/iotdb/rocketmq/Utils.java |   38 -
 example/session/pom.xml                            |   43 -
 .../org/apache/iotdb/DataMigrationExample.java     |  186 --
 .../main/java/org/apache/iotdb/SessionExample.java |  630 -----
 .../java/org/apache/iotdb/SessionPoolExample.java  |  121 -
 .../src/main/java/org/apache/iotdb/Write.java      |   44 -
 example/tsfile/pom.xml                             |   39 -
 example/tsfile/readme.md                           |   84 -
 .../java/org/apache/iotdb/tsfile/Constant.java     |   31 -
 .../iotdb/tsfile/TsFileForceAppendWrite.java       |  115 -
 .../java/org/apache/iotdb/tsfile/TsFileRead.java   |   96 -
 .../apache/iotdb/tsfile/TsFileSequenceRead.java    |  142 -
 .../iotdb/tsfile/TsFileWriteWithTSRecord.java      |   81 -
 .../apache/iotdb/tsfile/TsFileWriteWithTablet.java |  107 -
 .../apache/iotdb/tsfile/tlsm_compaction.properties |  681 -----
 .../org/apache/iotdb/tsfile/tlsm_write.properties  |  681 -----
 example/udf/pom.xml                                |  124 -
 .../java/org/apache/iotdb/udf/UDTFExample.java     |   57 -
 flink-iotdb-connector/README.md                    |   58 -
 flink-iotdb-connector/pom.xml                      |   55 -
 .../iotdb/flink/DefaultIoTSerializationSchema.java |  128 -
 .../main/java/org/apache/iotdb/flink/Event.java    |   70 -
 .../java/org/apache/iotdb/flink/IoTDBSink.java     |  229 --
 .../java/org/apache/iotdb/flink/IoTDBSource.java   |  100 -
 .../apache/iotdb/flink/IoTSerializationSchema.java |   32 -
 .../apache/iotdb/flink/options/IoTDBOptions.java   |   70 -
 .../iotdb/flink/options/IoTDBSinkOptions.java      |  117 -
 .../iotdb/flink/options/IoTDBSourceOptions.java    |   51 -
 .../flink/DefaultIoTSerializationSchemaTest.java   |   54 -
 .../iotdb/flink/IoTDBSinkBatchInsertTest.java      |  116 -
 .../iotdb/flink/IoTDBSinkBatchTimerTest.java       |   82 -
 .../apache/iotdb/flink/IoTDBSinkInsertTest.java    |   72 -
 flink-tsfile-connector/README.md                   |  177 --
 flink-tsfile-connector/pom.xml                     |   84 -
 .../apache/iotdb/flink/tsfile/RowRecordParser.java |   47 -
 .../iotdb/flink/tsfile/RowRowRecordParser.java     |  122 -
 .../iotdb/flink/tsfile/RowTSRecordConverter.java   |  167 --
 .../iotdb/flink/tsfile/TSRecordConverter.java      |   62 -
 .../iotdb/flink/tsfile/TSRecordOutputFormat.java   |   99 -
 .../iotdb/flink/tsfile/TsFileInputFormat.java      |  173 --
 .../iotdb/flink/tsfile/TsFileOutputFormat.java     |  136 -
 .../iotdb/flink/tsfile/util/TSFileConfigUtil.java  |   64 -
 .../tsfile/RowTSRecordOutputFormatITCase.java      |   54 -
 .../flink/tsfile/RowTSRecordOutputFormatTest.java  |   75 -
 .../flink/tsfile/RowTsFileConnectorTestBase.java   |   77 -
 .../flink/tsfile/RowTsFileInputFormatITCase.java   |  108 -
 .../flink/tsfile/RowTsFileInputFormatTest.java     |   89 -
 .../flink/tsfile/RowTsFileInputFormatTestBase.java |   49 -
 .../tsfile/RowTsFileOutputFormatTestBase.java      |  120 -
 .../util/TSFileConfigUtilCompletenessTest.java     |   88 -
 .../apache/iotdb/flink/util/TsFileWriteUtil.java   |  233 --
 grafana/img/add_data_source.png                    |  Bin 108927 -> 0 bytes
 grafana/img/add_graph.png                          |  Bin 364163 -> 0 bytes
 grafana/img/edit_data_source.png                   |  Bin 177869 -> 0 bytes
 grafana/pom.xml                                    |  258 --
 grafana/readme.md                                  |  175 --
 grafana/readme_zh.md                               |  172 --
 .../web/grafana/TsfileWebDemoApplication.java      |   30 -
 .../apache/iotdb/web/grafana/bean/TimeValues.java  |   47 -
 .../iotdb/web/grafana/conf/MyConfiguration.java    |   41 -
 .../controller/DatabaseConnectController.java      |  227 --
 .../org/apache/iotdb/web/grafana/dao/BasicDao.java |   33 -
 .../iotdb/web/grafana/dao/impl/BasicDaoImpl.java   |  212 --
 .../grafana/service/DatabaseConnectService.java    |   34 -
 .../service/impl/DatabaseConnectServiceImpl.java   |   51 -
 grafana/src/main/resources/application.properties  |   39 -
 .../web/grafana/dao/impl/BasicDaoImplTest.java     |   52 -
 hadoop/README.md                                   |  212 --
 hadoop/pom.xml                                     |  185 --
 .../iotdb/hadoop/fileSystem/HDFSConfUtil.java      |  105 -
 .../apache/iotdb/hadoop/fileSystem/HDFSFile.java   |  435 ---
 .../apache/iotdb/hadoop/fileSystem/HDFSInput.java  |  142 -
 .../apache/iotdb/hadoop/fileSystem/HDFSOutput.java |  104 -
 .../org/apache/iotdb/hadoop/tsfile/IReaderSet.java |   38 -
 .../iotdb/hadoop/tsfile/TSFHadoopException.java    |   45 -
 .../apache/iotdb/hadoop/tsfile/TSFInputFormat.java |  289 --
 .../apache/iotdb/hadoop/tsfile/TSFInputSplit.java  |   39 -
 .../iotdb/hadoop/tsfile/TSFOutputFormat.java       |   58 -
 .../iotdb/hadoop/tsfile/TSFRecordReader.java       |  258 --
 .../iotdb/hadoop/tsfile/TSFRecordWriter.java       |   62 -
 .../iotdb/hadoop/tsfile/record/HDFSTSRecord.java   |  197 --
 .../apache/iotdb/hadoop/tsfile/TSFHadoopTest.java  |  190 --
 .../iotdb/hadoop/tsfile/TSFInputSplitTest.java     |   70 -
 .../iotdb/hadoop/tsfile/TsFileTestHelper.java      |  122 -
 .../iotdb/hadoop/tsfile/constant/TestConstant.java |   28 -
 hadoop/src/test/resources/logback.xml              |   41 -
 hive-connector/pom.xml                             |  215 --
 .../org/apache/iotdb/hive/TSFHiveInputFormat.java  |   52 -
 .../org/apache/iotdb/hive/TSFHiveOutputFormat.java |   75 -
 .../org/apache/iotdb/hive/TSFHiveRecordReader.java |  158 --
 .../org/apache/iotdb/hive/TSFHiveRecordWriter.java |   71 -
 .../org/apache/iotdb/hive/TsFileDeserializer.java  |  151 -
 .../java/org/apache/iotdb/hive/TsFileSerDe.java    |  173 --
 .../apache/iotdb/hive/TsFileSerDeException.java    |   40 -
 .../apache/iotdb/hive/TSFHiveInputFormatTest.java  |   88 -
 .../apache/iotdb/hive/TSFHiveRecordReaderTest.java |  135 -
 .../apache/iotdb/hive/TsFileDeserializerTest.java  |  119 -
 .../org/apache/iotdb/hive/TsFileSerDeTest.java     |  142 -
 .../org/apache/iotdb/hive/TsFileTestHelper.java    |  127 -
 .../apache/iotdb/hive/constant/TestConstant.java   |   28 -
 hive-connector/src/test/resources/logback.xml      |   39 -
 java-google-style.xml                              |  618 ----
 jdbc/README.md                                     |  272 --
 jdbc/osgi.bnd                                      |   31 -
 jdbc/pom.xml                                       |  266 --
 jdbc/src/main/feature/feature.xml                  |   36 -
 .../iotdb/jdbc/AbstractIoTDBJDBCResultSet.java     | 1126 --------
 .../main/java/org/apache/iotdb/jdbc/Activator.java |   41 -
 .../main/java/org/apache/iotdb/jdbc/Config.java    |   56 -
 .../main/java/org/apache/iotdb/jdbc/Constant.java  |   28 -
 .../org/apache/iotdb/jdbc/IoTDBConnection.java     |  547 ----
 .../apache/iotdb/jdbc/IoTDBConnectionParams.java   |  102 -
 .../org/apache/iotdb/jdbc/IoTDBDataSource.java     |  138 -
 .../apache/iotdb/jdbc/IoTDBDataSourceFactory.java  |   79 -
 .../apache/iotdb/jdbc/IoTDBDatabaseMetadata.java   | 1034 -------
 .../java/org/apache/iotdb/jdbc/IoTDBDriver.java    |   98 -
 .../org/apache/iotdb/jdbc/IoTDBJDBCResultSet.java  |  119 -
 .../iotdb/jdbc/IoTDBNonAlignJDBCResultSet.java     |  280 --
 .../apache/iotdb/jdbc/IoTDBPreparedStatement.java  |  501 ----
 .../org/apache/iotdb/jdbc/IoTDBResultMetadata.java |  232 --
 .../org/apache/iotdb/jdbc/IoTDBSQLException.java   |   41 -
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |  721 -----
 .../org/apache/iotdb/jdbc/IoTDBURLException.java   |   30 -
 .../src/main/java/org/apache/iotdb/jdbc/Utils.java |   72 -
 .../resources/services/META-INF/java.sql.Driver    |   19 -
 .../test/java/org/apache/iotdb/jdbc/BatchTest.java |  161 --
 .../org/apache/iotdb/jdbc/IoTDBConnectionTest.java |  108 -
 .../apache/iotdb/jdbc/IoTDBJDBCResultSetTest.java  |  405 ---
 .../iotdb/jdbc/IoTDBPreparedStatementTest.java     |  317 ---
 .../apache/iotdb/jdbc/IoTDBResultMetadataTest.java |  172 --
 .../org/apache/iotdb/jdbc/IoTDBStatementTest.java  |  104 -
 .../test/java/org/apache/iotdb/jdbc/UtilsTest.java |  116 -
 jenkins.pom                                        |   67 -
 licenses/CDDL License 1.1                          |   90 -
 licenses/Eclipse Public License 1.0 (EPL-1.0)      |   83 -
 .../Eclipse Public License version 2.0 (EPL-2.0)   |   81 -
 licenses/The 2-Clause BSD License                  |   14 -
 licenses/The 3-Clause BSD License                  |   16 -
 licenses/The MIT License (QOS.ch)                  |   21 -
 licenses/The MIT License (progressbar)             |   21 -
 mvnw.cmd                                           |  159 --
 mvnw.sh                                            |  270 --
 pom.xml                                            | 1368 ---------
 separation_py/SeparationServer.py                  |   31 -
 .../gen-java/SeparationTunningService.java         |  963 -------
 separation_py/gen-py/__init__.py                   |    0
 separation_py/org/__init__.py                      |    0
 separation_py/org/apache/__init__.py               |    0
 separation_py/org/apache/iotdb/__init__.py         |    0
 .../separation_py/SeparationTunningService-remote  |  117 -
 .../separation_py/SeparationTunningService.py      |  246 --
 .../org/apache/iotdb/separation_py/__init__.py     |    1 -
 .../org/apache/iotdb/separation_py/constants.py    |   14 -
 .../org/apache/iotdb/separation_py/hlsm.py         |   70 -
 .../org/apache/iotdb/separation_py/tools.py        |  188 --
 .../org/apache/iotdb/separation_py/ttypes.py       |   18 -
 separation_py/separation.thrift                    |    7 -
 server/file-changelists/TsFileMods-changelist.md   |   39 -
 .../file-changelists/TsFileResource-changelist.md  |   40 -
 server/file-changelists/conf-changelist.md         |  102 -
 server/file-changelists/mlog-changelist.md         |   30 -
 server/file-changelists/role-changelist.md         |   34 -
 .../system.properties-changelist.md                |   39 -
 server/file-changelists/tlog-changelist.md         |   20 -
 server/file-changelists/user-changelist.md         |   34 -
 server/file-changelists/wal-changelist.md          |   30 -
 server/pom.xml                                     |  321 ---
 server/server-changelist.md                        |   53 -
 .../resources/conf/iotdb-engine.properties         |  686 -----
 server/src/assembly/resources/conf/iotdb-env.bat   |  130 -
 server/src/assembly/resources/conf/iotdb-env.sh    |  219 --
 .../resources/conf/iotdb-sync-client.properties    |   35 -
 server/src/assembly/resources/conf/jmx.access      |   22 -
 server/src/assembly/resources/conf/jmx.password    |   22 -
 .../src/assembly/resources/conf/logback-tool.xml   |   22 -
 server/src/assembly/resources/conf/logback.xml     |  282 --
 .../src/assembly/resources/sbin/start-server.bat   |  126 -
 server/src/assembly/resources/sbin/start-server.sh |   82 -
 server/src/assembly/resources/sbin/stop-server.bat |   38 -
 server/src/assembly/resources/sbin/stop-server.sh  |   35 -
 .../assembly/resources/tools/detect-watermark.bat  |   65 -
 .../assembly/resources/tools/detect-watermark.sh   |   46 -
 .../assembly/resources/tools/mlog/mLogParser.bat   |   62 -
 .../assembly/resources/tools/mlog/mLogParser.sh    |   48 -
 .../assembly/resources/tools/start-WalChecker.bat  |  111 -
 .../assembly/resources/tools/start-WalChecker.sh   |   90 -
 .../assembly/resources/tools/start-sync-client.bat |   71 -
 .../assembly/resources/tools/start-sync-client.sh  |   54 -
 .../assembly/resources/tools/stop-sync-client.bat  |   23 -
 .../assembly/resources/tools/stop-sync-client.sh   |   30 -
 .../tools/tsfileToolSet/print-iotdb-data-dir.bat   |   62 -
 .../tools/tsfileToolSet/print-iotdb-data-dir.sh    |   48 -
 .../tsfileToolSet/print-tsfile-resource-files.bat  |   61 -
 .../tsfileToolSet/print-tsfile-resource-files.sh   |   59 -
 .../tools/tsfileToolSet/print-tsfile-sketch.bat    |   62 -
 .../tools/tsfileToolSet/print-tsfile-sketch.sh     |   48 -
 server/src/assembly/server.xml                     |   40 -
 .../org/apache/iotdb/db/auth/AuthException.java    |   37 -
 .../org/apache/iotdb/db/auth/AuthorityChecker.java |  166 --
 .../iotdb/db/auth/authorizer/BasicAuthorizer.java  |  406 ---
 .../iotdb/db/auth/authorizer/IAuthorizer.java      |  261 --
 .../db/auth/authorizer/LocalFileAuthorizer.java    |   44 -
 .../iotdb/db/auth/authorizer/OpenIdAuthorizer.java |  282 --
 .../apache/iotdb/db/auth/entity/PathPrivilege.java |  127 -
 .../apache/iotdb/db/auth/entity/PrivilegeType.java |   61 -
 .../java/org/apache/iotdb/db/auth/entity/Role.java |  143 -
 .../java/org/apache/iotdb/db/auth/entity/User.java |  231 --
 .../iotdb/db/auth/role/BasicRoleManager.java       |  189 --
 .../apache/iotdb/db/auth/role/IRoleAccessor.java   |   64 -
 .../apache/iotdb/db/auth/role/IRoleManager.java    |  101 -
 .../iotdb/db/auth/role/LocalFileRoleAccessor.java  |  191 --
 .../iotdb/db/auth/role/LocalFileRoleManager.java   |   26 -
 .../iotdb/db/auth/user/BasicUserManager.java       |  331 ---
 .../apache/iotdb/db/auth/user/IUserAccessor.java   |   64 -
 .../apache/iotdb/db/auth/user/IUserManager.java    |  150 -
 .../iotdb/db/auth/user/LocalFileUserAccessor.java  |  245 --
 .../iotdb/db/auth/user/LocalFileUserManager.java   |   28 -
 .../org/apache/iotdb/db/concurrent/HashLock.java   |   62 -
 .../IoTDBDefaultThreadExceptionHandler.java        |   33 -
 .../db/concurrent/IoTDBThreadPoolFactory.java      |  145 -
 .../iotdb/db/concurrent/IoTThreadFactory.java      |   58 -
 .../org/apache/iotdb/db/concurrent/ThreadName.java |   57 -
 .../iotdb/db/concurrent/WrappedRunnable.java       |   46 -
 .../java/org/apache/iotdb/db/conf/IoTDBConfig.java | 2180 --------------
 .../org/apache/iotdb/db/conf/IoTDBConfigCheck.java |  547 ----
 .../org/apache/iotdb/db/conf/IoTDBConstant.java    |  154 -
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  | 1210 --------
 .../iotdb/db/conf/ServerConfigConsistent.java      |   34 -
 .../iotdb/db/conf/adapter/CompressionRatio.java    |  190 --
 .../db/conf/directories/DirectoryManager.java      |  192 --
 .../directories/strategy/DirectoryStrategy.java    |   70 -
 .../strategy/MaxDiskUsableSpaceFirstStrategy.java  |   55 -
 .../MinFolderOccupiedSpaceFirstStrategy.java       |   61 -
 .../strategy/RandomOnDiskUsableSpaceStrategy.java  |   65 -
 .../directories/strategy/SequenceStrategy.java     |   63 -
 .../db/cost/statistic/ConcurrentCircularArray.java |   67 -
 .../iotdb/db/cost/statistic/Measurement.java       |  425 ---
 .../iotdb/db/cost/statistic/MeasurementMBean.java  |   60 -
 .../apache/iotdb/db/cost/statistic/Operation.java  |   38 -
 .../org/apache/iotdb/db/engine/StorageEngine.java  |  954 -------
 .../iotdb/db/engine/cache/AccountableString.java   |   64 -
 .../db/engine/cache/CacheHitRatioMonitor.java      |  115 -
 .../engine/cache/CacheHitRatioMonitorMXBean.java   |   42 -
 .../apache/iotdb/db/engine/cache/ChunkCache.java   |  213 --
 .../iotdb/db/engine/cache/LRULinkedHashMap.java    |  138 -
 .../db/engine/cache/TimeSeriesMetadataCache.java   |  333 ---
 .../compaction/CompactionMergeTaskPoolManager.java |  193 --
 .../db/engine/compaction/CompactionStrategy.java   |   42 -
 .../db/engine/compaction/TsFileManagement.java     |  461 ---
 .../level/LevelCompactionTsFileManagement.java     |  869 ------
 ...TraditionalLevelCompactionTsFileManagement.java |  792 ------
 .../no/NoCompactionTsFileManagement.java           |  290 --
 .../compaction/utils/CompactionLogAnalyzer.java    |  112 -
 .../engine/compaction/utils/CompactionLogger.java  |   77 -
 .../utils/CompactionSeparateFileUtils.java         |  250 --
 .../engine/compaction/utils/CompactionUtils.java   |  427 ---
 .../db/engine/fileSystem/SystemFileFactory.java    |   69 -
 .../iotdb/db/engine/flush/CloseFileListener.java   |   28 -
 .../iotdb/db/engine/flush/FlushListener.java       |   46 -
 .../apache/iotdb/db/engine/flush/FlushManager.java |  176 --
 .../iotdb/db/engine/flush/FlushManagerMBean.java   |   31 -
 .../iotdb/db/engine/flush/MemTableFlushTask.java   |  328 ---
 .../iotdb/db/engine/flush/NotifyFlushMemTable.java |   46 -
 .../iotdb/db/engine/flush/TsFileFlushPolicy.java   |   48 -
 .../db/engine/flush/pool/AbstractPoolManager.java  |   91 -
 .../engine/flush/pool/FlushSubTaskPoolManager.java |   74 -
 .../db/engine/flush/pool/FlushTaskPoolManager.java |   76 -
 .../iotdb/db/engine/memtable/AbstractMemTable.java |  359 ---
 .../apache/iotdb/db/engine/memtable/IMemTable.java |  140 -
 .../db/engine/memtable/IWritableMemChunk.java      |   95 -
 .../db/engine/memtable/PrimitiveMemTable.java      |   66 -
 .../iotdb/db/engine/memtable/WritableMemChunk.java |  220 --
 .../iotdb/db/engine/merge/manage/MergeContext.java |   90 -
 .../iotdb/db/engine/merge/manage/MergeFuture.java  |  151 -
 .../iotdb/db/engine/merge/manage/MergeManager.java |  410 ---
 .../db/engine/merge/manage/MergeManagerMBean.java  |   26 -
 .../db/engine/merge/manage/MergeResource.java      |  293 --
 .../db/engine/merge/manage/MergeThreadPool.java    |   54 -
 .../apache/iotdb/db/engine/merge/package-info.java |   25 -
 .../iotdb/db/engine/merge/recover/LogAnalyzer.java |  326 ---
 .../iotdb/db/engine/merge/recover/MergeLogger.java |  131 -
 .../merge/selector/IFileQueryMemMeasurement.java   |   36 -
 .../engine/merge/selector/IMergeFileSelector.java  |   35 -
 .../engine/merge/selector/IMergePathSelector.java  |   31 -
 .../merge/selector/MaxFileMergeFileSelector.java   |  359 ---
 .../merge/selector/MaxSeriesMergeFileSelector.java |  115 -
 .../engine/merge/selector/MergeFileStrategy.java   |   27 -
 .../engine/merge/selector/NaivePathSelector.java   |   55 -
 .../iotdb/db/engine/merge/task/MergeCallback.java  |   40 -
 .../iotdb/db/engine/merge/task/MergeFileTask.java  |  408 ---
 .../db/engine/merge/task/MergeMultiChunkTask.java  |  740 -----
 .../iotdb/db/engine/merge/task/MergeTask.java      |  276 --
 .../db/engine/merge/task/RecoverMergeTask.java     |  300 --
 .../iotdb/db/engine/modification/Deletion.java     |  107 -
 .../iotdb/db/engine/modification/Modification.java |   97 -
 .../db/engine/modification/ModificationFile.java   |  170 --
 .../io/LocalTextModificationAccessor.java          |  200 --
 .../engine/modification/io/ModificationReader.java |   39 -
 .../engine/modification/io/ModificationWriter.java |   45 -
 .../iotdb/db/engine/modification/package-info.java |   21 -
 .../db/engine/querycontext/QueryDataSource.java    |   78 -
 .../db/engine/querycontext/ReadOnlyMemChunk.java   |  158 --
 .../db/engine/storagegroup/StorageGroupInfo.java   |  135 -
 .../engine/storagegroup/StorageGroupProcessor.java | 2989 --------------------
 .../iotdb/db/engine/storagegroup/TsFileLock.java   |  110 -
 .../db/engine/storagegroup/TsFileProcessor.java    | 1209 --------
 .../engine/storagegroup/TsFileProcessorInfo.java   |   52 -
 .../db/engine/storagegroup/TsFileResource.java     |  898 ------
 .../storagegroup/timeindex/DeviceTimeIndex.java    |  307 --
 .../storagegroup/timeindex/FileTimeIndex.java      |  211 --
 .../engine/storagegroup/timeindex/ITimeIndex.java  |  150 -
 .../storagegroup/timeindex/TimeIndexLevel.java     |   52 -
 .../virtualSg/HashVirtualPartitioner.java          |   63 -
 .../storagegroup/virtualSg/VirtualPartitioner.java |   39 -
 .../virtualSg/VirtualStorageGroupManager.java      |  408 ---
 .../iotdb/db/engine/trigger/api/TriggerEvent.java  |   35 -
 .../db/engine/upgrade/UpgradeCheckStatus.java      |   40 -
 .../apache/iotdb/db/engine/upgrade/UpgradeLog.java |   88 -
 .../iotdb/db/engine/upgrade/UpgradeTask.java       |  169 --
 .../version/SimpleFileVersionController.java       |  156 -
 .../engine/version/SysTimeVersionController.java   |   38 -
 .../iotdb/db/engine/version/VersionController.java |   44 -
 .../iotdb/db/exception/BatchProcessException.java  |   39 -
 .../exception/DiskSpaceInsufficientException.java  |   34 -
 .../apache/iotdb/db/exception/IoTDBException.java  |   67 -
 .../db/exception/LoadConfigurationException.java   |   36 -
 .../iotdb/db/exception/LoadEmptyFileException.java |   27 -
 .../iotdb/db/exception/LoadFileException.java      |   33 -
 .../apache/iotdb/db/exception/MergeException.java  |   31 -
 .../db/exception/PartitionViolationException.java  |   27 -
 .../db/exception/QueryIdNotExsitException.java     |   28 -
 .../exception/QueryInBatchStatementException.java  |   33 -
 .../iotdb/db/exception/ShutdownException.java      |   40 -
 .../iotdb/db/exception/StartupException.java       |   40 -
 .../iotdb/db/exception/StorageEngineException.java |   46 -
 .../exception/StorageGroupProcessorException.java  |   34 -
 .../db/exception/SyncConnectionException.java      |   38 -
 .../SyncDeviceOwnerConflictException.java          |   39 -
 .../iotdb/db/exception/SystemCheckException.java   |   33 -
 .../db/exception/TsFileProcessorException.java     |   34 -
 .../db/exception/UDFRegistrationException.java     |   34 -
 .../iotdb/db/exception/WriteProcessException.java  |   47 -
 .../db/exception/WriteProcessRejectException.java  |   34 -
 .../exception/index/DistanceMetricException.java   |   28 -
 .../index/IllegalIndexParamException.java          |   28 -
 .../db/exception/index/IndexManagerException.java  |   34 -
 .../db/exception/index/IndexRuntimeException.java  |   32 -
 .../db/exception/index/QueryIndexException.java    |   29 -
 .../index/UnsupportedIndexTypeException.java       |   32 -
 .../metadata/AliasAlreadyExistException.java       |   35 -
 .../metadata/DataTypeMismatchException.java        |   31 -
 .../exception/metadata/DeleteFailedException.java  |   39 -
 .../metadata/IllegalParameterOfPathException.java  |   30 -
 .../exception/metadata/IllegalPathException.java   |   32 -
 .../db/exception/metadata/MetadataException.java   |   63 -
 .../metadata/PathAlreadyExistException.java        |   35 -
 .../exception/metadata/PathNotExistException.java  |   52 -
 .../metadata/StorageGroupAlreadySetException.java  |   43 -
 .../metadata/StorageGroupNotSetException.java      |   34 -
 .../exception/query/LogicalOperatorException.java  |   54 -
 .../exception/query/LogicalOptimizeException.java  |   45 -
 .../db/exception/query/OutOfTTLException.java      |   40 -
 .../iotdb/db/exception/query/PathException.java    |   38 -
 .../exception/query/PathNumOverLimitException.java |   37 -
 .../db/exception/query/QueryProcessException.java  |   48 -
 .../query/QueryTimeoutRuntimeException.java        |   34 -
 .../query/UnSupportedFillTypeException.java        |   33 -
 .../exception/runtime/FlushRunTimeException.java   |   29 -
 .../db/exception/runtime/RPCServiceException.java  |   32 -
 .../db/exception/runtime/SQLParserException.java   |   35 -
 .../runtime/StorageEngineFailureException.java     |   33 -
 .../iotdb/db/index/common/IndexConstant.java       |   36 -
 .../apache/iotdb/db/index/common/IndexType.java    |   84 -
 .../apache/iotdb/db/index/common/IndexUtils.java   |   35 -
 .../apache/iotdb/db/metadata/MLogTxtWriter.java    |  267 --
 .../org/apache/iotdb/db/metadata/MManager.java     | 1966 -------------
 .../java/org/apache/iotdb/db/metadata/MTree.java   | 1572 ----------
 .../apache/iotdb/db/metadata/MeasurementMeta.java  |   85 -
 .../org/apache/iotdb/db/metadata/MetaUtils.java    |  140 -
 .../org/apache/iotdb/db/metadata/Metadata.java     |  120 -
 .../apache/iotdb/db/metadata/MetadataConstant.java |   46 -
 .../iotdb/db/metadata/MetadataOperationType.java   |   36 -
 .../org/apache/iotdb/db/metadata/PartialPath.java  |  315 ---
 .../org/apache/iotdb/db/metadata/TagLogFile.java   |  169 --
 .../iotdb/db/metadata/logfile/MLogReader.java      |   75 -
 .../iotdb/db/metadata/logfile/MLogTxtReader.java   |   78 -
 .../iotdb/db/metadata/logfile/MLogWriter.java      |  418 ---
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |  306 --
 .../iotdb/db/metadata/mnode/MeasurementMNode.java  |  170 --
 .../iotdb/db/metadata/mnode/StorageGroupMNode.java |   63 -
 .../apache/iotdb/db/metrics/server/JettyUtil.java  |  107 -
 .../iotdb/db/metrics/server/MetricsSystem.java     |   82 -
 .../iotdb/db/metrics/server/QueryServlet.java      |   56 -
 .../iotdb/db/metrics/server/ServerArgument.java    |  324 ---
 .../iotdb/db/metrics/server/SqlArgument.java       |   84 -
 .../apache/iotdb/db/metrics/sink/ConsoleSink.java  |   54 -
 .../iotdb/db/metrics/sink/MetricsServletSink.java  |   53 -
 .../org/apache/iotdb/db/metrics/sink/Sink.java     |   28 -
 .../apache/iotdb/db/metrics/source/JvmSource.java  |   50 -
 .../iotdb/db/metrics/source/MetricsSource.java     |  134 -
 .../org/apache/iotdb/db/metrics/source/Source.java |   24 -
 .../apache/iotdb/db/metrics/ui/MetricsPage.java    |  187 --
 .../apache/iotdb/db/metrics/ui/MetricsWebUI.java   |   68 -
 .../org/apache/iotdb/db/monitor/IStatistic.java    |   54 -
 .../apache/iotdb/db/monitor/MonitorConstants.java  |   47 -
 .../org/apache/iotdb/db/monitor/StatMonitor.java   |  308 --
 .../apache/iotdb/db/monitor/StatMonitorMBean.java  |   38 -
 .../apache/iotdb/db/mqtt/BrokerAuthenticator.java  |   47 -
 .../apache/iotdb/db/mqtt/JSONPayloadFormatter.java |   84 -
 .../java/org/apache/iotdb/db/mqtt/Message.java     |   76 -
 .../apache/iotdb/db/mqtt/PayloadFormatManager.java |   45 -
 .../org/apache/iotdb/db/mqtt/PayloadFormatter.java |   40 -
 .../org/apache/iotdb/db/mqtt/PublishHandler.java   |  128 -
 .../main/java/org/apache/iotdb/db/qp/Planner.java  |  227 --
 .../apache/iotdb/db/qp/constant/SQLConstant.java   |  294 --
 .../apache/iotdb/db/qp/executor/IPlanExecutor.java |  127 -
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  | 1790 ------------
 .../org/apache/iotdb/db/qp/logical/Operator.java   |  156 -
 .../apache/iotdb/db/qp/logical/RootOperator.java   |   30 -
 .../db/qp/logical/crud/BasicFunctionOperator.java  |  170 --
 .../db/qp/logical/crud/BasicOperatorType.java      |  189 --
 .../db/qp/logical/crud/DeleteDataOperator.java     |   49 -
 .../iotdb/db/qp/logical/crud/FilterOperator.java   |  301 --
 .../iotdb/db/qp/logical/crud/FromOperator.java     |   45 -
 .../iotdb/db/qp/logical/crud/FunctionOperator.java |   48 -
 .../iotdb/db/qp/logical/crud/InOperator.java       |  210 --
 .../iotdb/db/qp/logical/crud/InsertOperator.java   |   56 -
 .../iotdb/db/qp/logical/crud/QueryOperator.java    |  253 --
 .../iotdb/db/qp/logical/crud/SFWOperator.java      |   98 -
 .../iotdb/db/qp/logical/crud/SelectOperator.java   |  116 -
 .../db/qp/logical/sys/AlterTimeSeriesOperator.java |  106 -
 .../iotdb/db/qp/logical/sys/AuthorOperator.java    |  225 --
 .../db/qp/logical/sys/ClearCacheOperator.java      |   29 -
 .../iotdb/db/qp/logical/sys/CountOperator.java     |   46 -
 .../db/qp/logical/sys/CreateFunctionOperator.java  |   58 -
 .../db/qp/logical/sys/CreateIndexOperator.java     |   61 -
 .../db/qp/logical/sys/CreateSnapshotOperator.java  |   30 -
 .../qp/logical/sys/CreateTimeSeriesOperator.java   |  108 -
 .../db/qp/logical/sys/CreateTriggerOperator.java   |   82 -
 .../iotdb/db/qp/logical/sys/DataAuthOperator.java  |   43 -
 .../db/qp/logical/sys/DeletePartitionOperator.java |   52 -
 .../qp/logical/sys/DeleteStorageGroupOperator.java |   42 -
 .../qp/logical/sys/DeleteTimeSeriesOperator.java   |   43 -
 .../db/qp/logical/sys/DropFunctionOperator.java    |   40 -
 .../iotdb/db/qp/logical/sys/DropIndexOperator.java |   41 -
 .../db/qp/logical/sys/DropTriggerOperator.java     |   40 -
 .../iotdb/db/qp/logical/sys/FlushOperator.java     |   52 -
 .../iotdb/db/qp/logical/sys/KillQueryOperator.java |   42 -
 .../qp/logical/sys/LoadConfigurationOperator.java  |   43 -
 .../iotdb/db/qp/logical/sys/LoadDataOperator.java  |   46 -
 .../iotdb/db/qp/logical/sys/LoadFilesOperator.java |   51 -
 .../iotdb/db/qp/logical/sys/MergeOperator.java     |   29 -
 .../iotdb/db/qp/logical/sys/MoveFileOperator.java  |   45 -
 .../db/qp/logical/sys/RemoveFileOperator.java      |   39 -
 .../db/qp/logical/sys/SetStorageGroupOperator.java |   40 -
 .../iotdb/db/qp/logical/sys/SetTTLOperator.java    |   51 -
 .../db/qp/logical/sys/ShowChildNodesOperator.java  |   36 -
 .../db/qp/logical/sys/ShowChildPathsOperator.java  |   36 -
 .../db/qp/logical/sys/ShowDevicesOperator.java     |   63 -
 .../db/qp/logical/sys/ShowFunctionsOperator.java   |   37 -
 .../db/qp/logical/sys/ShowMergeStatusOperator.java |   30 -
 .../iotdb/db/qp/logical/sys/ShowOperator.java      |   34 -
 .../qp/logical/sys/ShowStorageGroupOperator.java   |   36 -
 .../iotdb/db/qp/logical/sys/ShowTTLOperator.java   |   40 -
 .../db/qp/logical/sys/ShowTimeSeriesOperator.java  |   88 -
 .../db/qp/logical/sys/ShowTriggersOperator.java    |   39 -
 .../db/qp/logical/sys/StartTriggerOperator.java    |   40 -
 .../db/qp/logical/sys/StopTriggerOperator.java     |   40 -
 .../iotdb/db/qp/logical/sys/TracingOperator.java   |   36 -
 .../org/apache/iotdb/db/qp/physical/BatchPlan.java |   53 -
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |  433 ---
 .../iotdb/db/qp/physical/crud/AggregationPlan.java |  137 -
 .../db/qp/physical/crud/AlignByDevicePlan.java     |  150 -
 .../db/qp/physical/crud/DeletePartitionPlan.java   |   53 -
 .../iotdb/db/qp/physical/crud/DeletePlan.java      |  164 --
 .../iotdb/db/qp/physical/crud/FillQueryPlan.java   |   61 -
 .../db/qp/physical/crud/GroupByTimeFillPlan.java   |   43 -
 .../iotdb/db/qp/physical/crud/GroupByTimePlan.java |   99 -
 .../db/qp/physical/crud/InsertMultiTabletPlan.java |  367 ---
 .../iotdb/db/qp/physical/crud/InsertPlan.java      |  175 --
 .../iotdb/db/qp/physical/crud/InsertRowPlan.java   |  571 ----
 .../physical/crud/InsertRowsOfOneDevicePlan.java   |  197 --
 .../iotdb/db/qp/physical/crud/InsertRowsPlan.java  |  274 --
 .../db/qp/physical/crud/InsertTabletPlan.java      |  604 ----
 .../iotdb/db/qp/physical/crud/LastQueryPlan.java   |   56 -
 .../iotdb/db/qp/physical/crud/QueryIndexPlan.java  |   76 -
 .../iotdb/db/qp/physical/crud/QueryPlan.java       |  139 -
 .../db/qp/physical/crud/RawDataQueryPlan.java      |  109 -
 .../apache/iotdb/db/qp/physical/crud/UDFPlan.java  |   48 -
 .../apache/iotdb/db/qp/physical/crud/UDTFPlan.java |  141 -
 .../db/qp/physical/sys/AlterTimeSeriesPlan.java    |  212 --
 .../iotdb/db/qp/physical/sys/AuthorPlan.java       |  422 ---
 .../iotdb/db/qp/physical/sys/ChangeAliasPlan.java  |  115 -
 .../db/qp/physical/sys/ChangeTagOffsetPlan.java    |  115 -
 .../iotdb/db/qp/physical/sys/ClearCachePlan.java   |   38 -
 .../apache/iotdb/db/qp/physical/sys/CountPlan.java |   53 -
 .../db/qp/physical/sys/CreateFunctionPlan.java     |   58 -
 .../iotdb/db/qp/physical/sys/CreateIndexPlan.java  |  180 --
 .../qp/physical/sys/CreateMultiTimeSeriesPlan.java |  383 ---
 .../db/qp/physical/sys/CreateSnapshotPlan.java     |   39 -
 .../db/qp/physical/sys/CreateTimeSeriesPlan.java   |  311 --
 .../db/qp/physical/sys/CreateTriggerPlan.java      |   77 -
 .../iotdb/db/qp/physical/sys/DataAuthPlan.java     |  100 -
 .../db/qp/physical/sys/DeleteStorageGroupPlan.java |   84 -
 .../db/qp/physical/sys/DeleteTimeSeriesPlan.java   |  106 -
 .../iotdb/db/qp/physical/sys/DropFunctionPlan.java |   46 -
 .../iotdb/db/qp/physical/sys/DropIndexPlan.java    |  129 -
 .../iotdb/db/qp/physical/sys/DropTriggerPlan.java  |   46 -
 .../apache/iotdb/db/qp/physical/sys/FlushPlan.java |  244 --
 .../iotdb/db/qp/physical/sys/KillQueryPlan.java    |   45 -
 .../db/qp/physical/sys/LoadConfigurationPlan.java  |  144 -
 .../iotdb/db/qp/physical/sys/LoadDataPlan.java     |   73 -
 .../apache/iotdb/db/qp/physical/sys/MNodePlan.java |  116 -
 .../db/qp/physical/sys/MeasurementMNodePlan.java   |  153 -
 .../apache/iotdb/db/qp/physical/sys/MergePlan.java |   42 -
 .../iotdb/db/qp/physical/sys/OperateFilePlan.java  |   91 -
 .../db/qp/physical/sys/SetStorageGroupPlan.java    |  100 -
 .../iotdb/db/qp/physical/sys/SetTTLPlan.java       |  102 -
 .../db/qp/physical/sys/ShowChildNodesPlan.java     |   39 -
 .../db/qp/physical/sys/ShowChildPathsPlan.java     |   39 -
 .../iotdb/db/qp/physical/sys/ShowDevicesPlan.java  |   65 -
 .../db/qp/physical/sys/ShowFunctionsPlan.java      |   34 -
 .../db/qp/physical/sys/ShowMergeStatusPlan.java    |   27 -
 .../apache/iotdb/db/qp/physical/sys/ShowPlan.java  |  122 -
 .../qp/physical/sys/ShowQueryProcesslistPlan.java  |   26 -
 .../db/qp/physical/sys/ShowStorageGroupPlan.java   |   36 -
 .../iotdb/db/qp/physical/sys/ShowTTLPlan.java      |   42 -
 .../db/qp/physical/sys/ShowTimeSeriesPlan.java     |  123 -
 .../iotdb/db/qp/physical/sys/ShowTriggersPlan.java |   35 -
 .../iotdb/db/qp/physical/sys/StartTriggerPlan.java |   46 -
 .../iotdb/db/qp/physical/sys/StopTriggerPlan.java  |   46 -
 .../db/qp/physical/sys/StorageGroupMNodePlan.java  |  110 -
 .../iotdb/db/qp/physical/sys/TracingPlan.java      |   45 -
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    | 2142 --------------
 .../iotdb/db/qp/strategy/LogicalGenerator.java     |   70 -
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |  965 -------
 .../apache/iotdb/db/qp/strategy/SQLParseError.java |   40 -
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |  492 ----
 .../qp/strategy/optimizer/DnfFilterOptimizer.java  |  165 --
 .../db/qp/strategy/optimizer/IFilterOptimizer.java |   29 -
 .../qp/strategy/optimizer/ILogicalOptimizer.java   |   31 -
 .../optimizer/MergeSingleFilterOptimizer.java      |  179 --
 .../qp/strategy/optimizer/RemoveNotOptimizer.java  |  102 -
 .../apache/iotdb/db/qp/utils/DatetimeUtils.java    |  625 ----
 .../db/query/aggregation/AggregateResult.java      |  317 ---
 .../db/query/aggregation/AggregationType.java      |  107 -
 .../db/query/aggregation/impl/AvgAggrResult.java   |  202 --
 .../db/query/aggregation/impl/CountAggrResult.java |  119 -
 .../aggregation/impl/FirstValueAggrResult.java     |  151 -
 .../aggregation/impl/FirstValueDescAggrResult.java |   81 -
 .../aggregation/impl/LastValueAggrResult.java      |  132 -
 .../aggregation/impl/LastValueDescAggrResult.java  |  111 -
 .../query/aggregation/impl/MaxTimeAggrResult.java  |  112 -
 .../aggregation/impl/MaxTimeDescAggrResult.java    |   93 -
 .../query/aggregation/impl/MaxValueAggrResult.java |  119 -
 .../query/aggregation/impl/MinTimeAggrResult.java  |  130 -
 .../aggregation/impl/MinTimeDescAggrResult.java    |   69 -
 .../query/aggregation/impl/MinValueAggrResult.java |  117 -
 .../db/query/aggregation/impl/SumAggrResult.java   |  144 -
 .../iotdb/db/query/context/QueryContext.java       |  112 -
 .../iotdb/db/query/control/FileReaderManager.java  |  289 --
 .../iotdb/db/query/control/QueryFileManager.java   |  125 -
 .../db/query/control/QueryResourceManager.java     |  237 --
 .../iotdb/db/query/control/QueryTimeManager.java   |  186 --
 .../iotdb/db/query/control/TracingManager.java     |  234 --
 .../db/query/dataset/AlignByDeviceDataSet.java     |  274 --
 .../db/query/dataset/DirectAlignByTimeDataSet.java |   34 -
 .../db/query/dataset/DirectNonAlignDataSet.java    |   32 -
 .../apache/iotdb/db/query/dataset/ListDataSet.java |   61 -
 .../db/query/dataset/NonAlignEngineDataSet.java    |  353 ---
 .../dataset/RawQueryDataSetWithValueFilter.java    |  217 --
 .../dataset/RawQueryDataSetWithoutValueFilter.java |  507 ----
 .../apache/iotdb/db/query/dataset/ShowDataSet.java |   79 -
 .../iotdb/db/query/dataset/ShowDevicesDataSet.java |   77 -
 .../iotdb/db/query/dataset/ShowDevicesResult.java  |   74 -
 .../apache/iotdb/db/query/dataset/ShowResult.java  |   49 -
 .../db/query/dataset/ShowTimeSeriesResult.java     |  168 --
 .../db/query/dataset/ShowTimeseriesDataSet.java    |  109 -
 .../iotdb/db/query/dataset/SingleDataSet.java      |   52 -
 .../iotdb/db/query/dataset/UDFInputDataSet.java    |   34 -
 .../db/query/dataset/UDTFAlignByTimeDataSet.java   |  303 --
 .../apache/iotdb/db/query/dataset/UDTFDataSet.java |  177 --
 .../db/query/dataset/UDTFNonAlignDataSet.java      |  216 --
 .../dataset/groupby/GroupByEngineDataSet.java      |  181 --
 .../db/query/dataset/groupby/GroupByExecutor.java  |   40 -
 .../query/dataset/groupby/GroupByFillDataSet.java  |  220 --
 .../query/dataset/groupby/GroupByTimeDataSet.java  |   97 -
 .../groupby/GroupByWithValueFilterDataSet.java     |  284 --
 .../groupby/GroupByWithoutValueFilterDataSet.java  |  193 --
 .../dataset/groupby/LocalGroupByExecutor.java      |  353 ---
 .../db/query/executor/AggregationExecutor.java     |  514 ----
 .../iotdb/db/query/executor/FillQueryExecutor.java |  131 -
 .../iotdb/db/query/executor/IQueryRouter.java      |   68 -
 .../iotdb/db/query/executor/LastQueryExecutor.java |  290 --
 .../iotdb/db/query/executor/QueryRouter.java       |  304 --
 .../db/query/executor/RawDataQueryExecutor.java    |  221 --
 .../iotdb/db/query/executor/UDTFQueryExecutor.java |  109 -
 .../apache/iotdb/db/query/executor/fill/IFill.java |   73 -
 .../db/query/executor/fill/LastPointReader.java    |  242 --
 .../iotdb/db/query/executor/fill/LinearFill.java   |  234 --
 .../iotdb/db/query/executor/fill/PreviousFill.java |  120 -
 .../db/query/externalsort/ExternalSortJob.java     |   43 -
 .../query/externalsort/ExternalSortJobEngine.java  |   52 -
 .../db/query/externalsort/ExternalSortJobPart.java |   43 -
 .../externalsort/ExternalSortJobScheduler.java     |   40 -
 .../iotdb/db/query/externalsort/LineMerger.java    |   55 -
 .../MultiSourceExternalSortJobPart.java            |   50 -
 .../externalsort/SimpleExternalSortEngine.java     |  178 --
 .../SingleSourceExternalSortJobPart.java           |   39 -
 .../adapter/ByTimestampReaderAdapter.java          |   73 -
 .../serialize/IExternalSortFileDeserializer.java   |   32 -
 .../serialize/IExternalSortFileSerializer.java     |   30 -
 .../FixLengthIExternalSortFileDeserializer.java    |  267 --
 .../impl/FixLengthTimeValuePairSerializer.java     |  169 --
 .../db/query/factory/AggregateResultFactory.java   |  143 -
 .../apache/iotdb/db/query/filter/TsFileFilter.java |   31 -
 .../iotdb/db/query/pool/QueryTaskPoolManager.java  |   78 -
 .../db/query/reader/chunk/ChunkDataIterator.java   |   79 -
 .../db/query/reader/chunk/ChunkReaderWrap.java     |   96 -
 .../db/query/reader/chunk/DiskChunkLoader.java     |   49 -
 .../reader/chunk/DiskChunkReaderByTimestamp.java   |   82 -
 .../db/query/reader/chunk/MemChunkLoader.java      |   49 -
 .../db/query/reader/chunk/MemChunkReader.java      |  106 -
 .../iotdb/db/query/reader/chunk/MemPageReader.java |   79 -
 .../chunk/metadata/DiskChunkMetadataLoader.java    |  122 -
 .../chunk/metadata/MemChunkMetadataLoader.java     |   76 -
 .../resource/CachedUnseqResourceMergeReader.java   |   42 -
 .../reader/series/BaseManagedSeriesReader.java     |   45 -
 .../db/query/reader/series/IAggregateReader.java   |   57 -
 .../db/query/reader/series/IReaderByTimestamp.java |   47 -
 .../query/reader/series/ManagedSeriesReader.java   |   37 -
 .../query/reader/series/SeriesAggregateReader.java |  147 -
 .../reader/series/SeriesRawDataBatchReader.java    |  195 --
 .../reader/series/SeriesRawDataPointReader.java    |   87 -
 .../iotdb/db/query/reader/series/SeriesReader.java | 1200 --------
 .../reader/series/SeriesReaderByTimestamp.java     |  169 --
 .../universal/CachedPriorityMergeReader.java       |   96 -
 .../reader/universal/DescPriorityMergeReader.java  |   55 -
 .../iotdb/db/query/reader/universal/Element.java   |   72 -
 .../reader/universal/PriorityMergeReader.java      |  180 --
 .../query/timegenerator/ServerTimeGenerator.java   |  149 -
 .../org/apache/iotdb/db/query/udf/api/UDF.java     |   40 -
 .../org/apache/iotdb/db/query/udf/api/UDTF.java    |  120 -
 .../apache/iotdb/db/query/udf/api/access/Row.java  |  128 -
 .../iotdb/db/query/udf/api/access/RowIterator.java |   47 -
 .../iotdb/db/query/udf/api/access/RowWindow.java   |   62 -
 .../db/query/udf/api/collector/PointCollector.java |  138 -
 .../api/customizer/config/UDFConfigurations.java   |   38 -
 .../api/customizer/config/UDTFConfigurations.java  |  106 -
 .../parameter/UDFParameterValidator.java           |  211 --
 .../api/customizer/parameter/UDFParameters.java    |  153 -
 .../api/customizer/strategy/AccessStrategy.java    |   58 -
 .../strategy/RowByRowAccessStrategy.java           |   61 -
 .../strategy/SlidingSizeWindowAccessStrategy.java  |  124 -
 .../strategy/SlidingTimeWindowAccessStrategy.java  |  261 --
 .../UDFAttributeNotProvidedException.java          |   27 -
 .../db/query/udf/api/exception/UDFException.java   |   31 -
 .../UDFInputSeriesDataTypeNotValidException.java   |   43 -
 .../UDFInputSeriesIndexNotValidException.java      |   30 -
 .../UDFInputSeriesNumberNotValidException.java     |   38 -
 .../exception/UDFParameterNotValidException.java   |   27 -
 .../db/query/udf/builtin/BuiltinFunction.java      |   73 -
 .../apache/iotdb/db/query/udf/builtin/UDTFAbs.java |   70 -
 .../iotdb/db/query/udf/builtin/UDTFAcos.java       |   28 -
 .../iotdb/db/query/udf/builtin/UDTFAsin.java       |   28 -
 .../iotdb/db/query/udf/builtin/UDTFAtan.java       |   28 -
 .../iotdb/db/query/udf/builtin/UDTFBottomK.java    |  115 -
 .../iotdb/db/query/udf/builtin/UDTFCeil.java       |   28 -
 .../db/query/udf/builtin/UDTFCommonDerivative.java |   64 -
 .../udf/builtin/UDTFCommonValueDifference.java     |   62 -
 .../iotdb/db/query/udf/builtin/UDTFContains.java   |   56 -
 .../apache/iotdb/db/query/udf/builtin/UDTFCos.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFDegrees.java    |   28 -
 .../iotdb/db/query/udf/builtin/UDTFDerivative.java |   58 -
 .../apache/iotdb/db/query/udf/builtin/UDTFExp.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFFloor.java      |   28 -
 .../apache/iotdb/db/query/udf/builtin/UDTFLog.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFLog10.java      |   28 -
 .../iotdb/db/query/udf/builtin/UDTFMatches.java    |   58 -
 .../iotdb/db/query/udf/builtin/UDTFMath.java       |   90 -
 .../udf/builtin/UDTFNonNegativeDerivative.java     |   64 -
 .../builtin/UDTFNonNegativeValueDifference.java    |   62 -
 .../iotdb/db/query/udf/builtin/UDTFRadians.java    |   28 -
 .../iotdb/db/query/udf/builtin/UDTFRound.java      |   28 -
 .../iotdb/db/query/udf/builtin/UDTFSelectK.java    |  176 --
 .../iotdb/db/query/udf/builtin/UDTFSign.java       |   28 -
 .../apache/iotdb/db/query/udf/builtin/UDTFSin.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFSqrt.java       |   28 -
 .../apache/iotdb/db/query/udf/builtin/UDTFTan.java |   28 -
 .../db/query/udf/builtin/UDTFTimeDifference.java   |   57 -
 .../iotdb/db/query/udf/builtin/UDTFTopK.java       |  111 -
 .../db/query/udf/builtin/UDTFValueDifference.java  |   52 -
 .../iotdb/db/query/udf/builtin/UDTFValueTrend.java |   74 -
 .../iotdb/db/query/udf/core/access/RowImpl.java    |   97 -
 .../db/query/udf/core/access/RowIteratorImpl.java  |   62 -
 .../db/query/udf/core/access/RowWindowImpl.java    |   80 -
 .../db/query/udf/core/context/UDFContext.java      |  142 -
 .../db/query/udf/core/executor/UDTFExecutor.java   |  117 -
 .../iotdb/db/query/udf/core/input/InputLayer.java  |  571 ----
 .../iotdb/db/query/udf/core/input/SafetyLine.java  |   77 -
 .../db/query/udf/core/reader/LayerPointReader.java |   49 -
 .../db/query/udf/core/reader/LayerRowReader.java   |   39 -
 .../udf/core/reader/LayerRowWindowReader.java      |   37 -
 .../core/transformer/RawQueryPointTransformer.java |   73 -
 .../db/query/udf/core/transformer/Transformer.java |   94 -
 .../core/transformer/UDFQueryRowTransformer.java   |   46 -
 .../transformer/UDFQueryRowWindowTransformer.java  |   47 -
 .../udf/core/transformer/UDFQueryTransformer.java  |  102 -
 .../iotdb/db/query/udf/datastructure/Cache.java    |   96 -
 .../query/udf/datastructure/SerializableList.java  |  166 --
 .../primitive/ElasticSerializableIntList.java      |   99 -
 .../query/udf/datastructure/primitive/IntList.java |   33 -
 .../primitive/SerializableIntList.java             |  133 -
 .../datastructure/primitive/WrappedIntArray.java   |   51 -
 .../row/ElasticSerializableRowRecordList.java      |  261 --
 .../row/SerializableRowRecordList.java             |  237 --
 .../tv/ElasticSerializableBinaryTVList.java        |  132 -
 .../tv/ElasticSerializableTVList.java              |  319 ---
 .../datastructure/tv/SerializableBinaryTVList.java |   82 -
 .../tv/SerializableBooleanTVList.java              |   72 -
 .../datastructure/tv/SerializableDoubleTVList.java |   72 -
 .../datastructure/tv/SerializableFloatTVList.java  |   72 -
 .../datastructure/tv/SerializableIntTVList.java    |   72 -
 .../datastructure/tv/SerializableLongTVList.java   |   72 -
 .../udf/datastructure/tv/SerializableTVList.java   |  100 -
 .../udf/service/TemporaryQueryDataFileService.java |  141 -
 .../iotdb/db/query/udf/service/UDFClassLoader.java |   85 -
 .../query/udf/service/UDFClassLoaderManager.java   |  125 -
 .../iotdb/db/query/udf/service/UDFLogWriter.java   |   70 -
 .../udf/service/UDFRegistrationInformation.java    |   82 -
 .../query/udf/service/UDFRegistrationService.java  |  431 ---
 .../apache/iotdb/db/rescon/CachedStringPool.java   |   42 -
 .../apache/iotdb/db/rescon/MemTableManager.java    |  111 -
 .../iotdb/db/rescon/PrimitiveArrayManager.java     |  312 --
 .../org/apache/iotdb/db/rescon/SystemInfo.java     |  254 --
 .../apache/iotdb/db/rescon/TVListAllocator.java    |   94 -
 .../iotdb/db/rescon/TVListAllocatorMBean.java      |   24 -
 .../org/apache/iotdb/db/rescon/package-info.java   |   24 -
 .../iotdb/db/separation/statistics/Collector.java  |   14 -
 .../statistics/SeparationTuningClient.java         |   87 -
 .../statistics/SeparationTunningService.java       | 1105 --------
 .../java/org/apache/iotdb/db/service/IService.java |   49 -
 .../java/org/apache/iotdb/db/service/IoTDB.java    |  207 --
 .../org/apache/iotdb/db/service/IoTDBMBean.java    |   27 -
 .../apache/iotdb/db/service/IoTDBShutdownHook.java |   39 -
 .../org/apache/iotdb/db/service/JMXService.java    |  101 -
 .../org/apache/iotdb/db/service/MQTTService.java   |  115 -
 .../apache/iotdb/db/service/MetricsService.java    |  207 --
 .../iotdb/db/service/MetricsServiceMBean.java      |   32 -
 .../org/apache/iotdb/db/service/RPCService.java    |  103 -
 .../apache/iotdb/db/service/RPCServiceMBean.java   |   34 -
 .../iotdb/db/service/RPCServiceThriftHandler.java  |   52 -
 .../apache/iotdb/db/service/RegisterManager.java   |   85 -
 .../org/apache/iotdb/db/service/ServiceType.java   |   74 -
 .../org/apache/iotdb/db/service/StartupCheck.java  |   28 -
 .../org/apache/iotdb/db/service/StartupChecks.java |   78 -
 .../org/apache/iotdb/db/service/StaticResps.java   |   59 -
 .../org/apache/iotdb/db/service/TSServiceImpl.java | 2021 -------------
 .../org/apache/iotdb/db/service/UpgradeSevice.java |  119 -
 .../iotdb/db/service/thrift/ThriftService.java     |  163 --
 .../db/service/thrift/ThriftServiceThread.java     |  180 --
 .../apache/iotdb/db/sync/conf/SyncConstant.java    |   81 -
 .../iotdb/db/sync/conf/SyncSenderConfig.java       |  127 -
 .../iotdb/db/sync/conf/SyncSenderDescriptor.java   |  124 -
 .../org/apache/iotdb/db/sync/package-info.java     |   38 -
 .../iotdb/db/sync/receiver/SyncServerManager.java  |  123 -
 .../db/sync/receiver/SyncServerManagerMBean.java   |   34 -
 .../db/sync/receiver/SyncServerThriftHandler.java  |   56 -
 .../iotdb/db/sync/receiver/load/FileLoader.java    |  203 --
 .../db/sync/receiver/load/FileLoaderManager.java   |  213 --
 .../iotdb/db/sync/receiver/load/IFileLoader.java   |   50 -
 .../iotdb/db/sync/receiver/load/ILoadLogger.java   |   57 -
 .../iotdb/db/sync/receiver/load/LoadLogger.java    |   72 -
 .../iotdb/db/sync/receiver/load/LoadType.java      |   25 -
 .../receiver/recover/ISyncReceiverLogAnalyzer.java |   33 -
 .../sync/receiver/recover/ISyncReceiverLogger.java |   50 -
 .../receiver/recover/SyncReceiverLogAnalyzer.java  |  154 -
 .../sync/receiver/recover/SyncReceiverLogger.java  |   72 -
 .../db/sync/receiver/transfer/SyncServiceImpl.java |  357 ---
 .../db/sync/sender/manage/ISyncFileManager.java    |   72 -
 .../db/sync/sender/manage/SyncFileManager.java     |  291 --
 .../sender/recover/ISyncSenderLogAnalyzer.java     |   47 -
 .../db/sync/sender/recover/ISyncSenderLogger.java  |   67 -
 .../sync/sender/recover/SyncSenderLogAnalyzer.java |  128 -
 .../db/sync/sender/recover/SyncSenderLogger.java   |   72 -
 .../iotdb/db/sync/sender/transfer/ISyncClient.java |   95 -
 .../iotdb/db/sync/sender/transfer/SyncClient.java  |  752 -----
 .../apache/iotdb/db/tools/IoTDBDataDirViewer.java  |  164 --
 .../iotdb/db/tools/TsFileResourcePrinter.java      |   87 -
 .../apache/iotdb/db/tools/TsFileRewriteTool.java   |  481 ----
 .../apache/iotdb/db/tools/TsFileSketchTool.java    |  247 --
 .../java/org/apache/iotdb/db/tools/WalChecker.java |  134 -
 .../org/apache/iotdb/db/tools/mlog/MLogParser.java |  207 --
 .../db/tools/upgrade/TsFileOnlineUpgradeTool.java  |  290 --
 .../db/tools/virtualsg/DeviceMappingViewer.java    |   63 -
 .../watermark/GroupedLSBWatermarkEncoder.java      |  150 -
 .../db/tools/watermark/WatermarkDetector.java      |  226 --
 .../iotdb/db/tools/watermark/WatermarkEncoder.java |   36 -
 .../java/org/apache/iotdb/db/utils/AuthUtils.java  |  319 ---
 .../org/apache/iotdb/db/utils/CommonUtils.java     |  212 --
 .../iotdb/db/utils/CopyOnReadLinkedList.java       |   72 -
 .../iotdb/db/utils/EncodingInferenceUtils.java     |   54 -
 .../org/apache/iotdb/db/utils/FileLoaderUtils.java |  184 --
 .../org/apache/iotdb/db/utils/FilePathUtils.java   |  259 --
 .../java/org/apache/iotdb/db/utils/FileUtils.java  |   49 -
 .../java/org/apache/iotdb/db/utils/IOUtils.java    |  182 --
 .../java/org/apache/iotdb/db/utils/MathUtils.java  |   80 -
 .../java/org/apache/iotdb/db/utils/MemUtils.java   |  187 --
 .../java/org/apache/iotdb/db/utils/MergeUtils.java |  301 --
 .../java/org/apache/iotdb/db/utils/MmapUtil.java   |   35 -
 .../org/apache/iotdb/db/utils/OpenFileNumUtil.java |  290 --
 .../apache/iotdb/db/utils/QueryDataSetUtils.java   |  258 --
 .../java/org/apache/iotdb/db/utils/QueryUtils.java |  107 -
 .../apache/iotdb/db/utils/RandomDeleteCache.java   |   76 -
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |  244 --
 .../org/apache/iotdb/db/utils/SerializeUtils.java  |  561 ----
 .../org/apache/iotdb/db/utils/StatusUtils.java     |   46 -
 .../java/org/apache/iotdb/db/utils/SyncUtils.java  |  109 -
 .../java/org/apache/iotdb/db/utils/TestOnly.java   |   34 -
 .../apache/iotdb/db/utils/TimeValuePairUtils.java  |  110 -
 .../apache/iotdb/db/utils/TypeInferenceUtils.java  |  103 -
 .../org/apache/iotdb/db/utils/UpgradeUtils.java    |  165 --
 .../iotdb/db/utils/datastructure/BinaryTVList.java |  230 --
 .../db/utils/datastructure/BooleanTVList.java      |  230 --
 .../iotdb/db/utils/datastructure/DoubleTVList.java |  234 --
 .../iotdb/db/utils/datastructure/FloatTVList.java  |  234 --
 .../iotdb/db/utils/datastructure/IntTVList.java    |  228 --
 .../iotdb/db/utils/datastructure/LongTVList.java   |  228 --
 .../iotdb/db/utils/datastructure/TVList.java       |  574 ----
 .../iotdb/db/utils/datastructure/TimeSelector.java |  155 -
 .../apache/iotdb/db/writelog/WALFlushListener.java |   50 -
 .../iotdb/db/writelog/io/BatchLogReader.java       |   83 -
 .../apache/iotdb/db/writelog/io/ILogReader.java    |   50 -
 .../apache/iotdb/db/writelog/io/ILogWriter.java    |   50 -
 .../org/apache/iotdb/db/writelog/io/LogWriter.java |  133 -
 .../iotdb/db/writelog/io/MultiFileLogReader.java   |   76 -
 .../iotdb/db/writelog/io/SingleFileLogReader.java  |  142 -
 .../writelog/manager/MultiFileLogNodeManager.java  |  165 --
 .../db/writelog/manager/WriteLogNodeManager.java   |   49 -
 .../db/writelog/node/ExclusiveWriteLogNode.java    |  377 ---
 .../iotdb/db/writelog/node/WriteLogNode.java       |   86 -
 .../iotdb/db/writelog/recover/LogReplayer.java     |  206 --
 .../writelog/recover/TsFileRecoverPerformer.java   |  242 --
 .../org.apache.iotdb.db.mqtt.PayloadFormatter      |   20 -
 .../src/main/resources/iotdb/ui/static/index.html  |   79 -
 .../main/resources/iotdb/ui/static/iotdb-logo.png  |  Bin 1187 -> 0 bytes
 .../src/main/resources/iotdb/ui/static/webui.css   |  194 --
 .../apache/iotdb/db/auth/AuthorityCheckerTest.java |  236 --
 .../auth/authorizer/LocalFileAuthorizerTest.java   |  333 ---
 .../db/auth/authorizer/OpenIdAuthorizerTest.java   |   97 -
 .../iotdb/db/auth/entity/PathPrivilegeTest.java    |   41 -
 .../org/apache/iotdb/db/auth/entity/RoleTest.java  |   41 -
 .../org/apache/iotdb/db/auth/entity/UserTest.java  |   43 -
 .../db/auth/role/LocalFileRoleAccessorTest.java    |   95 -
 .../db/auth/role/LocalFileRoleManagerTest.java     |  148 -
 .../db/auth/user/LocalFileUserAccessorTest.java    |  112 -
 .../db/auth/user/LocalFileUserManagerTest.java     |  202 --
 .../IoTDBDefaultThreadExceptionHandlerTest.java    |   80 -
 .../db/concurrent/IoTDBThreadPoolFactoryTest.java  |  218 --
 .../apache/iotdb/db/conf/IoTDBDescriptorTest.java  |   75 -
 .../db/conf/adapter/CompressionRatioTest.java      |  152 -
 .../strategy/DirectoryStrategyTest.java            |  206 --
 .../org/apache/iotdb/db/constant/TestConstant.java |  106 -
 .../db/cost/statistic/PerformanceStatTest.java     |  105 -
 .../iotdb/db/engine/MetadataManagerHelper.java     |  158 --
 .../db/engine/compaction/CompactionChunkTest.java  |  238 --
 .../compaction/LevelCompactionCacheTest.java       |  127 -
 .../engine/compaction/LevelCompactionLogTest.java  |   87 -
 .../compaction/LevelCompactionMergeTest.java       |  233 --
 .../engine/compaction/LevelCompactionModsTest.java |  135 -
 .../compaction/LevelCompactionMoreDataTest.java    |  239 --
 .../compaction/LevelCompactionRecoverTest.java     |  703 -----
 .../compaction/LevelCompactionSelectorTest.java    |   76 -
 .../db/engine/compaction/LevelCompactionTest.java  |  234 --
 .../LevelCompactionTsFileManagementTest.java       |  228 --
 .../NoCompactionTsFileManagementTest.java          |  235 --
 .../db/engine/memtable/MemTableFlushTaskTest.java  |  103 -
 .../db/engine/memtable/MemTableTestUtils.java      |   65 -
 .../db/engine/memtable/MemtableBenchmark.java      |   64 -
 .../db/engine/memtable/PrimitiveMemTableTest.java  |  244 --
 .../engine/merge/MaxFileMergeFileSelectorTest.java |  239 --
 .../merge/MaxSeriesMergeFileSelectorTest.java      |  108 -
 .../apache/iotdb/db/engine/merge/MergeLogTest.java |   92 -
 .../iotdb/db/engine/merge/MergeManagerTest.java    |  176 --
 .../iotdb/db/engine/merge/MergeOverLapTest.java    |  226 --
 .../iotdb/db/engine/merge/MergePerfTest.java       |  108 -
 .../iotdb/db/engine/merge/MergeTaskTest.java       |  578 ----
 .../apache/iotdb/db/engine/merge/MergeTest.java    |  232 --
 .../iotdb/db/engine/merge/MergeUpgradeTest.java    |  190 --
 .../engine/modification/DeletionFileNodeTest.java  |  351 ---
 .../db/engine/modification/DeletionQueryTest.java  |  346 ---
 .../engine/modification/ModificationFileTest.java  |  103 -
 .../io/LocalTextModificationAccessorTest.java      |   81 -
 .../storagegroup/FileNodeManagerBenchmark.java     |  133 -
 .../storagegroup/StorageGroupProcessorTest.java    |  629 ----
 .../iotdb/db/engine/storagegroup/TTLTest.java      |  435 ---
 .../engine/storagegroup/TsFileProcessorTest.java   |  356 ---
 .../virtualSg/HashVirtualPartitionerTest.java      |   63 -
 .../version/SimpleFileVersionControllerTest.java   |   56 -
 .../version/SysTimeVersionControllerTest.java      |   44 -
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  967 -------
 .../integration/IOTDBGroupByInnerIntervalIT.java   |  341 ---
 .../apache/iotdb/db/integration/IOTDBInsertIT.java |  126 -
 .../iotdb/db/integration/IoTDBAddSubDeviceIT.java  |  248 --
 .../apache/iotdb/db/integration/IoTDBAliasIT.java  |  338 ---
 .../iotdb/db/integration/IoTDBAlignByDeviceIT.java | 1277 ---------
 .../org/apache/iotdb/db/integration/IoTDBAsIT.java |  608 ----
 .../db/integration/IoTDBAutoCreateSchemaIT.java    |  250 --
 .../iotdb/db/integration/IoTDBCheckConfigIT.java   |  161 --
 .../iotdb/db/integration/IoTDBClearCacheIT.java    |  174 --
 .../apache/iotdb/db/integration/IoTDBCloseIT.java  |  197 --
 .../iotdb/db/integration/IoTDBCompleteIT.java      |  487 ----
 .../iotdb/db/integration/IoTDBCompressTypeIT.java  |  109 -
 .../db/integration/IoTDBCreateSnapshotIT.java      |  187 --
 .../db/integration/IoTDBCreateTimeseriesIT.java    |  157 -
 .../apache/iotdb/db/integration/IoTDBDaemonIT.java |  470 ---
 .../db/integration/IoTDBDeleteStorageGroupIT.java  |  169 --
 .../db/integration/IoTDBDeleteTimeseriesIT.java    |  179 --
 .../iotdb/db/integration/IoTDBDeletionIT.java      |  427 ---
 .../iotdb/db/integration/IoTDBDisableAlignIT.java  |  419 ---
 .../iotdb/db/integration/IoTDBEncodingIT.java      |  291 --
 .../db/integration/IoTDBEngineTimeGeneratorIT.java |  283 --
 .../iotdb/db/integration/IoTDBExecuteBatchIT.java  |  197 --
 .../iotdb/db/integration/IoTDBFilePathUtilsIT.java |  110 -
 .../apache/iotdb/db/integration/IoTDBFillIT.java   |  882 ------
 .../db/integration/IoTDBFloatPrecisionIT.java      |  174 --
 .../db/integration/IoTDBFlushQueryMergeIT.java     |  214 --
 .../iotdb/db/integration/IoTDBGroupByFillIT.java   |  850 ------
 .../integration/IoTDBGroupByFillWithRangeIT.java   |  182 --
 .../iotdb/db/integration/IoTDBGroupByMonthIT.java  |  272 --
 .../iotdb/db/integration/IoTDBInsertNaNIT.java     |  203 --
 .../db/integration/IoTDBInsertWithQueryIT.java     |  532 ----
 .../iotdb/db/integration/IoTDBKillQueryIT.java     |   81 -
 .../iotdb/db/integration/IoTDBLargeDataIT.java     |  395 ---
 .../apache/iotdb/db/integration/IoTDBLastIT.java   |  559 ----
 .../db/integration/IoTDBLevelCompactionIT.java     | 1200 --------
 .../iotdb/db/integration/IoTDBLimitSlimitIT.java   |  208 --
 ...IoTDBLoadExternalTsFileWithTimePartitionIT.java |  210 --
 .../db/integration/IoTDBLoadExternalTsfileIT.java  |  706 -----
 .../apache/iotdb/db/integration/IoTDBMergeIT.java  |  386 ---
 .../iotdb/db/integration/IoTDBMetadataFetchIT.java |  639 -----
 .../iotdb/db/integration/IoTDBMultiDeviceIT.java   |  308 --
 .../IoTDBMultiOverlappedChunkInUnseqIT.java        |  120 -
 .../db/integration/IoTDBMultiOverlappedPageIT.java |  180 --
 .../iotdb/db/integration/IoTDBMultiSeriesIT.java   |  512 ----
 .../db/integration/IoTDBMultiStatementsIT.java     |  202 --
 .../db/integration/IoTDBNewTsFileCompactionIT.java | 1057 -------
 .../iotdb/db/integration/IoTDBNumberPathIT.java    |  484 ----
 .../db/integration/IoTDBOverlappedPageIT.java      |  158 --
 .../iotdb/db/integration/IoTDBQueryDemoIT.java     |  486 ----
 .../db/integration/IoTDBQueryMemoryControlIT.java  |  299 --
 .../iotdb/db/integration/IoTDBQueryTimeoutIT.java  |  151 -
 .../iotdb/db/integration/IoTDBQuotedPathIT.java    |  149 -
 .../iotdb/db/integration/IoTDBRecoverIT.java       |  435 ---
 .../db/integration/IoTDBRecoverUnclosedIT.java     |  288 --
 .../db/integration/IoTDBRemovePartitionIT.java     |  330 ---
 .../iotdb/db/integration/IoTDBRestartIT.java       |  408 ---
 .../iotdb/db/integration/IoTDBResultSetIT.java     |  126 -
 .../db/integration/IoTDBRpcCompressionIT.java      |  151 -
 .../IoTDBSameMeasurementsDifferentTypesIT.java     |  187 --
 .../iotdb/db/integration/IoTDBSensorUpdateIT.java  |   85 -
 .../db/integration/IoTDBSequenceDataQueryIT.java   |  319 ---
 .../iotdb/db/integration/IoTDBSeriesReaderIT.java  |  490 ----
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   | 1279 ---------
 .../integration/IoTDBSortedShowTimeseriesIT.java   |  335 ---
 .../iotdb/db/integration/IoTDBTagAlterIT.java      |  640 -----
 .../apache/iotdb/db/integration/IoTDBTagIT.java    | 1161 --------
 .../iotdb/db/integration/IoTDBTimeZoneIT.java      |  163 --
 .../iotdb/db/integration/IoTDBTracingIT.java       |   70 -
 .../apache/iotdb/db/integration/IoTDBTtlIT.java    |  213 --
 .../iotdb/db/integration/IoTDBUDFManagementIT.java |  460 ---
 .../db/integration/IoTDBUDFWindowQueryIT.java      |  557 ----
 .../integration/IoTDBUDTFAlignByTimeQueryIT.java   |  846 ------
 .../db/integration/IoTDBUDTFBuiltinFunctionIT.java |  285 --
 .../db/integration/IoTDBUDTFHybridQueryIT.java     |  181 --
 .../db/integration/IoTDBUDTFNonAlignQueryIT.java   |  368 ---
 .../iotdb/db/integration/IoTDBVersionIT.java       |   70 -
 .../aggregation/IoTDBAggregationByLevelIT.java     |  358 ---
 .../aggregation/IoTDBAggregationDeleteIT.java      |   91 -
 .../aggregation/IoTDBAggregationIT.java            | 1029 -------
 .../aggregation/IoTDBAggregationLargeDataIT.java   |  991 -------
 .../aggregation/IoTDBAggregationSmallDataIT.java   |  774 -----
 .../db/integration/auth/IoTDBAuthorizationIT.java  | 1082 -------
 .../iotdb/db/metadata/MManagerAdvancedTest.java    |  230 --
 .../iotdb/db/metadata/MManagerBasicTest.java       |  810 ------
 .../iotdb/db/metadata/MManagerImproveTest.java     |  187 --
 .../org/apache/iotdb/db/metadata/MTreeTest.java    |  870 ------
 .../apache/iotdb/db/metadata/MetaUtilsTest.java    |  114 -
 .../apache/iotdb/db/metadata/PartialPathTest.java  |  113 -
 .../apache/iotdb/db/metadata/mnode/MNodeTest.java  |   98 -
 .../iotdb/db/monitor/IoTDBStatMonitorTest.java     |  177 --
 .../iotdb/db/mqtt/BrokerAuthenticatorTest.java     |   52 -
 .../iotdb/db/mqtt/JSONPayloadFormatTest.java       |   71 -
 .../iotdb/db/mqtt/PayloadFormatManagerTest.java    |   35 -
 .../apache/iotdb/db/mqtt/PublishHandlerTest.java   |   62 -
 .../java/org/apache/iotdb/db/qp/PlannerTest.java   |  256 --
 .../iotdb/db/qp/bench/QueryParseBenchmark.java     |   45 -
 .../iotdb/db/qp/logical/IndexLogicalPlanTest.java  |  156 -
 .../iotdb/db/qp/logical/LogicalPlanSmallTest.java  |  364 ---
 .../iotdb/db/qp/other/TSPlanContextAuthorTest.java |   91 -
 .../iotdb/db/qp/physical/ConcatOptimizerTest.java  |  138 -
 .../physical/IndexSubMatchingPhysicalPlanTest.java |  163 --
 .../IndexWholeMatchingPhysicalPlanTest.java        |  168 --
 .../db/qp/physical/InsertTabletMultiPlanTest.java  |  103 -
 .../iotdb/db/qp/physical/InsertTabletPlanTest.java |  109 -
 .../db/qp/physical/PhysicalPlanSerializeTest.java  |  284 --
 .../iotdb/db/qp/physical/PhysicalPlanTest.java     | 1218 --------
 .../iotdb/db/qp/physical/SerializationTest.java    |  151 -
 .../iotdb/db/qp/sql/IoTDBsqlVisitorTest.java       |   99 -
 .../db/qp/utils/DatetimeQueryDataSetUtilsTest.java |  199 --
 .../db/query/aggregation/AggregateResultTest.java  |  269 --
 .../query/aggregation/DescAggregateResultTest.java |  127 -
 .../db/query/control/FileReaderManagerTest.java    |  148 -
 .../db/query/control/QueryResourceManagerTest.java |   29 -
 .../iotdb/db/query/control/TracingManagerTest.java |  114 -
 .../dataset/EngineDataSetWithValueFilterTest.java  |  156 -
 .../iotdb/db/query/dataset/ListDataSetTest.java    |  149 -
 .../db/query/dataset/ShowDevicesResultTest.java    |   42 -
 .../db/query/dataset/ShowTimeSeriesResultTest.java |   66 -
 .../iotdb/db/query/dataset/SingleDataSetTest.java  |  130 -
 .../query/dataset/UDTFAlignByTimeDataSetTest.java  |  692 -----
 .../dataset/groupby/GroupByEngineDataSetTest.java  |  504 ----
 .../dataset/groupby/GroupByFillDataSetTest.java    |  194 --
 .../dataset/groupby/GroupByLevelDataSetTest.java   |  151 -
 .../dataset/groupby/GroupByTimeDataSetTest.java    |  225 --
 .../query/externalsort/ExternalSortEngineTest.java |  193 --
 .../db/query/externalsort/FakeChunkReaderWrap.java |   43 -
 ...ExternalSortFileSerializerDeserializerTest.java |  131 -
 .../reader/series/SeriesAggregateReaderTest.java   |  136 -
 .../reader/series/SeriesReaderByTimestampTest.java |   98 -
 .../db/query/reader/series/SeriesReaderTest.java   |  188 --
 .../query/reader/series/SeriesReaderTestUtil.java  |  234 --
 .../query/reader/universal/FakedSeriesReader.java  |   85 -
 .../reader/universal/PriorityMergeReaderTest.java  |   85 -
 .../reader/universal/PriorityMergeReaderTest2.java |   60 -
 .../ElasticSerializableRowRecordListTest.java      |  233 --
 .../ElasticSerializableTVListTest.java             |  268 --
 .../iotdb/db/query/udf/datastructure/LRUCache.java |   59 -
 .../db/query/udf/datastructure/LRUCacheTest.java   |  115 -
 .../SerializableBinaryTVListTest.java              |   85 -
 .../SerializableBooleanTVListTest.java             |   85 -
 .../SerializableDoubleTVListTest.java              |   84 -
 .../datastructure/SerializableFloatTVListTest.java |   83 -
 .../datastructure/SerializableIntTVListTest.java   |   83 -
 .../udf/datastructure/SerializableListTest.java    |   43 -
 .../datastructure/SerializableLongTVListTest.java  |   83 -
 .../SerializableRowRecordListTest.java             |  183 --
 .../udf/datastructure/SerializableTVListTest.java  |   38 -
 .../iotdb/db/query/udf/example/Accumulator.java    |   95 -
 .../apache/iotdb/db/query/udf/example/Adder.java   |   94 -
 .../apache/iotdb/db/query/udf/example/Counter.java |   83 -
 .../org/apache/iotdb/db/query/udf/example/Max.java |   76 -
 .../iotdb/db/query/udf/example/Multiplier.java     |   65 -
 .../SlidingSizeWindowConstructorTester0.java       |   59 -
 .../SlidingSizeWindowConstructorTester1.java       |   66 -
 .../SlidingTimeWindowConstructionTester.java       |   74 -
 .../db/query/udf/example/TerminateTester.java      |   69 -
 .../iotdb/db/query/udf/example/ValidateTester.java |   46 -
 .../org/apache/iotdb/db/script/EnvScriptIT.java    |  128 -
 .../db/sync/receiver/load/FileLoaderTest.java      |  411 ---
 .../recover/SyncReceiverLogAnalyzerTest.java       |  232 --
 .../receiver/recover/SyncReceiverLoggerTest.java   |  115 -
 .../db/sync/sender/manage/SyncFileManagerTest.java |  350 ---
 .../sender/recover/SyncSenderLogAnalyzerTest.java  |  201 --
 .../sync/sender/recover/SyncSenderLoggerTest.java  |  112 -
 .../db/sync/sender/transfer/SyncClientTest.java    |  161 --
 .../apache/iotdb/db/tools/IoTDBWatermarkTest.java  |  247 --
 .../org/apache/iotdb/db/tools/MLogParserTest.java  |  191 --
 .../org/apache/iotdb/db/tools/WalCheckerTest.java  |  172 --
 .../iotdb/db/utils/CopyOnReadLinkedListTest.java   |   67 -
 .../iotdb/db/utils/EncodingInferenceUtilsTest.java |   50 -
 .../apache/iotdb/db/utils/EnvironmentUtils.java    |  322 ---
 .../apache/iotdb/db/utils/FilePathUtilsTest.java   |  124 -
 .../iotdb/db/utils/MathQueryDataSetUtilsTest.java  |   68 -
 .../org/apache/iotdb/db/utils/MemUtilsTest.java    |  113 -
 .../apache/iotdb/db/utils/OpenFileNumUtilTest.java |  294 --
 .../java/org/apache/iotdb/db/utils/RandomNum.java  |   65 -
 .../org/apache/iotdb/db/utils/SchemaUtilsTest.java |   71 -
 .../apache/iotdb/db/utils/SerializeUtilsTest.java  |  287 --
 .../iotdb/db/utils/TsFileRewriteToolTest.java      |  330 ---
 .../iotdb/db/utils/TypeInferenceUtilsTest.java     |   99 -
 .../db/utils/datastructure/BinaryTVListTest.java   |   58 -
 .../db/utils/datastructure/BooleanTVListTest.java  |   66 -
 .../db/utils/datastructure/DoubleTVListTest.java   |   76 -
 .../db/utils/datastructure/FloatTVListTest.java    |   76 -
 .../db/utils/datastructure/IntTVListTest.java      |   75 -
 .../db/utils/datastructure/LongTVListTest.java     |   98 -
 .../db/utils/datastructure/PrecisionTest.java      |  143 -
 .../db/utils/datastructure/TimeSelectorTest.java   |  218 --
 .../iotdb/db/writelog/IoTDBLogFileSizeTest.java    |  221 --
 .../apache/iotdb/db/writelog/PerformanceTest.java  |  219 --
 .../iotdb/db/writelog/WriteLogNodeManagerTest.java |  185 --
 .../apache/iotdb/db/writelog/WriteLogNodeTest.java |  324 ---
 .../iotdb/db/writelog/io/LogWriterReaderTest.java  |   97 -
 .../db/writelog/io/MultiFileLogReaderTest.java     |   89 -
 .../db/writelog/recover/DeviceStringTest.java      |  132 -
 .../iotdb/db/writelog/recover/LogReplayerTest.java |  281 --
 .../recover/RecoverResourceFromReaderTest.java     |  263 --
 .../db/writelog/recover/SeqTsFileRecoverTest.java  |  327 ---
 .../writelog/recover/UnseqTsFileRecoverTest.java   |  276 --
 server/src/test/resources/iotdb-engine.properties  |   24 -
 server/src/test/resources/logback.xml              |   58 -
 server/src/test/resources/start-sync-test.sh       |   54 -
 server/src/test/resources/stop-sync-test.sh        |   29 -
 service-rpc/pom.xml                                |  156 -
 .../org/apache/iotdb/rpc/AutoResizingBuffer.java   |   76 -
 .../iotdb/rpc/AutoScalingBufferReadTransport.java  |   86 -
 .../iotdb/rpc/AutoScalingBufferWriteTransport.java |   65 -
 .../apache/iotdb/rpc/BatchExecutionException.java  |   46 -
 .../apache/iotdb/rpc/IoTDBConnectionException.java |   36 -
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |  509 ----
 .../org/apache/iotdb/rpc/NonOpenTransport.java     |   43 -
 .../org/apache/iotdb/rpc/RedirectException.java    |   52 -
 .../main/java/org/apache/iotdb/rpc/RpcStat.java    |   50 -
 .../org/apache/iotdb/rpc/RpcTransportFactory.java  |   72 -
 .../main/java/org/apache/iotdb/rpc/RpcUtils.java   |  276 --
 .../iotdb/rpc/StatementExecutionException.java     |   47 -
 .../org/apache/iotdb/rpc/SynchronizedHandler.java  |   55 -
 .../rpc/TCompressedElasticFramedTransport.java     |   98 -
 .../apache/iotdb/rpc/TElasticFramedTransport.java  |  145 -
 .../java/org/apache/iotdb/rpc/TSStatusCode.java    |  101 -
 .../iotdb/rpc/TSnappyElasticFramedTransport.java   |   78 -
 .../rpc/TimeoutChangeableTFastFramedTransport.java |   69 -
 .../TimeoutChangeableTSnappyFramedTransport.java   |   70 -
 .../iotdb/rpc/TimeoutChangeableTransport.java      |   28 -
 session/pom.xml                                    |  153 -
 .../main/java/org/apache/iotdb/session/Config.java |   37 -
 .../java/org/apache/iotdb/session/Session.java     | 1544 ----------
 .../apache/iotdb/session/SessionConnection.java    |  689 -----
 .../org/apache/iotdb/session/SessionDataSet.java   |  281 --
 .../org/apache/iotdb/session/SessionUtils.java     |   91 -
 .../iotdb/session/pool/SessionDataSetWrapper.java  |  100 -
 .../org/apache/iotdb/session/pool/SessionPool.java | 1164 --------
 .../iotdb/session/IoTDBSessionComplexIT.java       |  803 ------
 .../iotdb/session/IoTDBSessionIteratorIT.java      |  343 ---
 .../apache/iotdb/session/IoTDBSessionSimpleIT.java |  684 -----
 .../apache/iotdb/session/SessionCacheLeaderUT.java |  821 ------
 .../java/org/apache/iotdb/session/SessionUT.java   |  202 --
 .../apache/iotdb/session/pool/SessionPoolTest.java |  309 --
 session/src/test/resources/iotdb-engine.properties |   20 -
 site/README-zh.md                                  |  208 --
 site/README.md                                     |  214 --
 site/iotdb-doap.rdf                                |   80 -
 site/pom.xml                                       |  885 ------
 site/src/main/.vuepress/config.js                  | 1687 -----------
 site/src/main/.vuepress/enhanceApp.js              |   31 -
 site/src/main/.vuepress/public/img/arrow.png       |  Bin 88 -> 0 bytes
 .../public/img/contributor-avatar/jlq.png          |  Bin 98500 -> 0 bytes
 .../public/img/contributor-avatar/kfx.jpeg         |  Bin 119029 -> 0 bytes
 .../public/img/contributor-avatar/user.svg         |   51 -
 .../public/img/contributor-avatar/xdh.jpg          |  Bin 123718 -> 0 bytes
 .../public/img/contributor-avatar/xww.jpg          |  Bin 64538 -> 0 bytes
 .../public/img/contributor-avatar/yrzh.jpg         |  Bin 99556 -> 0 bytes
 .../.vuepress/public/img/contributor-avatar/yt.jpg |  Bin 115804 -> 0 bytes
 .../public/img/contributor-avatar/zss.jpg          |  Bin 91455 -> 0 bytes
 site/src/main/.vuepress/public/img/home-Slide1.png |  Bin 323108 -> 0 bytes
 site/src/main/.vuepress/public/img/home-Slide2.png |  Bin 323620 -> 0 bytes
 site/src/main/.vuepress/public/img/home-Slide3.png |  Bin 324332 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon1.png  |  Bin 30032 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon2.png  |  Bin 4463 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon3.png  |  Bin 10753 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon4.png  |  Bin 8681 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon5.png  |  Bin 1531 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon6.png  |  Bin 11537 -> 0 bytes
 site/src/main/.vuepress/public/img/logo.png        |  Bin 21687 -> 0 bytes
 site/src/main/.vuepress/public/img/tools.jpg       |  Bin 294103 -> 0 bytes
 site/src/main/.vuepress/styles/index.styl          |   23 -
 site/src/main/.vuepress/styles/palette.styl        |   23 -
 .../theme/components/AlgoliaSearchBox.vue          |  172 --
 .../.vuepress/theme/components/DropdownLink.vue    |  196 --
 .../theme/components/DropdownTransition.vue        |   50 -
 site/src/main/.vuepress/theme/components/Home.vue  |  179 --
 .../main/.vuepress/theme/components/NavLink.vue    |   65 -
 .../main/.vuepress/theme/components/NavLinks.vue   |  166 --
 .../src/main/.vuepress/theme/components/Navbar.vue |  139 -
 site/src/main/.vuepress/theme/components/Page.vue  |  283 --
 .../main/.vuepress/theme/components/Sidebar.vue    |   76 -
 .../.vuepress/theme/components/SidebarButton.vue   |   44 -
 .../.vuepress/theme/components/SidebarGroup.vue    |  146 -
 .../.vuepress/theme/components/SidebarLink.vue     |  126 -
 .../.vuepress/theme/components/SidebarLinks.vue    |  103 -
 .../.vuepress/theme/global-components/Badge.vue    |   61 -
 .../theme/global-components/Contributor.vue        |  390 ---
 .../.vuepress/theme/global-components/IoTDB.vue    |  302 --
 .../.vuepress/theme/global-components/IoTDBZH.vue  |  296 --
 site/src/main/.vuepress/theme/index.js             |   63 -
 site/src/main/.vuepress/theme/layouts/404.vue      |   43 -
 site/src/main/.vuepress/theme/layouts/Layout.vue   |  166 --
 site/src/main/.vuepress/theme/styles/arrow.styl    |   39 -
 site/src/main/.vuepress/theme/styles/code.styl     |  166 --
 .../main/.vuepress/theme/styles/custom-blocks.styl |   47 -
 site/src/main/.vuepress/theme/styles/index.styl    |  229 --
 site/src/main/.vuepress/theme/styles/mobile.styl   |   54 -
 site/src/main/.vuepress/theme/styles/toc.styl      |   20 -
 site/src/main/.vuepress/theme/styles/wrapper.styl  |   26 -
 site/src/main/.vuepress/theme/util/index.js        |  256 --
 site/src/main/deploy.js                            |   25 -
 site/src/main/package.json                         |   44 -
 spark-iotdb-connector/Readme.md                    |  168 --
 spark-iotdb-connector/pom.xml                      |  142 -
 .../org/apache/iotdb/spark/db/SQLConstant.java     |   28 -
 .../org/apache/iotdb/spark/db/Converter.scala      |   85 -
 .../org/apache/iotdb/spark/db/DefaultSource.scala  |   43 -
 .../org/apache/iotdb/spark/db/IoTDBOptions.scala   |   43 -
 .../scala/org/apache/iotdb/spark/db/IoTDBRDD.scala |  133 -
 .../org/apache/iotdb/spark/db/IoTDBRelation.scala  |  117 -
 .../org/apache/iotdb/spark/db/Transformer.scala    |  172 --
 .../scala/org/apache/iotdb/spark/db/package.scala  |   36 -
 .../src/test/resources/iotdb-engine.properties     |   21 -
 .../apache/iotdb/spark/db/EnvironmentUtils.java    |  268 --
 .../org/apache/iotdb/spark/db/IoTDBTest.scala      |  153 -
 spark-tsfile/README.md                             |  335 ---
 spark-tsfile/pom.xml                               |  125 -
 .../iotdb/spark/tsfile/io/TsFileOutputFormat.java  |   46 -
 .../iotdb/spark/tsfile/io/TsFileRecordWriter.java  |   58 -
 .../org/apache/iotdb/spark/tsfile/qp/Executor.java |   46 -
 .../iotdb/spark/tsfile/qp/QueryProcessor.java      |  197 --
 .../spark/tsfile/qp/common/BasicOperator.java      |   66 -
 .../spark/tsfile/qp/common/FilterOperator.java     |  153 -
 .../iotdb/spark/tsfile/qp/common/Operator.java     |   44 -
 .../iotdb/spark/tsfile/qp/common/SQLConstant.java  |  144 -
 .../iotdb/spark/tsfile/qp/common/SingleQuery.java  |   65 -
 .../iotdb/spark/tsfile/qp/common/TSQueryPlan.java  |   68 -
 .../qp/exception/BasicOperatorException.java       |   29 -
 .../tsfile/qp/exception/DNFOptimizeException.java  |   29 -
 .../qp/exception/LogicalOptimizeException.java     |   29 -
 .../tsfile/qp/exception/MergeFilterException.java  |   28 -
 .../qp/exception/QueryOperatorException.java       |   28 -
 .../qp/exception/QueryProcessorException.java      |   37 -
 .../tsfile/qp/exception/RemoveNotException.java    |   29 -
 .../tsfile/qp/optimizer/DNFFilterOptimizer.java    |  155 -
 .../tsfile/qp/optimizer/IFilterOptimizer.java      |   31 -
 .../qp/optimizer/MergeSingleFilterOptimizer.java   |  143 -
 .../tsfile/qp/optimizer/PhysicalOptimizer.java     |  242 --
 .../tsfile/qp/optimizer/RemoveNotOptimizer.java    |   97 -
 .../org/apache/iotdb/spark/tsfile/Converter.scala  |  145 -
 .../apache/iotdb/spark/tsfile/DefaultSource.scala  |  294 --
 .../iotdb/spark/tsfile/NarrowConverter.scala       |  596 ----
 .../spark/tsfile/NarrowTsFileOutputWriter.scala    |   50 -
 .../apache/iotdb/spark/tsfile/Transformer.scala    |  175 --
 .../iotdb/spark/tsfile/TsFileWriterFactory.scala   |   42 -
 .../apache/iotdb/spark/tsfile/WideConverter.scala  |  501 ----
 .../spark/tsfile/WideTsFileOutputWriter.scala      |   53 -
 .../org/apache/iotdb/spark/tsfile/package.scala    |   62 -
 .../apache/iotdb/spark/constant/TestConstant.java  |   28 -
 .../org/apache/iotdb/spark/tool/TsFileExample.java |  114 -
 .../apache/iotdb/spark/tool/TsFileWriteTool.java   |  279 --
 .../apache/iotdb/spark/tsfile/ConverterTest.scala  |  269 --
 .../apache/iotdb/spark/tsfile/HDFSInputTest.java   |   81 -
 .../org/apache/iotdb/spark/tsfile/TSFileSuit.scala |  641 -----
 test/e2e/base/docker-compose.yaml                  |   51 -
 test/e2e/cases/README.md                           |   53 -
 test/e2e/cases/cli/README.md                       |   24 -
 test/e2e/cases/cli/cleanup.sh                      |   27 -
 test/e2e/cases/cli/docker-compose.yaml             |   41 -
 test/e2e/cases/cli/res/init.sql                    |   26 -
 test/e2e/cases/cli/run.sh                          |   48 -
 thrift-cluster/README.md                           |   22 -
 thrift-cluster/pom.xml                             |   67 -
 thrift-cluster/rpc-changelist.md                   |  181 --
 thrift-cluster/src/main/thrift/cluster.thrift      |  512 ----
 thrift-sync/README.md                              |   22 -
 thrift-sync/pom.xml                                |   67 -
 thrift-sync/rpc-changelist.md                      |  181 --
 thrift-sync/src/main/thrift/sync.thrift            |   51 -
 thrift/README.md                                   |   22 -
 thrift/pom.xml                                     |   98 -
 thrift/rpc-changelist.md                           |  181 --
 thrift/src/main/thrift/rpc.thrift                  |  372 ---
 tools/check_sigs.sh                                |   67 -
 tools/clean-site.sh                                |   35 -
 tools/common.sh                                    |  202 --
 tools/download_staged_release.sh                   |  143 -
 tsfile/README.md                                   |   63 -
 tsfile/format-changelist.md                        |   56 -
 tsfile/pom.xml                                     |  184 --
 .../iotdb/tsfile/common/cache/Accountable.java     |   26 -
 .../apache/iotdb/tsfile/common/cache/Cache.java    |   30 -
 .../apache/iotdb/tsfile/common/cache/LRUCache.java |   67 -
 .../iotdb/tsfile/common/conf/TSFileConfig.java     |  413 ---
 .../iotdb/tsfile/common/conf/TSFileDescriptor.java |  167 --
 .../tsfile/common/constant/JsonFormatConstant.java |   43 -
 .../tsfile/common/constant/QueryConstant.java      |   32 -
 .../tsfile/common/constant/TsFileConstant.java     |   34 -
 .../apache/iotdb/tsfile/compress/ICompressor.java  |  260 --
 .../iotdb/tsfile/compress/IUnCompressor.java       |  315 ---
 .../tsfile/encoding/bitpacking/IntPacker.java      |  162 --
 .../tsfile/encoding/bitpacking/LongPacker.java     |  176 --
 .../tsfile/encoding/decoder/BitmapDecoder.java     |  221 --
 .../iotdb/tsfile/encoding/decoder/Decoder.java     |  149 -
 .../encoding/decoder/DeltaBinaryDecoder.java       |  247 --
 .../encoding/decoder/DoublePrecisionDecoderV1.java |  117 -
 .../encoding/decoder/DoublePrecisionDecoderV2.java |   53 -
 .../tsfile/encoding/decoder/FloatDecoder.java      |  146 -
 .../tsfile/encoding/decoder/GorillaDecoderV1.java  |  128 -
 .../tsfile/encoding/decoder/GorillaDecoderV2.java  |  123 -
 .../tsfile/encoding/decoder/IntGorillaDecoder.java |   90 -
 .../tsfile/encoding/decoder/IntRleDecoder.java     |  124 -
 .../encoding/decoder/LongGorillaDecoder.java       |   89 -
 .../tsfile/encoding/decoder/LongRleDecoder.java    |  119 -
 .../tsfile/encoding/decoder/PlainDecoder.java      |   88 -
 .../encoding/decoder/RegularDataDecoder.java       |  282 --
 .../iotdb/tsfile/encoding/decoder/RleDecoder.java  |  230 --
 .../encoding/decoder/SinglePrecisionDecoderV1.java |  113 -
 .../encoding/decoder/SinglePrecisionDecoderV2.java |   53 -
 .../tsfile/encoding/encoder/BitmapEncoder.java     |  133 -
 .../encoding/encoder/DeltaBinaryEncoder.java       |  336 ---
 .../encoding/encoder/DoublePrecisionEncoderV1.java |  117 -
 .../encoding/encoder/DoublePrecisionEncoderV2.java |   55 -
 .../iotdb/tsfile/encoding/encoder/Encoder.java     |  111 -
 .../tsfile/encoding/encoder/FloatEncoder.java      |  138 -
 .../tsfile/encoding/encoder/GorillaEncoderV1.java  |   84 -
 .../tsfile/encoding/encoder/GorillaEncoderV2.java  |  105 -
 .../tsfile/encoding/encoder/IntGorillaEncoder.java |  158 --
 .../tsfile/encoding/encoder/IntRleEncoder.java     |  129 -
 .../encoding/encoder/LongGorillaEncoder.java       |  158 --
 .../tsfile/encoding/encoder/LongRleEncoder.java    |  122 -
 .../tsfile/encoding/encoder/PlainEncoder.java      |  138 -
 .../encoding/encoder/RegularDataEncoder.java       |  364 ---
 .../iotdb/tsfile/encoding/encoder/RleEncoder.java  |  333 ---
 .../iotdb/tsfile/encoding/encoder/SDTEncoder.java  |  452 ---
 .../encoding/encoder/SinglePrecisionEncoderV1.java |  113 -
 .../encoding/encoder/SinglePrecisionEncoderV2.java |   55 -
 .../tsfile/encoding/encoder/TSEncodingBuilder.java |  299 --
 .../exception/NotCompatibleTsFileException.java    |   28 -
 .../tsfile/exception/NotImplementedException.java  |   40 -
 .../iotdb/tsfile/exception/NullFieldException.java |   26 -
 .../tsfile/exception/TsFileRuntimeException.java   |   44 -
 .../tsfile/exception/cache/CacheException.java     |   44 -
 .../CompressionTypeNotSupportedException.java      |   43 -
 .../encoding/TsFileDecodingException.java          |   47 -
 .../encoding/TsFileEncodingException.java          |   47 -
 .../filter/QueryFilterOptimizationException.java   |   34 -
 .../exception/filter/StatisticsClassException.java |   34 -
 .../filter/UnSupportFilterDataTypeException.java   |   35 -
 .../exception/write/NoMeasurementException.java    |   29 -
 .../tsfile/exception/write/PageException.java      |   37 -
 .../write/TsFileNotCompleteException.java          |   39 -
 .../write/UnSupportedDataTypeException.java        |   30 -
 .../write/UnknownColumnTypeException.java          |   34 -
 .../exception/write/WriteProcessException.java     |   37 -
 .../org/apache/iotdb/tsfile/file/MetaMarker.java   |   52 -
 .../iotdb/tsfile/file/header/ChunkGroupHeader.java |  121 -
 .../iotdb/tsfile/file/header/ChunkHeader.java      |  281 --
 .../iotdb/tsfile/file/header/PageHeader.java       |  141 -
 .../tsfile/file/metadata/ChunkGroupMetadata.java   |   42 -
 .../iotdb/tsfile/file/metadata/ChunkMetadata.java  |  309 --
 .../file/metadata/MetadataIndexConstructor.java    |  159 --
 .../tsfile/file/metadata/MetadataIndexEntry.java   |   70 -
 .../tsfile/file/metadata/MetadataIndexNode.java    |  150 -
 .../tsfile/file/metadata/TimeseriesMetadata.java   |  259 --
 .../iotdb/tsfile/file/metadata/TsFileMetadata.java |  152 -
 .../file/metadata/enums/CompressionType.java       |  100 -
 .../file/metadata/enums/MetadataIndexNodeType.java |   98 -
 .../tsfile/file/metadata/enums/TSDataType.java     |  118 -
 .../tsfile/file/metadata/enums/TSEncoding.java     |   85 -
 .../file/metadata/statistics/BinaryStatistics.java |  222 --
 .../metadata/statistics/BooleanStatistics.java     |  235 --
 .../file/metadata/statistics/DoubleStatistics.java |  280 --
 .../file/metadata/statistics/FloatStatistics.java  |  272 --
 .../metadata/statistics/IntegerStatistics.java     |  272 --
 .../file/metadata/statistics/LongStatistics.java   |  281 --
 .../file/metadata/statistics/Statistics.java       |  456 ---
 .../iotdb/tsfile/fileSystem/FSFactoryProducer.java |   64 -
 .../org/apache/iotdb/tsfile/fileSystem/FSType.java |   25 -
 .../fileInputFactory/FileInputFactory.java         |   27 -
 .../fileInputFactory/HDFSInputFactory.java         |   58 -
 .../fileInputFactory/LocalFSInputFactory.java      |   44 -
 .../fileOutputFactory/FileOutputFactory.java       |   27 -
 .../fileOutputFactory/HDFSOutputFactory.java       |   58 -
 .../fileOutputFactory/LocalFSOutputFactory.java    |   45 -
 .../tsfile/fileSystem/fsFactory/FSFactory.java     |  139 -
 .../tsfile/fileSystem/fsFactory/HDFSFactory.java   |  237 --
 .../fileSystem/fsFactory/LocalFSFactory.java       |  154 -
 .../apache/iotdb/tsfile/read/ReadOnlyTsFile.java   |   60 -
 .../apache/iotdb/tsfile/read/TimeValuePair.java    |   81 -
 .../iotdb/tsfile/read/TsFileCheckStatus.java       |   26 -
 .../iotdb/tsfile/read/TsFileRestorableReader.java  |   71 -
 .../iotdb/tsfile/read/TsFileSequenceReader.java    | 1360 ---------
 .../iotdb/tsfile/read/UnClosedTsFileReader.java    |   44 -
 .../apache/iotdb/tsfile/read/common/BatchData.java |  602 ----
 .../iotdb/tsfile/read/common/BatchDataFactory.java |   44 -
 .../org/apache/iotdb/tsfile/read/common/Chunk.java |  171 --
 .../tsfile/read/common/DescReadBatchData.java      |   83 -
 .../tsfile/read/common/DescReadWriteBatchData.java |  373 ---
 .../tsfile/read/common/ExceptionBatchData.java     |   37 -
 .../org/apache/iotdb/tsfile/read/common/Field.java |  227 --
 .../org/apache/iotdb/tsfile/read/common/Path.java  |  164 --
 .../apache/iotdb/tsfile/read/common/RowRecord.java |   79 -
 .../iotdb/tsfile/read/common/SignalBatchData.java  |   43 -
 .../apache/iotdb/tsfile/read/common/TimeRange.java |  373 ---
 .../read/controller/CachedChunkLoaderImpl.java     |   73 -
 .../iotdb/tsfile/read/controller/IChunkLoader.java |   33 -
 .../read/controller/IChunkMetadataLoader.java      |   32 -
 .../tsfile/read/controller/IMetadataQuerier.java   |   67 -
 .../read/controller/MetadataQuerierByFileImpl.java |  268 --
 .../tsfile/read/expression/ExpressionType.java     |   47 -
 .../tsfile/read/expression/IBinaryExpression.java  |   30 -
 .../iotdb/tsfile/read/expression/IExpression.java  |   28 -
 .../tsfile/read/expression/IUnaryExpression.java   |   28 -
 .../tsfile/read/expression/QueryExpression.java    |  102 -
 .../read/expression/impl/BinaryExpression.java     |  133 -
 .../read/expression/impl/GlobalTimeExpression.java |   61 -
 .../expression/impl/SingleSeriesExpression.java    |   68 -
 .../read/expression/util/ExpressionOptimizer.java  |  235 --
 .../read/expression/util/ExpressionPrinter.java    |   60 -
 .../iotdb/tsfile/read/filter/GroupByFilter.java    |  148 -
 .../tsfile/read/filter/GroupByMonthFilter.java     |  187 --
 .../iotdb/tsfile/read/filter/TimeFilter.java       |  125 -
 .../iotdb/tsfile/read/filter/ValueFilter.java      |  130 -
 .../tsfile/read/filter/basic/BinaryFilter.java     |   92 -
 .../iotdb/tsfile/read/filter/basic/Filter.java     |   68 -
 .../tsfile/read/filter/basic/UnaryFilter.java      |   99 -
 .../tsfile/read/filter/factory/FilterFactory.java  |   90 -
 .../read/filter/factory/FilterSerializeId.java     |   34 -
 .../tsfile/read/filter/factory/FilterType.java     |   36 -
 .../tsfile/read/filter/operator/AndFilter.java     |   73 -
 .../iotdb/tsfile/read/filter/operator/Eq.java      |   97 -
 .../iotdb/tsfile/read/filter/operator/Gt.java      |   95 -
 .../iotdb/tsfile/read/filter/operator/GtEq.java    |   95 -
 .../iotdb/tsfile/read/filter/operator/In.java      |  125 -
 .../iotdb/tsfile/read/filter/operator/Lt.java      |   95 -
 .../iotdb/tsfile/read/filter/operator/LtEq.java    |   95 -
 .../iotdb/tsfile/read/filter/operator/NotEq.java   |   97 -
 .../tsfile/read/filter/operator/NotFilter.java     |  115 -
 .../tsfile/read/filter/operator/OrFilter.java      |   75 -
 .../query/dataset/DataSetWithTimeGenerator.java    |   88 -
 .../query/dataset/DataSetWithoutTimeGenerator.java |  179 --
 .../tsfile/read/query/dataset/EmptyDataSet.java    |   40 -
 .../tsfile/read/query/dataset/QueryDataSet.java    |  170 --
 .../query/executor/ExecutorWithTimeGenerator.java  |  127 -
 .../tsfile/read/query/executor/QueryExecutor.java  |   29 -
 .../tsfile/read/query/executor/TsFileExecutor.java |  197 --
 .../read/query/timegenerator/TimeGenerator.java    |  135 -
 .../query/timegenerator/TsFileTimeGenerator.java   |   58 -
 .../read/query/timegenerator/node/AndNode.java     |  105 -
 .../read/query/timegenerator/node/LeafNode.java    |   92 -
 .../tsfile/read/query/timegenerator/node/Node.java |   30 -
 .../read/query/timegenerator/node/NodeType.java    |   26 -
 .../read/query/timegenerator/node/OrNode.java      |  118 -
 .../tsfile/read/reader/BatchDataIterator.java      |   54 -
 .../iotdb/tsfile/read/reader/IBatchReader.java     |   32 -
 .../iotdb/tsfile/read/reader/IChunkReader.java     |   35 -
 .../iotdb/tsfile/read/reader/IPageReader.java      |   40 -
 .../iotdb/tsfile/read/reader/IPointReader.java     |   34 -
 .../iotdb/tsfile/read/reader/LocalTsFileInput.java |  151 -
 .../iotdb/tsfile/read/reader/TsFileInput.java      |  130 -
 .../tsfile/read/reader/chunk/ChunkReader.java      |  238 --
 .../read/reader/chunk/ChunkReaderByTimestamp.java  |   44 -
 .../iotdb/tsfile/read/reader/page/PageReader.java  |  195 --
 .../reader/series/AbstractFileSeriesReader.java    |   92 -
 .../read/reader/series/EmptyFileSeriesReader.java  |   57 -
 .../read/reader/series/FileSeriesReader.java       |   51 -
 .../reader/series/FileSeriesReaderByTimestamp.java |  154 -
 .../java/org/apache/iotdb/tsfile/utils/Binary.java |  121 -
 .../org/apache/iotdb/tsfile/utils/BloomFilter.java |  144 -
 .../org/apache/iotdb/tsfile/utils/BytesUtils.java  |  877 ------
 .../java/org/apache/iotdb/tsfile/utils/Loader.java |   56 -
 .../apache/iotdb/tsfile/utils/Murmur128Hash.java   |  184 --
 .../java/org/apache/iotdb/tsfile/utils/Pair.java   |   83 -
 .../org/apache/iotdb/tsfile/utils/PublicBAOS.java  |   89 -
 .../iotdb/tsfile/utils/RamUsageEstimator.java      |  926 ------
 .../tsfile/utils/ReadWriteForEncodingUtils.java    |  341 ---
 .../iotdb/tsfile/utils/ReadWriteIOUtils.java       |  910 ------
 .../apache/iotdb/tsfile/utils/StringContainer.java |  388 ---
 .../apache/iotdb/tsfile/utils/TsPrimitiveType.java |  465 ---
 .../tsfile/v2/file/footer/ChunkGroupFooterV2.java  |   87 -
 .../iotdb/tsfile/v2/file/header/ChunkHeaderV2.java |  113 -
 .../iotdb/tsfile/v2/file/header/PageHeaderV2.java  |   49 -
 .../tsfile/v2/file/metadata/ChunkMetadataV2.java   |   51 -
 .../v2/file/metadata/MetadataIndexEntryV2.java     |   35 -
 .../v2/file/metadata/MetadataIndexNodeV2.java      |   45 -
 .../v2/file/metadata/TimeseriesMetadataV2.java     |   43 -
 .../tsfile/v2/file/metadata/TsFileMetadataV2.java  |   76 -
 .../v2/file/metadata/statistics/StatisticsV2.java  |  104 -
 .../tsfile/v2/read/TsFileSequenceReaderForV2.java  |  623 ----
 .../tsfile/v2/read/reader/page/PageReaderV2.java   |   94 -
 .../apache/iotdb/tsfile/write/TsFileWriter.java    |  365 ---
 .../tsfile/write/chunk/ChunkGroupWriterImpl.java   |  168 --
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |  460 ---
 .../tsfile/write/chunk/IChunkGroupWriter.java      |   91 -
 .../iotdb/tsfile/write/chunk/IChunkWriter.java     |   90 -
 .../apache/iotdb/tsfile/write/page/PageWriter.java |  291 --
 .../apache/iotdb/tsfile/write/record/TSRecord.java |   82 -
 .../apache/iotdb/tsfile/write/record/Tablet.java   |  235 --
 .../write/record/datapoint/BooleanDataPoint.java   |   62 -
 .../tsfile/write/record/datapoint/DataPoint.java   |  150 -
 .../write/record/datapoint/DoubleDataPoint.java    |   62 -
 .../write/record/datapoint/FloatDataPoint.java     |   62 -
 .../write/record/datapoint/IntDataPoint.java       |   62 -
 .../write/record/datapoint/LongDataPoint.java      |   62 -
 .../write/record/datapoint/StringDataPoint.java    |   63 -
 .../tsfile/write/schema/MeasurementSchema.java     |  326 ---
 .../apache/iotdb/tsfile/write/schema/Schema.java   |  108 -
 .../tsfile/write/schema/TimeseriesSchema.java      |  273 --
 .../write/writer/ForceAppendTsFileWriter.java      |   86 -
 .../iotdb/tsfile/write/writer/IDataWriter.java     |   21 -
 .../tsfile/write/writer/LocalTsFileOutput.java     |   89 -
 .../write/writer/RestorableTsFileIOWriter.java     |  244 --
 .../iotdb/tsfile/write/writer/TsFileIOWriter.java  |  460 ---
 .../iotdb/tsfile/write/writer/TsFileOutput.java    |   91 -
 .../apache/iotdb/tsfile/common/LRUCacheTest.java   |   55 -
 .../apache/iotdb/tsfile/compress/CompressTest.java |  106 -
 .../org/apache/iotdb/tsfile/compress/GZIPTest.java |   89 -
 .../org/apache/iotdb/tsfile/compress/LZ4Test.java  |   68 -
 .../apache/iotdb/tsfile/compress/SnappyTest.java   |   86 -
 .../apache/iotdb/tsfile/constant/TestConstant.java |   30 -
 .../iotdb/tsfile/encoding/SDTEncoderTest.java      |  177 --
 .../tsfile/encoding/bitpacking/IntPackerTest.java  |   79 -
 .../tsfile/encoding/bitpacking/LongPackerTest.java |  131 -
 .../tsfile/encoding/decoder/BitmapDecoderTest.java |   97 -
 .../tsfile/encoding/decoder/FloatDecoderTest.java  |  233 --
 .../encoding/decoder/GorillaDecoderV1Test.java     |  258 --
 .../encoding/decoder/GorillaDecoderV2Test.java     |  594 ----
 .../tsfile/encoding/decoder/IntRleDecoderTest.java |  218 --
 .../encoding/decoder/LongRleDecoderTest.java       |  221 --
 .../delta/DeltaBinaryEncoderIntegerTest.java       |  110 -
 .../decoder/delta/DeltaBinaryEncoderLongTest.java  |  201 --
 .../regular/RegularDataEncoderIntegerTest.java     |  157 -
 .../regular/RegularDataEncoderLongTest.java        |  252 --
 .../iotdb/tsfile/file/header/PageHeaderTest.java   |  108 -
 .../file/metadata/MetadataIndexNodeTest.java       |   50 -
 .../file/metadata/TimeSeriesMetadataTest.java      |  110 -
 .../tsfile/file/metadata/TsFileMetadataTest.java   |  106 -
 .../metadata/statistics/BooleanStatisticsTest.java |   83 -
 .../metadata/statistics/DoubleStatisticsTest.java  |   94 -
 .../metadata/statistics/FloatStatisticsTest.java   |   94 -
 .../metadata/statistics/IntegerStatisticsTest.java |   93 -
 .../metadata/statistics/LongStatisticsTest.java    |  121 -
 .../metadata/statistics/StringStatisticsTest.java  |   85 -
 .../tsfile/file/metadata/utils/TestHelper.java     |   73 -
 .../iotdb/tsfile/file/metadata/utils/Utils.java    |  170 --
 .../apache/iotdb/tsfile/read/ExpressionTest.java   |   61 -
 .../iotdb/tsfile/read/GetAllDevicesTest.java       |   85 -
 ...easurementChunkMetadataListMapIteratorTest.java |  197 --
 .../iotdb/tsfile/read/ReadInPartitionTest.java     |  230 --
 .../iotdb/tsfile/read/ReadOnlyTsFileTest.java      |  168 --
 .../org/apache/iotdb/tsfile/read/ReadTest.java     |  386 ---
 .../iotdb/tsfile/read/TimePlainEncodeReadTest.java |  379 ---
 .../tsfile/read/TimeSeriesMetadataReadTest.java    |   89 -
 .../tsfile/read/TsFileRestorableReaderTest.java    |   65 -
 .../tsfile/read/TsFileSequenceReaderTest.java      |  128 -
 .../iotdb/tsfile/read/common/BatchDataTest.java    |   82 -
 .../apache/iotdb/tsfile/read/common/FieldTest.java |   32 -
 .../apache/iotdb/tsfile/read/common/PathTest.java  |   49 -
 .../iotdb/tsfile/read/common/TimeRangeTest.java    |  432 ---
 .../tsfile/read/controller/ChunkLoaderTest.java    |   66 -
 .../controller/IMetadataQuerierByFileImplTest.java |  150 -
 .../tsfile/read/filter/FilterSerializeTest.java    |  100 -
 .../tsfile/read/filter/GroupByFilterTest.java      |  122 -
 .../tsfile/read/filter/GroupByMonthFilterTest.java |  226 --
 .../read/filter/IExpressionOptimizerTest.java      |  260 --
 .../read/filter/MinTimeMaxTimeFilterTest.java      |  214 --
 .../iotdb/tsfile/read/filter/OperatorTest.java     |  176 --
 .../tsfile/read/filter/StatisticsFilterTest.java   |  108 -
 .../read/query/executor/QueryExecutorTest.java     |  156 -
 .../tsfile/read/query/timegenerator/NodeTest.java  |  100 -
 .../read/query/timegenerator/ReadWriteTest.java    |  183 --
 .../query/timegenerator/ReaderByTimestampTest.java |  109 -
 .../timegenerator/TimeGeneratorReadEmptyTest.java  |  146 -
 .../timegenerator/TimeGeneratorReadWriteTest.java  |  182 --
 .../query/timegenerator/TimeGeneratorTest.java     |   90 -
 .../TsFileGeneratorForSeriesReaderByTimestamp.java |  267 --
 .../iotdb/tsfile/read/reader/FakedBatchReader.java |   55 -
 .../tsfile/read/reader/FakedMultiBatchReader.java  |   59 -
 .../tsfile/read/reader/FakedTimeGenerator.java     |   76 -
 .../iotdb/tsfile/read/reader/PageReaderTest.java   |  315 ---
 .../iotdb/tsfile/read/reader/ReaderTest.java       |  135 -
 .../apache/iotdb/tsfile/utils/BloomFilterTest.java |   66 -
 .../apache/iotdb/tsfile/utils/BytesUtilsTest.java  |  383 ---
 .../apache/iotdb/tsfile/utils/FileGenerator.java   |  312 --
 .../org/apache/iotdb/tsfile/utils/FileUtils.java   |   83 -
 .../apache/iotdb/tsfile/utils/FileUtilsTest.java   |   51 -
 .../org/apache/iotdb/tsfile/utils/PairTest.java    |   72 -
 .../utils/ReadWriteForEncodingUtilsTest.java       |   55 -
 .../iotdb/tsfile/utils/ReadWriteIOUtilsTest.java   |  140 -
 .../tsfile/utils/ReadWriteStreamUtilsTest.java     |  157 -
 .../tsfile/utils/ReadWriteToBytesUtilsTest.java    |   66 -
 .../org/apache/iotdb/tsfile/utils/RecordUtils.java |  113 -
 .../apache/iotdb/tsfile/utils/RecordUtilsTest.java |  186 --
 .../iotdb/tsfile/utils/StringContainerTest.java    |  175 --
 .../iotdb/tsfile/utils/TsFileGeneratorForTest.java |  250 --
 .../iotdb/tsfile/utils/TsPrimitiveTypeTest.java    |   60 -
 .../tsfile/write/DefaultDeviceTemplateTest.java    |  109 -
 .../org/apache/iotdb/tsfile/write/PerfTest.java    |  234 --
 .../iotdb/tsfile/write/ReadPageInMemTest.java      |  189 --
 ...SameMeasurementsWithDifferentDataTypesTest.java |  212 --
 .../iotdb/tsfile/write/TsFileIOWriterTest.java     |  122 -
 .../iotdb/tsfile/write/TsFileReadWriteTest.java    |  251 --
 .../iotdb/tsfile/write/TsFileWriterTest.java       |  314 --
 .../org/apache/iotdb/tsfile/write/WriteTest.java   |  284 --
 .../write/schema/converter/SchemaBuilderTest.java  |  127 -
 .../write/writer/ForceAppendTsFileWriterTest.java  |  121 -
 .../writer/MeasurementSchemaSerializeTest.java     |   57 -
 .../iotdb/tsfile/write/writer/PageWriterTest.java  |  219 --
 .../write/writer/RestorableTsFileIOWriterTest.java |  467 ---
 tsfile/src/test/resources/logback.xml              |  124 -
 zeppelin-interpreter/IoTDB-Zeppelin-Demo.zpln      |  377 ---
 zeppelin-interpreter/pom.xml                       |  151 -
 .../apache/zeppelin/iotdb/IoTDBInterpreter.java    |  296 --
 .../src/main/resources/interpreter-setting.json    |   70 -
 .../zeppelin/iotdb/IoTDBInterpreterTest.java       |  382 ---
 2262 files changed, 383885 deletions(-)
 delete mode 100644 Jenkinsfile
 delete mode 100644 LICENSE
 delete mode 100644 LICENSE-binary
 delete mode 100644 NOTICE
 delete mode 100644 NOTICE-binary
 delete mode 100644 README.md
 delete mode 100644 README_ZH.md
 delete mode 100644 RELEASE_NOTES.md
 delete mode 100644 antlr/pom.xml
 delete mode 100644 antlr/src/main/antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4
 delete mode 100644 asf.header
 delete mode 100644 checkstyle.xml
 delete mode 100644 cli/pom.xml
 delete mode 100644 cli/src/assembly/cli.xml
 delete mode 100644 cli/src/assembly/resources/sbin/start-cli.bat
 delete mode 100644 cli/src/assembly/resources/sbin/start-cli.sh
 delete mode 100644 cli/src/assembly/resources/tools/export-csv.bat
 delete mode 100644 cli/src/assembly/resources/tools/export-csv.sh
 delete mode 100644 cli/src/assembly/resources/tools/import-csv.bat
 delete mode 100644 cli/src/assembly/resources/tools/import-csv.sh
 delete mode 100644 cli/src/main/java/org/apache/iotdb/cli/AbstractCli.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/cli/Cli.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/cli/WinCli.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/cli/utils/IoTPrinter.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/exception/ArgsErrorException.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/tool/AbstractCsvTool.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/tool/ExportCsv.java
 delete mode 100644 cli/src/main/java/org/apache/iotdb/tool/ImportCsv.java
 delete mode 100644 cli/src/test/java/org/apache/iotdb/cli/AbstractCliIT.java
 delete mode 100644 cli/src/test/java/org/apache/iotdb/cli/AbstractScript.java
 delete mode 100644 cli/src/test/java/org/apache/iotdb/cli/StartClientScriptIT.java
 delete mode 100644 cli/src/test/java/org/apache/iotdb/tool/CsvLineSplitTest.java
 delete mode 100644 cli/src/test/java/org/apache/iotdb/tool/ExportCsvTestIT.java
 delete mode 100644 cli/src/test/java/org/apache/iotdb/tool/ImportCsvTestIT.java
 delete mode 100644 cli/src/test/resources/logback.xml
 delete mode 100644 client-cpp/README.md
 delete mode 100644 client-cpp/pom.xml
 delete mode 100644 client-cpp/src/assembly/client-cpp.xml
 delete mode 100644 client-cpp/src/main/Session.cpp
 delete mode 100644 client-cpp/src/main/Session.h
 delete mode 100644 client-cpp/src/test/cpp/sessionIT.cpp
 delete mode 100644 client-cpp/src/test/main.cpp
 delete mode 100644 client-py/.flake8
 delete mode 100644 client-py/.gitignore
 delete mode 100644 client-py/README.md
 delete mode 100644 client-py/SessionExample.py
 delete mode 100644 client-py/SessionTest.py
 delete mode 100644 client-py/iotdb/IoTDBContainer.py
 delete mode 100644 client-py/iotdb/Session.py
 delete mode 100644 client-py/iotdb/__init__.py
 delete mode 100644 client-py/iotdb/utils/Field.py
 delete mode 100644 client-py/iotdb/utils/IoTDBConstants.py
 delete mode 100644 client-py/iotdb/utils/IoTDBRpcDataSet.py
 delete mode 100644 client-py/iotdb/utils/RowRecord.py
 delete mode 100644 client-py/iotdb/utils/SessionDataSet.py
 delete mode 100644 client-py/iotdb/utils/Tablet.py
 delete mode 100644 client-py/iotdb/utils/__init__.py
 delete mode 100644 client-py/pom.xml
 delete mode 100644 client-py/pyproject.toml
 delete mode 100755 client-py/release.sh
 delete mode 100644 client-py/setup.py
 delete mode 100644 client-py/tests/__init__.py
 delete mode 100644 client-py/tests/test_dataframe.py
 delete mode 100644 cluster/pom.xml
 delete mode 100644 cluster/src/assembly/cluster.xml
 delete mode 100644 cluster/src/assembly/resources/conf/iotdb-cluster.properties
 delete mode 100755 cluster/src/assembly/resources/sbin/add-node.bat
 delete mode 100755 cluster/src/assembly/resources/sbin/add-node.sh
 delete mode 100755 cluster/src/assembly/resources/sbin/nodetool.bat
 delete mode 100755 cluster/src/assembly/resources/sbin/nodetool.sh
 delete mode 100755 cluster/src/assembly/resources/sbin/start-node.bat
 delete mode 100755 cluster/src/assembly/resources/sbin/start-node.sh
 delete mode 100644 cluster/src/assembly/resources/sbin/stop-node.bat
 delete mode 100644 cluster/src/assembly/resources/sbin/stop-node.sh
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/ClientMain.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/ClusterFileFlushPolicy.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/RemoteTsFileResource.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/DataClientProvider.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/async/AsyncClientFactory.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/async/AsyncClientPool.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/async/AsyncDataClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/async/AsyncDataHeartbeatClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/async/AsyncMetaClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/async/AsyncMetaHeartbeatClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncClientAdaptor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncClientFactory.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncClientPool.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncDataClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncDataHeartbeatClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncMetaClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/client/sync/SyncMetaHeartbeatClient.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterConfig.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterConstant.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterDescriptor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/config/ConsistencyLevel.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/coordinator/Coordinator.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/AddSelfException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/BadSeedUrlFormatException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/CheckConsistencyException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/ConfigInconsistentException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/EmptyIntervalException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/EntryCompactedException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/EntryUnavailableException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/GetEntriesWrongParametersException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/LeaderUnknownException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/LogExecutionException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/MemberReadOnlyException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/NoHeaderNodeException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/NotInSameGroupException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/NotManagedSlotException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/PartitionTableUnavailableException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/PullFileException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/QueryTimeOutException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/ReaderNotFoundException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/RequestTimeOutException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/SnapshotInstallationException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/StartUpCheckFailureException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/TruncateCommittedEntryException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/UnknownLogTypeException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/exception/UnsupportedPlanException.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/CommitLogCallback.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/CommitLogTask.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/HardState.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/Log.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/LogApplier.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/LogDispatcher.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/LogParser.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/Snapshot.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/StableEntryManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/applier/AsyncDataLogApplier.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/applier/BaseApplier.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/applier/DataLogApplier.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/applier/MetaLogApplier.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/catchup/CatchUpTask.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/catchup/LogCatchUpTask.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/catchup/SnapshotCatchUpTask.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/logtypes/AddNodeLog.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/logtypes/CloseFileLog.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/logtypes/EmptyContentLog.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/logtypes/LargeTestLog.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/logtypes/PhysicalPlanLog.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/logtypes/RemoveNodeLog.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/CommittedEntryManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/FilePartitionedSnapshotLogManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/MetaSingleSnapshotLogManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/PartitionedSnapshotLogManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/RaftLogManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/UnCommittedEntryManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/serializable/LogManagerMeta.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/manage/serializable/SyncLogDequeSerializer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/FileSnapshot.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/MetaSimpleSnapshot.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/PartitionedSnapshot.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/PullSnapshotTask.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/PullSnapshotTaskDescriptor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/SnapshotFactory.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/SnapshotInstaller.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/log/snapshot/TimeseriesSchemaSnapshot.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/metadata/CMManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/metadata/MetaPuller.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/NodeAdditionResult.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/NodeRemovalResult.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/PartitionGroup.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/PartitionTable.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/slot/SlotManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/slot/SlotNodeAdditionResult.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/slot/SlotNodeRemovalResult.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/slot/SlotPartitionTable.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/partition/slot/SlotStrategy.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterConcatPathOptimizer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterDataQueryExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterPhysicalGenerator.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterPlanExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterPlanRouter.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterPlanner.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterQueryRouter.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/LocalQueryExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/RemoteQueryContext.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/aggregate/ClusterAggregateExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/aggregate/ClusterAggregator.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/dataset/ClusterAlignByDeviceDataSet.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/fill/ClusterFillExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/fill/ClusterLinearFill.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/fill/ClusterPreviousFill.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/fill/PreviousFillArguments.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/filter/SlotSgFilter.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/filter/SlotTsFileFilter.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/groupby/ClusterGroupByNoVFilterDataSet.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/groupby/ClusterGroupByVFilterDataSet.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/groupby/MergeGroupByExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/groupby/RemoteGroupByExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/last/ClusterLastQueryExecutor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/manage/ClusterQueryManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/manage/QueryCoordinator.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/ClusterReaderFactory.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/ClusterTimeGenerator.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/DataSourceInfo.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/EmptyReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/ManagedMergeReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/MergedReaderByTime.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/RemoteSeriesReaderByTimestamp.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/RemoteSimpleSeriesReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/AbstractMultPointReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/AssignPathManagedMergeReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/AssignPathPriorityMergeReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/IMultBatchReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/MultBatchReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/MultDataSourceInfo.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/MultEmptyReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/MultSeriesRawDataPointReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/query/reader/mult/RemoteMultSeriesReader.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/ClientServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/DataClusterServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/HardLinkCleaner.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/MetaClusterServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/NodeCharacter.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/PullSnapshotHintService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/RaftServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/Response.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/StoppedMemberManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/AppendGroupEntryHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/AppendNodeEntryHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/ElectionHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/GenericHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/GetChildNodeNextLevelHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/GetChildNodeNextLevelPathHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/GetDevicesHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/GetNodesListHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/GetTimeseriesSchemaHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/HeartbeatHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/JoinClusterHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/LogCatchUpHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/LogCatchUpInBatchHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/NodeStatusHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/PreviousFillHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/PullMeasurementSchemaHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/PullSnapshotHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/PullTimeseriesSchemaHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/SnapshotCatchUpHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/package-info.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/forwarder/ForwardPlanHandler.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/heartbeat/DataHeartbeatServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/heartbeat/DataHeartbeatThread.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/heartbeat/HeartbeatServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/heartbeat/HeartbeatThread.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/heartbeat/MetaHeartbeatServer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/heartbeat/MetaHeartbeatThread.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/member/DataGroupMember.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/member/RaftMember.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/member/package-info.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/monitor/NodeReport.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/monitor/NodeStatus.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/monitor/NodeStatusManager.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/monitor/Peer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/monitor/Timer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/BaseAsyncService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/BaseSyncService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/DataAsyncService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/DataSyncService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/MetaAsyncService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/MetaSyncService.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/server/service/package-info.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/ClientUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterConsistent.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterQueryUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/IOUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/NodeSerializeUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/PartitionUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/PlanSerializer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/StatusUtils.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/ClusterMonitor.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/ClusterMonitorMBean.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/NodeTool.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/Printer.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/function/Host.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/function/LogView.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/function/NodeToolCmd.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/function/Partition.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/function/Ring.java
 delete mode 100644 cluster/src/main/java/org/apache/iotdb/cluster/utils/nodetool/function/Status.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/DataClientProviderTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncClientPoolTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncDataClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncDataHeartbeatClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncMetaClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncMetaHeartbeatClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/sync/SyncClientAdaptorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/sync/SyncClientPoolTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/sync/SyncDataClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/sync/SyncDataHeartbeatClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/sync/SyncMetaClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/client/sync/SyncMetaHeartbeatClientTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/IoTDBTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestAsyncClient.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestAsyncClientFactory.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestAsyncDataClient.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestAsyncMetaClient.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestDataGroupMember.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestException.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestLog.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestLogApplier.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestLogManager.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestManagedSeriesReader.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestMetaGroupMember.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestPartitionedLogManager.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestSnapshot.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestSyncClient.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestSyncClientFactory.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/common/TestUtils.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/integration/BaseSingleNodeTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/integration/SingleNodeTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/CommitLogCallbackTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/CommitLogTaskTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/HardStateTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/LogDispatcherTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/LogParserTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/applier/AsyncDataLogApplierTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/applier/DataLogApplierTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/applier/MetaLogApplierTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/catchup/CatchUpTaskTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/catchup/LogCatchUpTaskTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/catchup/SnapshotCatchUpTaskTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/logtypes/SerializeLogTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/manage/CommittedEntryManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/manage/FilePartitionedSnapshotLogManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/manage/MetaSingleSnapshotLogManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/manage/RaftLogManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/manage/UnCommittedEntryManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/manage/serializable/SyncLogDequeSerializerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/DataSnapshotTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/FileSnapshotTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/MetaSimpleSnapshotTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/PartitionedSnapshotTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/PullSnapshotTaskDescriptorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/PullSnapshotTaskTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/log/snapshot/SimpleSnapshot.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/partition/MManagerWhiteBox.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/partition/SlotManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/partition/SlotPartitionTableTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/BaseQueryTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterAggregateExecutorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterDataQueryExecutorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterFillExecutorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterPhysicalGeneratorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterPlanExecutorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterPlannerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/ClusterQueryRouterTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/LoadConfigurationTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/groupby/ClusterGroupByNoVFilterDataSetTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/groupby/ClusterGroupByVFilterDataSetTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/groupby/MergeGroupByExecutorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/groupby/RemoteGroupByExecutorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/manage/ClusterQueryManagerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/manage/QueryCoordinatorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/ClusterTimeGeneratorTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/DatasourceInfoTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/RemoteSeriesReaderByTimestampTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/RemoteSimpleSeriesReaderTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/mult/AssignPathManagedMergeReaderTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/mult/MultSeriesRawDataPointReaderTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/query/reader/mult/RemoteMultSeriesReaderTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/AppendGroupEntryHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/AppendNodeEntryHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/ElectionHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/GenericHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/HeartbeatHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/JoinClusterHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/LogCatchUpHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/PullMeasurementSchemaHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/PullSnapshotHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/caller/SnapshotCatchUpHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/handlers/forwarder/ForwardPlanHandlerTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/heartbeat/DataHeartbeatThreadTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/heartbeat/HeartbeatThreadTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/heartbeat/MetaHeartbeatThreadTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/member/BaseMember.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/member/DataGroupMemberTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/member/MetaGroupMemberTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/server/member/RaftMemberTest.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/utils/Constants.java
 delete mode 100644 cluster/src/test/java/org/apache/iotdb/cluster/utils/SerializeUtilTest.java
 delete mode 100644 cluster/src/test/resources/logback.xml
 delete mode 100644 cluster/src/test/resources/node1conf/iotdb-cluster.properties
 delete mode 100644 cluster/src/test/resources/node1conf/iotdb-engine.properties
 delete mode 100644 cluster/src/test/resources/node2conf/iotdb-cluster.properties
 delete mode 100644 cluster/src/test/resources/node2conf/iotdb-engine.properties
 delete mode 100644 cluster/src/test/resources/node3conf/iotdb-cluster.properties
 delete mode 100644 cluster/src/test/resources/node3conf/iotdb-engine.properties
 delete mode 100644 code-coverage/README.md
 delete mode 100755 code-coverage/copy-code-coverage-sources.sh
 delete mode 100644 code-coverage/pom.xml
 delete mode 100644 codecov.yml
 delete mode 100644 compile-tools/README.md
 delete mode 100644 compile-tools/pom.xml
 delete mode 100644 compile-tools/thrift/pom.xml
 delete mode 100644 cross-tests/pom.xml
 delete mode 100644 cross-tests/src/test/java/org/apache/iotdb/cross/tests/tools/importCsv/AbstractScript.java
 delete mode 100644 cross-tests/src/test/java/org/apache/iotdb/cross/tests/tools/importCsv/ExportCsvTestIT.java
 delete mode 100644 cross-tests/src/test/java/org/apache/iotdb/cross/tests/tools/importCsv/ImportCsvTestIT.java
 delete mode 100644 cross-tests/src/test/resources/iotdb-engine.properties
 delete mode 100644 distribution/pom.xml
 delete mode 100644 distribution/src/assembly/all.xml
 delete mode 100644 distribution/src/assembly/cli.xml
 delete mode 100644 distribution/src/assembly/client-cpp.xml
 delete mode 100644 distribution/src/assembly/cluster.xml
 delete mode 100644 distribution/src/assembly/common-files.xml
 delete mode 100644 distribution/src/assembly/grafana.xml
 delete mode 100644 distribution/src/assembly/server.xml
 delete mode 100644 docker/ReadMe.md
 delete mode 100644 docker/src/main/Dockerfile
 delete mode 100644 docker/src/main/Dockerfile-0.10.0
 delete mode 100644 docker/src/main/Dockerfile-0.10.1
 delete mode 100644 docker/src/main/Dockerfile-0.11.0
 delete mode 100644 docker/src/main/Dockerfile-0.11.1
 delete mode 100644 docker/src/main/Dockerfile-0.11.2
 delete mode 100644 docker/src/main/Dockerfile-0.8.1
 delete mode 100644 docker/src/main/Dockerfile-0.9.0
 delete mode 100644 docker/src/main/Dockerfile-0.9.1
 delete mode 100644 docker/src/main/Dockerfile-0.9.1-jre8
 delete mode 100644 docs/Blog/Release0_93.md
 delete mode 100644 docs/Blog/index.md
 delete mode 100644 docs/Community/Community-Powered By.md
 delete mode 100644 docs/Community/Community-Project Committers.md
 delete mode 100644 docs/Community/Feedback.md
 delete mode 100644 docs/Community/Materials.md
 delete mode 100644 docs/Development/Committer.md
 delete mode 100644 docs/Development/ContributeGuide.md
 delete mode 100644 docs/Development/HowToCommit.md
 delete mode 100644 docs/Development/VoteRelease.md
 delete mode 100644 docs/Download/README.md
 delete mode 100644 docs/README.md
 delete mode 100644 docs/SystemDesign/Architecture/Architecture.md
 delete mode 100644 docs/SystemDesign/Client/RPC.md
 delete mode 100644 docs/SystemDesign/Connector/Hive-TsFile.md
 delete mode 100644 docs/SystemDesign/Connector/Spark-IOTDB.md
 delete mode 100644 docs/SystemDesign/Connector/Spark-TsFile.md
 delete mode 100644 docs/SystemDesign/DataQuery/AggregationQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/AlignByDeviceQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/DataQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/FillFunction.md
 delete mode 100644 docs/SystemDesign/DataQuery/GroupByFillQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/GroupByQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/LastQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/QueryFundamentals.md
 delete mode 100644 docs/SystemDesign/DataQuery/RawDataQuery.md
 delete mode 100644 docs/SystemDesign/DataQuery/SeriesReader.md
 delete mode 100644 docs/SystemDesign/QueryEngine/PlanExecutor.md
 delete mode 100644 docs/SystemDesign/QueryEngine/Planner.md
 delete mode 100644 docs/SystemDesign/QueryEngine/QueryEngine.md
 delete mode 100644 docs/SystemDesign/QueryEngine/ResultSetConstruction.md
 delete mode 100644 docs/SystemDesign/SchemaManager/SchemaManager.md
 delete mode 100644 docs/SystemDesign/StorageEngine/DataManipulation.md
 delete mode 100644 docs/SystemDesign/StorageEngine/DataPartition.md
 delete mode 100644 docs/SystemDesign/StorageEngine/FlushManager.md
 delete mode 100644 docs/SystemDesign/StorageEngine/MergeManager.md
 delete mode 100644 docs/SystemDesign/StorageEngine/Recover.md
 delete mode 100644 docs/SystemDesign/StorageEngine/StorageEngine.md
 delete mode 100644 docs/SystemDesign/StorageEngine/WAL.md
 delete mode 100644 docs/SystemDesign/Tools/Sync.md
 delete mode 100644 docs/SystemDesign/TsFile/Format.md
 delete mode 100644 docs/SystemDesign/TsFile/Read.md
 delete mode 100644 docs/SystemDesign/TsFile/TsFile.md
 delete mode 100644 docs/SystemDesign/TsFile/Write.md
 delete mode 100644 docs/UserGuide/API/Programming-JDBC.md
 delete mode 100644 docs/UserGuide/API/Programming-Native-API.md
 delete mode 100644 docs/UserGuide/API/Programming-Other-Languages.md
 delete mode 100644 docs/UserGuide/API/Programming-TsFile-API.md
 delete mode 100644 docs/UserGuide/Administration-Management/Administration.md
 delete mode 100644 docs/UserGuide/Appendix/Config-Manual.md
 delete mode 100644 docs/UserGuide/Appendix/SQL-Reference.md
 delete mode 100644 docs/UserGuide/Appendix/Status-Codes.md
 delete mode 100644 docs/UserGuide/CLI/Command-Line-Interface.md
 delete mode 100644 docs/UserGuide/Cluster/Cluster-Setup-Example.md
 delete mode 100644 docs/UserGuide/Cluster/Cluster-Setup.md
 delete mode 100644 docs/UserGuide/Collaboration-of-Edge-and-Cloud/Sync-Tool.md
 delete mode 100644 docs/UserGuide/Communication-Service-Protocol/Programming-MQTT.md
 delete mode 100644 docs/UserGuide/Communication-Service-Protocol/Programming-Thrift.md
 delete mode 100644 docs/UserGuide/Comparison/TSDB-Comparison.md
 delete mode 100644 docs/UserGuide/Data-Concept/Compression.md
 delete mode 100644 docs/UserGuide/Data-Concept/Data-Model-and-Terminology.md
 delete mode 100644 docs/UserGuide/Data-Concept/Data-Type.md
 delete mode 100644 docs/UserGuide/Data-Concept/Encoding.md
 delete mode 100644 docs/UserGuide/Data-Concept/SDT.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Flink IoTDB.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Flink TsFile.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Grafana.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Hive TsFile.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/MapReduce TsFile.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Spark IoTDB.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Spark TsFile.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Writing Data on HDFS.md
 delete mode 100644 docs/UserGuide/Ecosystem Integration/Zeppelin-IoTDB.md
 delete mode 100644 docs/UserGuide/FAQ/Frequently-asked-questions.md
 delete mode 100644 docs/UserGuide/IoTDB-Introduction/Architecture.md
 delete mode 100644 docs/UserGuide/IoTDB-Introduction/Features.md
 delete mode 100644 docs/UserGuide/IoTDB-Introduction/Publication.md
 delete mode 100644 docs/UserGuide/IoTDB-Introduction/Scenario.md
 delete mode 100644 docs/UserGuide/IoTDB-Introduction/What-is-IoTDB.md
 delete mode 100644 docs/UserGuide/IoTDB-SQL-Language/DDL-Data-Definition-Language.md
 delete mode 100644 docs/UserGuide/IoTDB-SQL-Language/DML-Data-Manipulation-Language.md
 delete mode 100644 docs/UserGuide/IoTDB-SQL-Language/Maintenance-Command.md
 delete mode 100644 docs/UserGuide/QuickStart/Files.md
 delete mode 100644 docs/UserGuide/QuickStart/QuickStart.md
 delete mode 100644 docs/UserGuide/QuickStart/ServerFileList.md
 delete mode 100644 docs/UserGuide/QuickStart/WayToGetIoTDB.md
 delete mode 100644 docs/UserGuide/System-Tools/CSV-Tool.md
 delete mode 100644 docs/UserGuide/System-Tools/JMX-Tool.md
 delete mode 100644 docs/UserGuide/System-Tools/Load-External-Tsfile.md
 delete mode 100644 docs/UserGuide/System-Tools/MLogParser-Tool.md
 delete mode 100644 docs/UserGuide/System-Tools/Monitor-and-Log-Tools.md
 delete mode 100644 docs/UserGuide/System-Tools/NodeTool.md
 delete mode 100644 docs/UserGuide/System-Tools/Performance-Tracing-Tool.md
 delete mode 100644 docs/UserGuide/System-Tools/Query-History-Visualization-Tool.md
 delete mode 100644 docs/UserGuide/System-Tools/Watermark-Tool.md
 delete mode 100644 docs/UserGuide/UDF/Triggers.md
 delete mode 100644 docs/UserGuide/UDF/UDF-User-Defined-Function.md
 delete mode 100644 docs/UserGuide/UserGuideReadme.md
 delete mode 100644 docs/zh/Community/Community-Powered By.md
 delete mode 100644 docs/zh/Community/Community-Project Committers.md
 delete mode 100644 docs/zh/Community/Feedback.md
 delete mode 100644 docs/zh/Development/Committer.md
 delete mode 100644 docs/zh/Development/ContributeGuide.md
 delete mode 100644 docs/zh/Development/HowToCommit.md
 delete mode 100644 docs/zh/Development/VoteRelease.md
 delete mode 100644 docs/zh/Download/README.md
 delete mode 100644 docs/zh/README.md
 delete mode 100644 docs/zh/SystemDesign/Architecture/Architecture.md
 delete mode 100644 docs/zh/SystemDesign/Client/RPC.md
 delete mode 100644 docs/zh/SystemDesign/Connector/Hive-TsFile.md
 delete mode 100644 docs/zh/SystemDesign/Connector/Spark-IOTDB.md
 delete mode 100644 docs/zh/SystemDesign/Connector/Spark-TsFile.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/AggregationQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/AlignByDeviceQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/DataQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/FillFunction.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/GroupByFillQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/GroupByQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/LastQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/OrderByTimeQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/QueryFundamentals.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/RawDataQuery.md
 delete mode 100644 docs/zh/SystemDesign/DataQuery/SeriesReader.md
 delete mode 100644 docs/zh/SystemDesign/QueryEngine/PlanExecutor.md
 delete mode 100644 docs/zh/SystemDesign/QueryEngine/Planner.md
 delete mode 100644 docs/zh/SystemDesign/QueryEngine/QueryEngine.md
 delete mode 100644 docs/zh/SystemDesign/QueryEngine/ResultSetConstruction.md
 delete mode 100644 docs/zh/SystemDesign/SchemaManager/SchemaManager.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/Compaction.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/DataManipulation.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/DataPartition.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/FileLists.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/FlushManager.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/MergeManager.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/Recover.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/StorageEngine.md
 delete mode 100644 docs/zh/SystemDesign/StorageEngine/WAL.md
 delete mode 100644 docs/zh/SystemDesign/Tools/Sync.md
 delete mode 100644 docs/zh/SystemDesign/TsFile/Format.md
 delete mode 100644 docs/zh/SystemDesign/TsFile/Read.md
 delete mode 100644 docs/zh/SystemDesign/TsFile/TsFile.md
 delete mode 100644 docs/zh/SystemDesign/TsFile/Write.md
 delete mode 100644 docs/zh/UserGuide/API/Programming-JDBC.md
 delete mode 100644 docs/zh/UserGuide/API/Programming-Native-API.md
 delete mode 100644 docs/zh/UserGuide/API/Programming-Other-Languages.md
 delete mode 100644 docs/zh/UserGuide/API/Programming-TsFile-API.md
 delete mode 100644 docs/zh/UserGuide/Administration-Management/Administration.md
 delete mode 100644 docs/zh/UserGuide/Appendix/Config-Manual.md
 delete mode 100644 docs/zh/UserGuide/Appendix/SQL-Reference.md
 delete mode 100644 docs/zh/UserGuide/Appendix/Status-Codes.md
 delete mode 100644 docs/zh/UserGuide/CLI/Command-Line-Interface.md
 delete mode 100644 docs/zh/UserGuide/Cluster/Cluster-Setup-Example.md
 delete mode 100644 docs/zh/UserGuide/Cluster/Cluster-Setup.md
 delete mode 100644 docs/zh/UserGuide/Collaboration-of-Edge-and-Cloud/Sync-Tool.md
 delete mode 100644 docs/zh/UserGuide/Communication-Service-Protocol/Programming-MQTT.md
 delete mode 100644 docs/zh/UserGuide/Communication-Service-Protocol/Programming-Thrift.md
 delete mode 100644 docs/zh/UserGuide/Data-Concept/Compression.md
 delete mode 100644 docs/zh/UserGuide/Data-Concept/Data-Model-and-Terminology.md
 delete mode 100644 docs/zh/UserGuide/Data-Concept/Data-Type.md
 delete mode 100644 docs/zh/UserGuide/Data-Concept/Encoding.md
 delete mode 100644 docs/zh/UserGuide/Data-Concept/SDT.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Flink IoTDB.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Flink TsFile.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Grafana.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Hive TsFile.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/MapReduce TsFile.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Spark IoTDB.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Spark TsFile.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Writing Data on HDFS.md
 delete mode 100644 docs/zh/UserGuide/Ecosystem Integration/Zeppelin-IoTDB.md
 delete mode 100644 docs/zh/UserGuide/FAQ/Frequently-asked-questions.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-Introduction/Architecture.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-Introduction/Features.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-Introduction/Publication.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-Introduction/Scenario.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-Introduction/What-is-IoTDB.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-SQL-Language/DDL-Data-Definition-Language.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-SQL-Language/DML-Data-Manipulation-Language.md
 delete mode 100644 docs/zh/UserGuide/IoTDB-SQL-Language/Maintenance-Command.md
 delete mode 100644 docs/zh/UserGuide/QuickStart/Files.md
 delete mode 100644 docs/zh/UserGuide/QuickStart/QuickStart.md
 delete mode 100644 docs/zh/UserGuide/QuickStart/ServerFileList.md
 delete mode 100644 docs/zh/UserGuide/QuickStart/WayToGetIoTDB.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/CSV-Tool.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/JMX-Tool.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/Load-External-Tsfile.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/MLogParser-Tool.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/Monitor-and-Log-Tools.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/NodeTool.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/Performance-Tracing-Tool.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/Query-History-Visualization-Tool.md
 delete mode 100644 docs/zh/UserGuide/System-Tools/Watermark-Tool.md
 delete mode 100644 docs/zh/UserGuide/UDF/Triggers.md
 delete mode 100644 docs/zh/UserGuide/UDF/UDF-User-Defined-Function.md
 delete mode 100644 docs/zh/UserGuide/UserGuideReadme.md
 delete mode 100644 docs/zh/chinese-render-template.latex
 delete mode 100644 example/client-cpp-example/README.md
 delete mode 100644 example/client-cpp-example/pom.xml
 delete mode 100644 example/client-cpp-example/src/SessionExample.cpp
 delete mode 100644 example/flink/README.md
 delete mode 100644 example/flink/pom.xml
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/FlinkIoTDBSink.java
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/FlinkIoTDBSource.java
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/FlinkTsFileBatchSink.java
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/FlinkTsFileBatchSource.java
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/FlinkTsFileStreamSink.java
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/FlinkTsFileStreamSource.java
 delete mode 100644 example/flink/src/main/java/org/apache/iotdb/flink/TsFileUtils.java
 delete mode 100644 example/hadoop/pom.xml
 delete mode 100644 example/hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/Constant.java
 delete mode 100644 example/hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFMRReadExample.java
 delete mode 100644 example/hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSMRWriteExample.java
 delete mode 100644 example/hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TsFileHelper.java
 delete mode 100644 example/hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TsFileWriteToHDFS.java
 delete mode 100644 example/jdbc/pom.xml
 delete mode 100644 example/jdbc/src/main/java/org/apache/iotdb/JDBCExample.java
 delete mode 100644 example/jdbc/src/main/java/org/apache/iotdb/PrepareStatementDemo.java
 delete mode 100644 example/kafka/pom.xml
 delete mode 100644 example/kafka/readme.md
 delete mode 100644 example/kafka/src/main/java/org/apache/iotdb/kafka/Constant.java
 delete mode 100644 example/kafka/src/main/java/org/apache/iotdb/kafka/KafkaConsumer.java
 delete mode 100644 example/kafka/src/main/java/org/apache/iotdb/kafka/KafkaConsumerThread.java
 delete mode 100644 example/kafka/src/main/java/org/apache/iotdb/kafka/KafkaProducer.java
 delete mode 100644 example/mqtt/README.md
 delete mode 100644 example/mqtt/pom.xml
 delete mode 100644 example/mqtt/src/main/java/org/apache/iotdb/mqtt/MQTTClient.java
 delete mode 100644 example/pom.xml
 delete mode 100644 example/pulsar/pom.xml
 delete mode 100644 example/pulsar/src/main/java/org/apache/iotdb/pulsar/Constant.java
 delete mode 100644 example/pulsar/src/main/java/org/apache/iotdb/pulsar/PulsarConsumer.java
 delete mode 100644 example/pulsar/src/main/java/org/apache/iotdb/pulsar/PulsarConsumerThread.java
 delete mode 100644 example/pulsar/src/main/java/org/apache/iotdb/pulsar/PulsarProducer.java
 delete mode 100644 example/rocketmq/pom.xml
 delete mode 100644 example/rocketmq/readme.md
 delete mode 100644 example/rocketmq/src/main/java/org/apache/iotdb/rocketmq/Constant.java
 delete mode 100644 example/rocketmq/src/main/java/org/apache/iotdb/rocketmq/RocketMQConsumer.java
 delete mode 100644 example/rocketmq/src/main/java/org/apache/iotdb/rocketmq/RocketMQProducer.java
 delete mode 100644 example/rocketmq/src/main/java/org/apache/iotdb/rocketmq/Utils.java
 delete mode 100644 example/session/pom.xml
 delete mode 100644 example/session/src/main/java/org/apache/iotdb/DataMigrationExample.java
 delete mode 100644 example/session/src/main/java/org/apache/iotdb/SessionExample.java
 delete mode 100644 example/session/src/main/java/org/apache/iotdb/SessionPoolExample.java
 delete mode 100644 example/session/src/main/java/org/apache/iotdb/Write.java
 delete mode 100644 example/tsfile/pom.xml
 delete mode 100644 example/tsfile/readme.md
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/Constant.java
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/TsFileForceAppendWrite.java
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/TsFileRead.java
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/TsFileSequenceRead.java
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/TsFileWriteWithTSRecord.java
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/TsFileWriteWithTablet.java
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/tlsm_compaction.properties
 delete mode 100644 example/tsfile/src/main/java/org/apache/iotdb/tsfile/tlsm_write.properties
 delete mode 100644 example/udf/pom.xml
 delete mode 100644 example/udf/src/main/java/org/apache/iotdb/udf/UDTFExample.java
 delete mode 100644 flink-iotdb-connector/README.md
 delete mode 100644 flink-iotdb-connector/pom.xml
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/DefaultIoTSerializationSchema.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/Event.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/IoTDBSink.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/IoTDBSource.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/IoTSerializationSchema.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/options/IoTDBOptions.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/options/IoTDBSinkOptions.java
 delete mode 100644 flink-iotdb-connector/src/main/java/org/apache/iotdb/flink/options/IoTDBSourceOptions.java
 delete mode 100644 flink-iotdb-connector/src/test/java/org/apache/iotdb/flink/DefaultIoTSerializationSchemaTest.java
 delete mode 100644 flink-iotdb-connector/src/test/java/org/apache/iotdb/flink/IoTDBSinkBatchInsertTest.java
 delete mode 100644 flink-iotdb-connector/src/test/java/org/apache/iotdb/flink/IoTDBSinkBatchTimerTest.java
 delete mode 100644 flink-iotdb-connector/src/test/java/org/apache/iotdb/flink/IoTDBSinkInsertTest.java
 delete mode 100644 flink-tsfile-connector/README.md
 delete mode 100644 flink-tsfile-connector/pom.xml
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/RowRecordParser.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/RowRowRecordParser.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/RowTSRecordConverter.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/TSRecordConverter.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/TSRecordOutputFormat.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/TsFileInputFormat.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/TsFileOutputFormat.java
 delete mode 100644 flink-tsfile-connector/src/main/java/org/apache/iotdb/flink/tsfile/util/TSFileConfigUtil.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTSRecordOutputFormatITCase.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTSRecordOutputFormatTest.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTsFileConnectorTestBase.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTsFileInputFormatITCase.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTsFileInputFormatTest.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTsFileInputFormatTestBase.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/tsfile/RowTsFileOutputFormatTestBase.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/util/TSFileConfigUtilCompletenessTest.java
 delete mode 100644 flink-tsfile-connector/src/test/java/org/apache/iotdb/flink/util/TsFileWriteUtil.java
 delete mode 100644 grafana/img/add_data_source.png
 delete mode 100644 grafana/img/add_graph.png
 delete mode 100644 grafana/img/edit_data_source.png
 delete mode 100644 grafana/pom.xml
 delete mode 100644 grafana/readme.md
 delete mode 100644 grafana/readme_zh.md
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/TsfileWebDemoApplication.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/bean/TimeValues.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/conf/MyConfiguration.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/controller/DatabaseConnectController.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/dao/BasicDao.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/dao/impl/BasicDaoImpl.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/service/DatabaseConnectService.java
 delete mode 100644 grafana/src/main/java/org/apache/iotdb/web/grafana/service/impl/DatabaseConnectServiceImpl.java
 delete mode 100644 grafana/src/main/resources/application.properties
 delete mode 100644 grafana/src/test/java/org/apache/iotdb/web/grafana/dao/impl/BasicDaoImplTest.java
 delete mode 100644 hadoop/README.md
 delete mode 100644 hadoop/pom.xml
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/fileSystem/HDFSConfUtil.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/fileSystem/HDFSFile.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/fileSystem/HDFSInput.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/fileSystem/HDFSOutput.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/IReaderSet.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFHadoopException.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFInputFormat.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFInputSplit.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFOutputFormat.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFRecordReader.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/TSFRecordWriter.java
 delete mode 100644 hadoop/src/main/java/org/apache/iotdb/hadoop/tsfile/record/HDFSTSRecord.java
 delete mode 100644 hadoop/src/test/java/org/apache/iotdb/hadoop/tsfile/TSFHadoopTest.java
 delete mode 100644 hadoop/src/test/java/org/apache/iotdb/hadoop/tsfile/TSFInputSplitTest.java
 delete mode 100644 hadoop/src/test/java/org/apache/iotdb/hadoop/tsfile/TsFileTestHelper.java
 delete mode 100644 hadoop/src/test/java/org/apache/iotdb/hadoop/tsfile/constant/TestConstant.java
 delete mode 100644 hadoop/src/test/resources/logback.xml
 delete mode 100644 hive-connector/pom.xml
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TSFHiveInputFormat.java
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TSFHiveOutputFormat.java
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TSFHiveRecordReader.java
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TSFHiveRecordWriter.java
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TsFileDeserializer.java
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TsFileSerDe.java
 delete mode 100644 hive-connector/src/main/java/org/apache/iotdb/hive/TsFileSerDeException.java
 delete mode 100644 hive-connector/src/test/java/org/apache/iotdb/hive/TSFHiveInputFormatTest.java
 delete mode 100644 hive-connector/src/test/java/org/apache/iotdb/hive/TSFHiveRecordReaderTest.java
 delete mode 100644 hive-connector/src/test/java/org/apache/iotdb/hive/TsFileDeserializerTest.java
 delete mode 100644 hive-connector/src/test/java/org/apache/iotdb/hive/TsFileSerDeTest.java
 delete mode 100644 hive-connector/src/test/java/org/apache/iotdb/hive/TsFileTestHelper.java
 delete mode 100644 hive-connector/src/test/java/org/apache/iotdb/hive/constant/TestConstant.java
 delete mode 100644 hive-connector/src/test/resources/logback.xml
 delete mode 100644 java-google-style.xml
 delete mode 100644 jdbc/README.md
 delete mode 100644 jdbc/osgi.bnd
 delete mode 100644 jdbc/pom.xml
 delete mode 100644 jdbc/src/main/feature/feature.xml
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/AbstractIoTDBJDBCResultSet.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/Activator.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/Config.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/Constant.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBConnection.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBConnectionParams.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBDataSource.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBDataSourceFactory.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBDatabaseMetadata.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBDriver.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBJDBCResultSet.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBNonAlignJDBCResultSet.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBPreparedStatement.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBResultMetadata.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBSQLException.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBStatement.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/IoTDBURLException.java
 delete mode 100644 jdbc/src/main/java/org/apache/iotdb/jdbc/Utils.java
 delete mode 100644 jdbc/src/main/resources/services/META-INF/java.sql.Driver
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/BatchTest.java
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/IoTDBConnectionTest.java
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/IoTDBJDBCResultSetTest.java
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/IoTDBPreparedStatementTest.java
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/IoTDBResultMetadataTest.java
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/IoTDBStatementTest.java
 delete mode 100644 jdbc/src/test/java/org/apache/iotdb/jdbc/UtilsTest.java
 delete mode 100644 jenkins.pom
 delete mode 100644 licenses/CDDL License 1.1
 delete mode 100644 licenses/Eclipse Public License 1.0 (EPL-1.0)
 delete mode 100644 licenses/Eclipse Public License version 2.0 (EPL-2.0)
 delete mode 100644 licenses/The 2-Clause BSD License
 delete mode 100644 licenses/The 3-Clause BSD License
 delete mode 100644 licenses/The MIT License (QOS.ch)
 delete mode 100644 licenses/The MIT License (progressbar)
 delete mode 100644 mvnw.cmd
 delete mode 100755 mvnw.sh
 delete mode 100644 pom.xml
 delete mode 100644 separation_py/SeparationServer.py
 delete mode 100644 separation_py/gen-java/SeparationTunningService.java
 delete mode 100644 separation_py/gen-py/__init__.py
 delete mode 100644 separation_py/org/__init__.py
 delete mode 100644 separation_py/org/apache/__init__.py
 delete mode 100644 separation_py/org/apache/iotdb/__init__.py
 delete mode 100755 separation_py/org/apache/iotdb/separation_py/SeparationTunningService-remote
 delete mode 100644 separation_py/org/apache/iotdb/separation_py/SeparationTunningService.py
 delete mode 100644 separation_py/org/apache/iotdb/separation_py/__init__.py
 delete mode 100644 separation_py/org/apache/iotdb/separation_py/constants.py
 delete mode 100755 separation_py/org/apache/iotdb/separation_py/hlsm.py
 delete mode 100755 separation_py/org/apache/iotdb/separation_py/tools.py
 delete mode 100644 separation_py/org/apache/iotdb/separation_py/ttypes.py
 delete mode 100644 separation_py/separation.thrift
 delete mode 100644 server/file-changelists/TsFileMods-changelist.md
 delete mode 100644 server/file-changelists/TsFileResource-changelist.md
 delete mode 100644 server/file-changelists/conf-changelist.md
 delete mode 100644 server/file-changelists/mlog-changelist.md
 delete mode 100644 server/file-changelists/role-changelist.md
 delete mode 100644 server/file-changelists/system.properties-changelist.md
 delete mode 100644 server/file-changelists/tlog-changelist.md
 delete mode 100644 server/file-changelists/user-changelist.md
 delete mode 100644 server/file-changelists/wal-changelist.md
 delete mode 100644 server/pom.xml
 delete mode 100644 server/server-changelist.md
 delete mode 100644 server/src/assembly/resources/conf/iotdb-engine.properties
 delete mode 100755 server/src/assembly/resources/conf/iotdb-env.bat
 delete mode 100755 server/src/assembly/resources/conf/iotdb-env.sh
 delete mode 100644 server/src/assembly/resources/conf/iotdb-sync-client.properties
 delete mode 100644 server/src/assembly/resources/conf/jmx.access
 delete mode 100644 server/src/assembly/resources/conf/jmx.password
 delete mode 100644 server/src/assembly/resources/conf/logback-tool.xml
 delete mode 100644 server/src/assembly/resources/conf/logback.xml
 delete mode 100755 server/src/assembly/resources/sbin/start-server.bat
 delete mode 100755 server/src/assembly/resources/sbin/start-server.sh
 delete mode 100755 server/src/assembly/resources/sbin/stop-server.bat
 delete mode 100755 server/src/assembly/resources/sbin/stop-server.sh
 delete mode 100644 server/src/assembly/resources/tools/detect-watermark.bat
 delete mode 100644 server/src/assembly/resources/tools/detect-watermark.sh
 delete mode 100644 server/src/assembly/resources/tools/mlog/mLogParser.bat
 delete mode 100644 server/src/assembly/resources/tools/mlog/mLogParser.sh
 delete mode 100644 server/src/assembly/resources/tools/start-WalChecker.bat
 delete mode 100755 server/src/assembly/resources/tools/start-WalChecker.sh
 delete mode 100755 server/src/assembly/resources/tools/start-sync-client.bat
 delete mode 100755 server/src/assembly/resources/tools/start-sync-client.sh
 delete mode 100755 server/src/assembly/resources/tools/stop-sync-client.bat
 delete mode 100755 server/src/assembly/resources/tools/stop-sync-client.sh
 delete mode 100644 server/src/assembly/resources/tools/tsfileToolSet/print-iotdb-data-dir.bat
 delete mode 100644 server/src/assembly/resources/tools/tsfileToolSet/print-iotdb-data-dir.sh
 delete mode 100644 server/src/assembly/resources/tools/tsfileToolSet/print-tsfile-resource-files.bat
 delete mode 100755 server/src/assembly/resources/tools/tsfileToolSet/print-tsfile-resource-files.sh
 delete mode 100644 server/src/assembly/resources/tools/tsfileToolSet/print-tsfile-sketch.bat
 delete mode 100755 server/src/assembly/resources/tools/tsfileToolSet/print-tsfile-sketch.sh
 delete mode 100644 server/src/assembly/server.xml
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/AuthException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/AuthorityChecker.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/authorizer/BasicAuthorizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/authorizer/IAuthorizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/authorizer/LocalFileAuthorizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/authorizer/OpenIdAuthorizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/entity/PathPrivilege.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/entity/PrivilegeType.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/entity/Role.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/entity/User.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/role/BasicRoleManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/role/IRoleAccessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/role/IRoleManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/role/LocalFileRoleAccessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/role/LocalFileRoleManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/user/BasicUserManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/user/IUserAccessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/user/IUserManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/user/LocalFileUserAccessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/auth/user/LocalFileUserManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/concurrent/HashLock.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/concurrent/IoTDBDefaultThreadExceptionHandler.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/concurrent/IoTDBThreadPoolFactory.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/concurrent/IoTThreadFactory.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/concurrent/ThreadName.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/concurrent/WrappedRunnable.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/IoTDBConfig.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/IoTDBConfigCheck.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/IoTDBConstant.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/IoTDBDescriptor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/ServerConfigConsistent.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/adapter/CompressionRatio.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/directories/DirectoryManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/directories/strategy/DirectoryStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/directories/strategy/MaxDiskUsableSpaceFirstStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/directories/strategy/MinFolderOccupiedSpaceFirstStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/directories/strategy/RandomOnDiskUsableSpaceStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/conf/directories/strategy/SequenceStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/cost/statistic/ConcurrentCircularArray.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/cost/statistic/Measurement.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/cost/statistic/MeasurementMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/cost/statistic/Operation.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/StorageEngine.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/cache/AccountableString.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/cache/CacheHitRatioMonitor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/cache/CacheHitRatioMonitorMXBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/cache/ChunkCache.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/cache/LRULinkedHashMap.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/cache/TimeSeriesMetadataCache.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/CompactionMergeTaskPoolManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/CompactionStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/TsFileManagement.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/level/LevelCompactionTsFileManagement.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/level/TraditionalLevelCompactionTsFileManagement.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/no/NoCompactionTsFileManagement.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/utils/CompactionLogAnalyzer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/utils/CompactionLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/utils/CompactionSeparateFileUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/utils/CompactionUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/fileSystem/SystemFileFactory.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/CloseFileListener.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/FlushListener.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/FlushManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/FlushManagerMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/MemTableFlushTask.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/NotifyFlushMemTable.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/TsFileFlushPolicy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/pool/AbstractPoolManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/pool/FlushSubTaskPoolManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/flush/pool/FlushTaskPoolManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/memtable/AbstractMemTable.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/memtable/IMemTable.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/memtable/IWritableMemChunk.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/memtable/PrimitiveMemTable.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/memtable/WritableMemChunk.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/manage/MergeContext.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/manage/MergeFuture.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/manage/MergeManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/manage/MergeManagerMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/manage/MergeResource.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/manage/MergeThreadPool.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/package-info.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/recover/LogAnalyzer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/recover/MergeLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/IFileQueryMemMeasurement.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/IMergeFileSelector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/IMergePathSelector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/MaxFileMergeFileSelector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/MaxSeriesMergeFileSelector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/MergeFileStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/selector/NaivePathSelector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/task/MergeCallback.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/task/MergeFileTask.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/task/MergeMultiChunkTask.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/task/MergeTask.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/merge/task/RecoverMergeTask.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/Deletion.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/Modification.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/ModificationFile.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/io/LocalTextModificationAccessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/io/ModificationReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/io/ModificationWriter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/modification/package-info.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/querycontext/QueryDataSource.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/querycontext/ReadOnlyMemChunk.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/StorageGroupInfo.java
 delete mode 100755 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/StorageGroupProcessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/TsFileLock.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/TsFileProcessor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/TsFileProcessorInfo.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/TsFileResource.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/timeindex/DeviceTimeIndex.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/timeindex/FileTimeIndex.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/timeindex/ITimeIndex.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/timeindex/TimeIndexLevel.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/virtualSg/HashVirtualPartitioner.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/virtualSg/VirtualPartitioner.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/storagegroup/virtualSg/VirtualStorageGroupManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/trigger/api/TriggerEvent.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/upgrade/UpgradeCheckStatus.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/upgrade/UpgradeLog.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/upgrade/UpgradeTask.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/version/SimpleFileVersionController.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/version/SysTimeVersionController.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/engine/version/VersionController.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/BatchProcessException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/DiskSpaceInsufficientException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/IoTDBException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/LoadConfigurationException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/LoadEmptyFileException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/LoadFileException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/MergeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/PartitionViolationException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/QueryIdNotExsitException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/QueryInBatchStatementException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/ShutdownException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/StartupException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/StorageEngineException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/StorageGroupProcessorException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/SyncConnectionException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/SyncDeviceOwnerConflictException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/SystemCheckException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/TsFileProcessorException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/UDFRegistrationException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/WriteProcessException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/WriteProcessRejectException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/index/DistanceMetricException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/index/IllegalIndexParamException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/index/IndexManagerException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/index/IndexRuntimeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/index/QueryIndexException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/index/UnsupportedIndexTypeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/AliasAlreadyExistException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/DataTypeMismatchException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/DeleteFailedException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/IllegalParameterOfPathException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/IllegalPathException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/MetadataException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/PathAlreadyExistException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/PathNotExistException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/StorageGroupAlreadySetException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/metadata/StorageGroupNotSetException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/LogicalOperatorException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/LogicalOptimizeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/OutOfTTLException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/PathException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/PathNumOverLimitException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/QueryProcessException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/QueryTimeoutRuntimeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/query/UnSupportedFillTypeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/runtime/FlushRunTimeException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/runtime/RPCServiceException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/runtime/SQLParserException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/exception/runtime/StorageEngineFailureException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/index/common/IndexConstant.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/index/common/IndexType.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/index/common/IndexUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MLogTxtWriter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MTree.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MeasurementMeta.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MetaUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/Metadata.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MetadataConstant.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/MetadataOperationType.java
 delete mode 100755 server/src/main/java/org/apache/iotdb/db/metadata/PartialPath.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/TagLogFile.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/logfile/MLogReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/logfile/MLogTxtReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/logfile/MLogWriter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/mnode/MNode.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/mnode/MeasurementMNode.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/mnode/StorageGroupMNode.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/server/JettyUtil.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/server/MetricsSystem.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/server/QueryServlet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/server/ServerArgument.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/server/SqlArgument.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/sink/ConsoleSink.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/sink/MetricsServletSink.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/sink/Sink.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/source/JvmSource.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/source/MetricsSource.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/source/Source.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/ui/MetricsPage.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/metrics/ui/MetricsWebUI.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/monitor/IStatistic.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/monitor/MonitorConstants.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/monitor/StatMonitor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/monitor/StatMonitorMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/mqtt/BrokerAuthenticator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/mqtt/JSONPayloadFormatter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/mqtt/Message.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/mqtt/PayloadFormatManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/mqtt/PayloadFormatter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/mqtt/PublishHandler.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/Planner.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/constant/SQLConstant.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/executor/IPlanExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/executor/PlanExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/Operator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/RootOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/BasicFunctionOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/BasicOperatorType.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/DeleteDataOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/FilterOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/FromOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/FunctionOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/InOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/InsertOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/QueryOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/SFWOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/crud/SelectOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/AlterTimeSeriesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/AuthorOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ClearCacheOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/CountOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/CreateFunctionOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/CreateIndexOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/CreateSnapshotOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/CreateTimeSeriesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/CreateTriggerOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DataAuthOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DeletePartitionOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DeleteStorageGroupOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DeleteTimeSeriesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DropFunctionOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DropIndexOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/DropTriggerOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/FlushOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/KillQueryOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/LoadConfigurationOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/LoadDataOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/LoadFilesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/MergeOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/MoveFileOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/RemoveFileOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/SetStorageGroupOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/SetTTLOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowChildNodesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowChildPathsOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowDevicesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowFunctionsOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowMergeStatusOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowStorageGroupOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowTTLOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowTimeSeriesOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/ShowTriggersOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/StartTriggerOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/StopTriggerOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/logical/sys/TracingOperator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/BatchPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/PhysicalPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/AggregationPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/AlignByDevicePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/DeletePartitionPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/DeletePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/FillQueryPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/GroupByTimeFillPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/GroupByTimePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertMultiTabletPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertRowPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertRowsOfOneDevicePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertRowsPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertTabletPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/LastQueryPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/QueryIndexPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/QueryPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/RawDataQueryPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/UDFPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/UDTFPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/AlterTimeSeriesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/AuthorPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ChangeAliasPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ChangeTagOffsetPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ClearCachePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CountPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CreateFunctionPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CreateIndexPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CreateMultiTimeSeriesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CreateSnapshotPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CreateTimeSeriesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/CreateTriggerPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DataAuthPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DeleteStorageGroupPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DeleteTimeSeriesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DropFunctionPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DropIndexPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DropTriggerPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/FlushPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/KillQueryPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/LoadConfigurationPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/LoadDataPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/MNodePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/MeasurementMNodePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/MergePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/OperateFilePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/SetStorageGroupPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/SetTTLPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowChildNodesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowChildPathsPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowDevicesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowFunctionsPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowMergeStatusPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowQueryProcesslistPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowStorageGroupPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowTTLPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowTimeSeriesPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/ShowTriggersPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/StartTriggerPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/StopTriggerPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/StorageGroupMNodePlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/TracingPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/LogicalGenerator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/PhysicalGenerator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/SQLParseError.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/optimizer/ConcatPathOptimizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/optimizer/DnfFilterOptimizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/optimizer/IFilterOptimizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/optimizer/ILogicalOptimizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/optimizer/MergeSingleFilterOptimizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/strategy/optimizer/RemoveNotOptimizer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/utils/DatetimeUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/AggregateResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/AggregationType.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/AvgAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/CountAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/FirstValueAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/FirstValueDescAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/LastValueAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/LastValueDescAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/MaxTimeAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/MaxTimeDescAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/MaxValueAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/MinTimeAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/MinTimeDescAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/MinValueAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/aggregation/impl/SumAggrResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/context/QueryContext.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/control/FileReaderManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/control/QueryFileManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/control/QueryResourceManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/control/QueryTimeManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/control/TracingManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/AlignByDeviceDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/DirectAlignByTimeDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/DirectNonAlignDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ListDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/NonAlignEngineDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/RawQueryDataSetWithValueFilter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/RawQueryDataSetWithoutValueFilter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ShowDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ShowDevicesDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ShowDevicesResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ShowResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ShowTimeSeriesResult.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/ShowTimeseriesDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/SingleDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDFInputDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDTFAlignByTimeDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDTFDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDTFNonAlignDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/GroupByEngineDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/GroupByExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/GroupByFillDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/GroupByTimeDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/GroupByWithValueFilterDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/GroupByWithoutValueFilterDataSet.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/groupby/LocalGroupByExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/AggregationExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/FillQueryExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/IQueryRouter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/LastQueryExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/QueryRouter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/RawDataQueryExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/UDTFQueryExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/fill/IFill.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/fill/LastPointReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/fill/LinearFill.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/fill/PreviousFill.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/ExternalSortJob.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/ExternalSortJobEngine.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/ExternalSortJobPart.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/ExternalSortJobScheduler.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/LineMerger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/MultiSourceExternalSortJobPart.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/SimpleExternalSortEngine.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/SingleSourceExternalSortJobPart.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/adapter/ByTimestampReaderAdapter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/serialize/IExternalSortFileDeserializer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/serialize/IExternalSortFileSerializer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/serialize/impl/FixLengthIExternalSortFileDeserializer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/externalsort/serialize/impl/FixLengthTimeValuePairSerializer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/factory/AggregateResultFactory.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/filter/TsFileFilter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/pool/QueryTaskPoolManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/ChunkDataIterator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/ChunkReaderWrap.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/DiskChunkLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/DiskChunkReaderByTimestamp.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/MemChunkLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/MemChunkReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/MemPageReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/metadata/DiskChunkMetadataLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/chunk/metadata/MemChunkMetadataLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/resource/CachedUnseqResourceMergeReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/BaseManagedSeriesReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/IAggregateReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/IReaderByTimestamp.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/ManagedSeriesReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/SeriesAggregateReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/SeriesRawDataBatchReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/SeriesRawDataPointReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/SeriesReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/series/SeriesReaderByTimestamp.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/universal/CachedPriorityMergeReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/universal/DescPriorityMergeReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/universal/Element.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/reader/universal/PriorityMergeReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/timegenerator/ServerTimeGenerator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/UDF.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/UDTF.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/access/Row.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/access/RowIterator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/access/RowWindow.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/collector/PointCollector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/config/UDFConfigurations.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/config/UDTFConfigurations.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/parameter/UDFParameterValidator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/parameter/UDFParameters.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/AccessStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/RowByRowAccessStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/SlidingSizeWindowAccessStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/SlidingTimeWindowAccessStrategy.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/exception/UDFAttributeNotProvidedException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/exception/UDFException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/exception/UDFInputSeriesDataTypeNotValidException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/exception/UDFInputSeriesIndexNotValidException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/exception/UDFInputSeriesNumberNotValidException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/exception/UDFParameterNotValidException.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/BuiltinFunction.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFAbs.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFAcos.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFAsin.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFAtan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFBottomK.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFCeil.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFCommonDerivative.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFCommonValueDifference.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFContains.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFCos.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFDegrees.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFDerivative.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFExp.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFFloor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFLog.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFLog10.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFMatches.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFMath.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFNonNegativeDerivative.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFNonNegativeValueDifference.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFRadians.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFRound.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFSelectK.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFSign.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFSin.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFSqrt.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFTan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFTimeDifference.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFTopK.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFValueDifference.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/builtin/UDTFValueTrend.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/access/RowImpl.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/access/RowIteratorImpl.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/access/RowWindowImpl.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/context/UDFContext.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/executor/UDTFExecutor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/input/InputLayer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/input/SafetyLine.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/reader/LayerPointReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/reader/LayerRowReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/reader/LayerRowWindowReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/RawQueryPointTransformer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/Transformer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/UDFQueryRowTransformer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/UDFQueryRowWindowTransformer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/UDFQueryTransformer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/Cache.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/SerializableList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/ElasticSerializableIntList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/IntList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/SerializableIntList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/WrappedIntArray.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/row/ElasticSerializableRowRecordList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/row/SerializableRowRecordList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/ElasticSerializableBinaryTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/ElasticSerializableTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableBinaryTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableBooleanTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableDoubleTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableFloatTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableIntTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableLongTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/TemporaryQueryDataFileService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFClassLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFClassLoaderManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFLogWriter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFRegistrationInformation.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFRegistrationService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/CachedStringPool.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/MemTableManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/PrimitiveArrayManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/SystemInfo.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/TVListAllocator.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/TVListAllocatorMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/rescon/package-info.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/separation/statistics/Collector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/separation/statistics/SeparationTuningClient.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/separation/statistics/SeparationTunningService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/IService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/IoTDB.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/IoTDBMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/IoTDBShutdownHook.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/JMXService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/MQTTService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/MetricsService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/MetricsServiceMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/RPCService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/RPCServiceMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/RPCServiceThriftHandler.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/RegisterManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/ServiceType.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/StartupCheck.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/StartupChecks.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/StaticResps.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/TSServiceImpl.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/UpgradeSevice.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/thrift/ThriftService.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/service/thrift/ThriftServiceThread.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/conf/SyncConstant.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/conf/SyncSenderConfig.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/conf/SyncSenderDescriptor.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/package-info.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/SyncServerManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/SyncServerManagerMBean.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/SyncServerThriftHandler.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/load/FileLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/load/FileLoaderManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/load/IFileLoader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/load/ILoadLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/load/LoadLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/load/LoadType.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/recover/ISyncReceiverLogAnalyzer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/recover/ISyncReceiverLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/recover/SyncReceiverLogAnalyzer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/recover/SyncReceiverLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/receiver/transfer/SyncServiceImpl.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/manage/ISyncFileManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/manage/SyncFileManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/recover/ISyncSenderLogAnalyzer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/recover/ISyncSenderLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/recover/SyncSenderLogAnalyzer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/recover/SyncSenderLogger.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/transfer/ISyncClient.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/sync/sender/transfer/SyncClient.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/IoTDBDataDirViewer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/TsFileResourcePrinter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/TsFileRewriteTool.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/TsFileSketchTool.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/WalChecker.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/mlog/MLogParser.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/upgrade/TsFileOnlineUpgradeTool.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/virtualsg/DeviceMappingViewer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/watermark/GroupedLSBWatermarkEncoder.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/watermark/WatermarkDetector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/tools/watermark/WatermarkEncoder.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/AuthUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/CommonUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/CopyOnReadLinkedList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/EncodingInferenceUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/FileLoaderUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/FilePathUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/FileUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/IOUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/MathUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/MemUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/MergeUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/MmapUtil.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/OpenFileNumUtil.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/QueryDataSetUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/QueryUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/RandomDeleteCache.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/SchemaUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/SerializeUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/StatusUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/SyncUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/TestOnly.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/TimeValuePairUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/TypeInferenceUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/UpgradeUtils.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/BinaryTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/BooleanTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/DoubleTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/FloatTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/IntTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/LongTVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/TVList.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/utils/datastructure/TimeSelector.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/WALFlushListener.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/io/BatchLogReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/io/ILogReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/io/ILogWriter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/io/LogWriter.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/io/MultiFileLogReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/io/SingleFileLogReader.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/manager/MultiFileLogNodeManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/manager/WriteLogNodeManager.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/node/ExclusiveWriteLogNode.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/node/WriteLogNode.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/recover/LogReplayer.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/writelog/recover/TsFileRecoverPerformer.java
 delete mode 100644 server/src/main/resources/META-INF/services/org.apache.iotdb.db.mqtt.PayloadFormatter
 delete mode 100644 server/src/main/resources/iotdb/ui/static/index.html
 delete mode 100644 server/src/main/resources/iotdb/ui/static/iotdb-logo.png
 delete mode 100644 server/src/main/resources/iotdb/ui/static/webui.css
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/AuthorityCheckerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/authorizer/LocalFileAuthorizerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/authorizer/OpenIdAuthorizerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/entity/PathPrivilegeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/entity/RoleTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/entity/UserTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/role/LocalFileRoleAccessorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/role/LocalFileRoleManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/user/LocalFileUserAccessorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/auth/user/LocalFileUserManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/concurrent/IoTDBDefaultThreadExceptionHandlerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/concurrent/IoTDBThreadPoolFactoryTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/conf/IoTDBDescriptorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/conf/adapter/CompressionRatioTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/conf/directories/strategy/DirectoryStrategyTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/constant/TestConstant.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/cost/statistic/PerformanceStatTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/MetadataManagerHelper.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/CompactionChunkTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionCacheTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionLogTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionMergeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionModsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionMoreDataTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionRecoverTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionSelectorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionTsFileManagementTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/NoCompactionTsFileManagementTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/memtable/MemTableFlushTaskTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/memtable/MemTableTestUtils.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/memtable/MemtableBenchmark.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/memtable/PrimitiveMemTableTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MaxFileMergeFileSelectorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MaxSeriesMergeFileSelectorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergeLogTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergeManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergeOverLapTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergePerfTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergeTaskTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/merge/MergeUpgradeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/modification/DeletionFileNodeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/modification/DeletionQueryTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/modification/ModificationFileTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/modification/io/LocalTextModificationAccessorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/storagegroup/FileNodeManagerBenchmark.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/storagegroup/StorageGroupProcessorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/storagegroup/TTLTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/storagegroup/TsFileProcessorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/storagegroup/virtualSg/HashVirtualPartitionerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/version/SimpleFileVersionControllerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/engine/version/SysTimeVersionControllerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IOTDBGroupByIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IOTDBGroupByInnerIntervalIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IOTDBInsertIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBAddSubDeviceIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBAliasIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBAlignByDeviceIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBAsIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBAutoCreateSchemaIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCheckConfigIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBClearCacheIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCloseIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCompleteIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCompressTypeIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCreateSnapshotIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCreateTimeseriesIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBDaemonIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBDeleteStorageGroupIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBDeleteTimeseriesIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBDeletionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBDisableAlignIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBEncodingIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBEngineTimeGeneratorIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBExecuteBatchIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBFilePathUtilsIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBFillIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBFloatPrecisionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBFlushQueryMergeIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBGroupByFillIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBGroupByFillWithRangeIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBGroupByMonthIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBInsertNaNIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBInsertWithQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBKillQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLargeDataIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLastIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLevelCompactionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLimitSlimitIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLoadExternalTsFileWithTimePartitionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLoadExternalTsfileIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMergeIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMetadataFetchIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMultiDeviceIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMultiOverlappedChunkInUnseqIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMultiOverlappedPageIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMultiSeriesIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBMultiStatementsIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBNewTsFileCompactionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBNumberPathIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBOverlappedPageIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBQueryDemoIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBQueryMemoryControlIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBQueryTimeoutIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBQuotedPathIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBRecoverIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBRecoverUnclosedIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBRemovePartitionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBRestartIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBResultSetIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBRpcCompressionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSameMeasurementsDifferentTypesIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSensorUpdateIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSequenceDataQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSeriesReaderIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSimpleQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBSortedShowTimeseriesIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBTagAlterIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBTagIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBTimeZoneIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBTracingIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBTtlIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDFManagementIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDFWindowQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFAlignByTimeQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFBuiltinFunctionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFHybridQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFNonAlignQueryIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBVersionIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/aggregation/IoTDBAggregationByLevelIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/aggregation/IoTDBAggregationDeleteIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/aggregation/IoTDBAggregationIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/aggregation/IoTDBAggregationLargeDataIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/aggregation/IoTDBAggregationSmallDataIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/auth/IoTDBAuthorizationIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/MManagerAdvancedTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/MManagerBasicTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/MManagerImproveTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/MTreeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/MetaUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/PartialPathTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/mnode/MNodeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/monitor/IoTDBStatMonitorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/mqtt/BrokerAuthenticatorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/mqtt/JSONPayloadFormatTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/mqtt/PayloadFormatManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/mqtt/PublishHandlerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/PlannerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/bench/QueryParseBenchmark.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/logical/IndexLogicalPlanTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/logical/LogicalPlanSmallTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/other/TSPlanContextAuthorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/ConcatOptimizerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/IndexSubMatchingPhysicalPlanTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/IndexWholeMatchingPhysicalPlanTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/InsertTabletMultiPlanTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/InsertTabletPlanTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/PhysicalPlanSerializeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/PhysicalPlanTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/physical/SerializationTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/sql/IoTDBsqlVisitorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/qp/utils/DatetimeQueryDataSetUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/aggregation/AggregateResultTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/aggregation/DescAggregateResultTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/control/FileReaderManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/control/QueryResourceManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/control/TracingManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/EngineDataSetWithValueFilterTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/ListDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/ShowDevicesResultTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/ShowTimeSeriesResultTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/SingleDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/UDTFAlignByTimeDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/groupby/GroupByEngineDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/groupby/GroupByFillDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/groupby/GroupByLevelDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/groupby/GroupByTimeDataSetTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/externalsort/ExternalSortEngineTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/externalsort/FakeChunkReaderWrap.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/externalsort/IExternalSortFileSerializerDeserializerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/series/SeriesAggregateReaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/series/SeriesReaderByTimestampTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/series/SeriesReaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/series/SeriesReaderTestUtil.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/universal/FakedSeriesReader.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/universal/PriorityMergeReaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/reader/universal/PriorityMergeReaderTest2.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/ElasticSerializableRowRecordListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/ElasticSerializableTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/LRUCache.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/LRUCacheTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableBinaryTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableBooleanTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableDoubleTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableFloatTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableIntTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableLongTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableRowRecordListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Accumulator.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Adder.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Counter.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Max.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Multiplier.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/SlidingSizeWindowConstructorTester0.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/SlidingSizeWindowConstructorTester1.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/SlidingTimeWindowConstructionTester.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/TerminateTester.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/ValidateTester.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/script/EnvScriptIT.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/receiver/load/FileLoaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/receiver/recover/SyncReceiverLogAnalyzerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/receiver/recover/SyncReceiverLoggerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/sender/manage/SyncFileManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/sender/recover/SyncSenderLogAnalyzerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/sender/recover/SyncSenderLoggerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/sync/sender/transfer/SyncClientTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/tools/IoTDBWatermarkTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/tools/MLogParserTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/tools/WalCheckerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/CopyOnReadLinkedListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/EncodingInferenceUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/EnvironmentUtils.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/FilePathUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/MathQueryDataSetUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/MemUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/OpenFileNumUtilTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/RandomNum.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/SchemaUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/SerializeUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/TsFileRewriteToolTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/TypeInferenceUtilsTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/BinaryTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/BooleanTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/DoubleTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/FloatTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/IntTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/LongTVListTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/PrecisionTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/TimeSelectorTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/IoTDBLogFileSizeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/PerformanceTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/WriteLogNodeManagerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/WriteLogNodeTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/io/LogWriterReaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/io/MultiFileLogReaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/recover/DeviceStringTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/recover/LogReplayerTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/recover/RecoverResourceFromReaderTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/recover/SeqTsFileRecoverTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/writelog/recover/UnseqTsFileRecoverTest.java
 delete mode 100644 server/src/test/resources/iotdb-engine.properties
 delete mode 100644 server/src/test/resources/logback.xml
 delete mode 100644 server/src/test/resources/start-sync-test.sh
 delete mode 100644 server/src/test/resources/stop-sync-test.sh
 delete mode 100644 service-rpc/pom.xml
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/AutoResizingBuffer.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/AutoScalingBufferReadTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/AutoScalingBufferWriteTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/BatchExecutionException.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/IoTDBConnectionException.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/NonOpenTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/RedirectException.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/RpcStat.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/RpcTransportFactory.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/RpcUtils.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/StatementExecutionException.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/SynchronizedHandler.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TCompressedElasticFramedTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TElasticFramedTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TSStatusCode.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TSnappyElasticFramedTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TimeoutChangeableTFastFramedTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TimeoutChangeableTSnappyFramedTransport.java
 delete mode 100644 service-rpc/src/main/java/org/apache/iotdb/rpc/TimeoutChangeableTransport.java
 delete mode 100644 session/pom.xml
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/Config.java
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/Session.java
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/SessionConnection.java
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/SessionDataSet.java
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/SessionUtils.java
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/pool/SessionDataSetWrapper.java
 delete mode 100644 session/src/main/java/org/apache/iotdb/session/pool/SessionPool.java
 delete mode 100644 session/src/test/java/org/apache/iotdb/session/IoTDBSessionComplexIT.java
 delete mode 100644 session/src/test/java/org/apache/iotdb/session/IoTDBSessionIteratorIT.java
 delete mode 100644 session/src/test/java/org/apache/iotdb/session/IoTDBSessionSimpleIT.java
 delete mode 100644 session/src/test/java/org/apache/iotdb/session/SessionCacheLeaderUT.java
 delete mode 100644 session/src/test/java/org/apache/iotdb/session/SessionUT.java
 delete mode 100644 session/src/test/java/org/apache/iotdb/session/pool/SessionPoolTest.java
 delete mode 100644 session/src/test/resources/iotdb-engine.properties
 delete mode 100644 site/README-zh.md
 delete mode 100644 site/README.md
 delete mode 100644 site/iotdb-doap.rdf
 delete mode 100644 site/pom.xml
 delete mode 100644 site/src/main/.vuepress/config.js
 delete mode 100644 site/src/main/.vuepress/enhanceApp.js
 delete mode 100644 site/src/main/.vuepress/public/img/arrow.png
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/jlq.png
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/kfx.jpeg
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/user.svg
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/xdh.jpg
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/xww.jpg
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/yrzh.jpg
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/yt.jpg
 delete mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/zss.jpg
 delete mode 100644 site/src/main/.vuepress/public/img/home-Slide1.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-Slide2.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-Slide3.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-icon1.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-icon2.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-icon3.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-icon4.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-icon5.png
 delete mode 100644 site/src/main/.vuepress/public/img/home-icon6.png
 delete mode 100644 site/src/main/.vuepress/public/img/logo.png
 delete mode 100644 site/src/main/.vuepress/public/img/tools.jpg
 delete mode 100644 site/src/main/.vuepress/styles/index.styl
 delete mode 100644 site/src/main/.vuepress/styles/palette.styl
 delete mode 100644 site/src/main/.vuepress/theme/components/AlgoliaSearchBox.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/DropdownLink.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/DropdownTransition.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/Home.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/NavLink.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/NavLinks.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/Navbar.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/Page.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/Sidebar.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/SidebarButton.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/SidebarGroup.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/SidebarLink.vue
 delete mode 100644 site/src/main/.vuepress/theme/components/SidebarLinks.vue
 delete mode 100644 site/src/main/.vuepress/theme/global-components/Badge.vue
 delete mode 100644 site/src/main/.vuepress/theme/global-components/Contributor.vue
 delete mode 100644 site/src/main/.vuepress/theme/global-components/IoTDB.vue
 delete mode 100644 site/src/main/.vuepress/theme/global-components/IoTDBZH.vue
 delete mode 100644 site/src/main/.vuepress/theme/index.js
 delete mode 100644 site/src/main/.vuepress/theme/layouts/404.vue
 delete mode 100644 site/src/main/.vuepress/theme/layouts/Layout.vue
 delete mode 100644 site/src/main/.vuepress/theme/styles/arrow.styl
 delete mode 100644 site/src/main/.vuepress/theme/styles/code.styl
 delete mode 100644 site/src/main/.vuepress/theme/styles/custom-blocks.styl
 delete mode 100644 site/src/main/.vuepress/theme/styles/index.styl
 delete mode 100644 site/src/main/.vuepress/theme/styles/mobile.styl
 delete mode 100644 site/src/main/.vuepress/theme/styles/toc.styl
 delete mode 100644 site/src/main/.vuepress/theme/styles/wrapper.styl
 delete mode 100644 site/src/main/.vuepress/theme/util/index.js
 delete mode 100644 site/src/main/deploy.js
 delete mode 100644 site/src/main/package.json
 delete mode 100644 spark-iotdb-connector/Readme.md
 delete mode 100644 spark-iotdb-connector/pom.xml
 delete mode 100644 spark-iotdb-connector/src/main/java/org/apache/iotdb/spark/db/SQLConstant.java
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/Converter.scala
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/DefaultSource.scala
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/IoTDBOptions.scala
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/IoTDBRDD.scala
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/IoTDBRelation.scala
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/Transformer.scala
 delete mode 100644 spark-iotdb-connector/src/main/scala/org/apache/iotdb/spark/db/package.scala
 delete mode 100644 spark-iotdb-connector/src/test/resources/iotdb-engine.properties
 delete mode 100644 spark-iotdb-connector/src/test/scala/org/apache/iotdb/spark/db/EnvironmentUtils.java
 delete mode 100644 spark-iotdb-connector/src/test/scala/org/apache/iotdb/spark/db/IoTDBTest.scala
 delete mode 100644 spark-tsfile/README.md
 delete mode 100644 spark-tsfile/pom.xml
 delete mode 100644 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/io/TsFileOutputFormat.java
 delete mode 100644 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/io/TsFileRecordWriter.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/Executor.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/QueryProcessor.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/common/BasicOperator.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/common/FilterOperator.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/common/Operator.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/common/SQLConstant.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/common/SingleQuery.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/common/TSQueryPlan.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/BasicOperatorException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/DNFOptimizeException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/LogicalOptimizeException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/MergeFilterException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/QueryOperatorException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/QueryProcessorException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/exception/RemoveNotException.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/optimizer/DNFFilterOptimizer.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/optimizer/IFilterOptimizer.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/optimizer/MergeSingleFilterOptimizer.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/optimizer/PhysicalOptimizer.java
 delete mode 100755 spark-tsfile/src/main/java/org/apache/iotdb/spark/tsfile/qp/optimizer/RemoveNotOptimizer.java
 delete mode 100644 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/Converter.scala
 delete mode 100755 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/DefaultSource.scala
 delete mode 100644 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/NarrowConverter.scala
 delete mode 100644 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/NarrowTsFileOutputWriter.scala
 delete mode 100644 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/Transformer.scala
 delete mode 100644 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/TsFileWriterFactory.scala
 delete mode 100755 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/WideConverter.scala
 delete mode 100644 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/WideTsFileOutputWriter.scala
 delete mode 100755 spark-tsfile/src/main/scala/org/apache/iotdb/spark/tsfile/package.scala
 delete mode 100644 spark-tsfile/src/test/scala/org/apache/iotdb/spark/constant/TestConstant.java
 delete mode 100644 spark-tsfile/src/test/scala/org/apache/iotdb/spark/tool/TsFileExample.java
 delete mode 100644 spark-tsfile/src/test/scala/org/apache/iotdb/spark/tool/TsFileWriteTool.java
 delete mode 100644 spark-tsfile/src/test/scala/org/apache/iotdb/spark/tsfile/ConverterTest.scala
 delete mode 100644 spark-tsfile/src/test/scala/org/apache/iotdb/spark/tsfile/HDFSInputTest.java
 delete mode 100644 spark-tsfile/src/test/scala/org/apache/iotdb/spark/tsfile/TSFileSuit.scala
 delete mode 100644 test/e2e/base/docker-compose.yaml
 delete mode 100644 test/e2e/cases/README.md
 delete mode 100644 test/e2e/cases/cli/README.md
 delete mode 100644 test/e2e/cases/cli/cleanup.sh
 delete mode 100644 test/e2e/cases/cli/docker-compose.yaml
 delete mode 100644 test/e2e/cases/cli/res/init.sql
 delete mode 100644 test/e2e/cases/cli/run.sh
 delete mode 100644 thrift-cluster/README.md
 delete mode 100644 thrift-cluster/pom.xml
 delete mode 100644 thrift-cluster/rpc-changelist.md
 delete mode 100644 thrift-cluster/src/main/thrift/cluster.thrift
 delete mode 100644 thrift-sync/README.md
 delete mode 100644 thrift-sync/pom.xml
 delete mode 100644 thrift-sync/rpc-changelist.md
 delete mode 100755 thrift-sync/src/main/thrift/sync.thrift
 delete mode 100644 thrift/README.md
 delete mode 100644 thrift/pom.xml
 delete mode 100644 thrift/rpc-changelist.md
 delete mode 100644 thrift/src/main/thrift/rpc.thrift
 delete mode 100755 tools/check_sigs.sh
 delete mode 100644 tools/clean-site.sh
 delete mode 100755 tools/common.sh
 delete mode 100755 tools/download_staged_release.sh
 delete mode 100644 tsfile/README.md
 delete mode 100644 tsfile/format-changelist.md
 delete mode 100644 tsfile/pom.xml
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/cache/Accountable.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/cache/Cache.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/cache/LRUCache.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/conf/TSFileConfig.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/conf/TSFileDescriptor.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/constant/JsonFormatConstant.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/constant/QueryConstant.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/common/constant/TsFileConstant.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/compress/ICompressor.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/compress/IUnCompressor.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/bitpacking/IntPacker.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/bitpacking/LongPacker.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/BitmapDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/Decoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/DeltaBinaryDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/DoublePrecisionDecoderV1.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/DoublePrecisionDecoderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/FloatDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/GorillaDecoderV1.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/GorillaDecoderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/IntGorillaDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/IntRleDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/LongGorillaDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/LongRleDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/PlainDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/RegularDataDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/RleDecoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/SinglePrecisionDecoderV1.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/SinglePrecisionDecoderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/BitmapEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/DeltaBinaryEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/DoublePrecisionEncoderV1.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/DoublePrecisionEncoderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/Encoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/FloatEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/GorillaEncoderV1.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/GorillaEncoderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/IntGorillaEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/IntRleEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/LongGorillaEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/LongRleEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/PlainEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/RegularDataEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/RleEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/SDTEncoder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/SinglePrecisionEncoderV1.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/SinglePrecisionEncoderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/TSEncodingBuilder.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/NotCompatibleTsFileException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/NotImplementedException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/NullFieldException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/TsFileRuntimeException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/cache/CacheException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/compress/CompressionTypeNotSupportedException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/encoding/TsFileDecodingException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/encoding/TsFileEncodingException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/filter/QueryFilterOptimizationException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/filter/StatisticsClassException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/filter/UnSupportFilterDataTypeException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/write/NoMeasurementException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/write/PageException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/write/TsFileNotCompleteException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/write/UnSupportedDataTypeException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/write/UnknownColumnTypeException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/exception/write/WriteProcessException.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/MetaMarker.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/header/ChunkGroupHeader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/header/ChunkHeader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/header/PageHeader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/ChunkGroupMetadata.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/ChunkMetadata.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/MetadataIndexConstructor.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/MetadataIndexEntry.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/MetadataIndexNode.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/TimeseriesMetadata.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/TsFileMetadata.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/enums/CompressionType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/enums/MetadataIndexNodeType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/enums/TSDataType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/enums/TSEncoding.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/BinaryStatistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/BooleanStatistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/DoubleStatistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/FloatStatistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/IntegerStatistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/LongStatistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/file/metadata/statistics/Statistics.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/FSFactoryProducer.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/FSType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fileInputFactory/FileInputFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fileInputFactory/HDFSInputFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fileInputFactory/LocalFSInputFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fileOutputFactory/FileOutputFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fileOutputFactory/HDFSOutputFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fileOutputFactory/LocalFSOutputFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fsFactory/FSFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fsFactory/HDFSFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/fileSystem/fsFactory/LocalFSFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/ReadOnlyTsFile.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/TimeValuePair.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/TsFileCheckStatus.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/TsFileRestorableReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/TsFileSequenceReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/UnClosedTsFileReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/BatchData.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/BatchDataFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/Chunk.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/DescReadBatchData.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/DescReadWriteBatchData.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/ExceptionBatchData.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/Field.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/Path.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/RowRecord.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/SignalBatchData.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/common/TimeRange.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/controller/CachedChunkLoaderImpl.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/controller/IChunkLoader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/controller/IChunkMetadataLoader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/controller/IMetadataQuerier.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/controller/MetadataQuerierByFileImpl.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/ExpressionType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/IBinaryExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/IExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/IUnaryExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/QueryExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/impl/BinaryExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/impl/GlobalTimeExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/impl/SingleSeriesExpression.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/util/ExpressionOptimizer.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/expression/util/ExpressionPrinter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/GroupByFilter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/GroupByMonthFilter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/TimeFilter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/ValueFilter.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/basic/BinaryFilter.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/basic/Filter.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/basic/UnaryFilter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/factory/FilterFactory.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/factory/FilterSerializeId.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/factory/FilterType.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/AndFilter.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/Eq.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/Gt.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/GtEq.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/In.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/Lt.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/LtEq.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/NotEq.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/NotFilter.java
 delete mode 100755 tsfile/src/main/java/org/apache/iotdb/tsfile/read/filter/operator/OrFilter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/DataSetWithTimeGenerator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/DataSetWithoutTimeGenerator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/EmptyDataSet.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/QueryDataSet.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/executor/ExecutorWithTimeGenerator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/executor/QueryExecutor.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/executor/TsFileExecutor.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/TimeGenerator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/TsFileTimeGenerator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/node/AndNode.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/node/LeafNode.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/node/Node.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/node/NodeType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/timegenerator/node/OrNode.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/BatchDataIterator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/IBatchReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/IChunkReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/IPageReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/IPointReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/LocalTsFileInput.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/TsFileInput.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/chunk/ChunkReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/chunk/ChunkReaderByTimestamp.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/page/PageReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/series/AbstractFileSeriesReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/series/EmptyFileSeriesReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/series/FileSeriesReader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/reader/series/FileSeriesReaderByTimestamp.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/Binary.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/BloomFilter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/BytesUtils.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/Loader.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/Murmur128Hash.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/Pair.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/PublicBAOS.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/RamUsageEstimator.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/ReadWriteForEncodingUtils.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/ReadWriteIOUtils.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/StringContainer.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/utils/TsPrimitiveType.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/footer/ChunkGroupFooterV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/header/ChunkHeaderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/header/PageHeaderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/ChunkMetadataV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/MetadataIndexEntryV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/MetadataIndexNodeV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/TimeseriesMetadataV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/TsFileMetadataV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/file/metadata/statistics/StatisticsV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/read/TsFileSequenceReaderForV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/v2/read/reader/page/PageReaderV2.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/TsFileWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/ChunkGroupWriterImpl.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/ChunkWriterImpl.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/IChunkGroupWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/IChunkWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/page/PageWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/TSRecord.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/Tablet.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/BooleanDataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/DataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/DoubleDataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/FloatDataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/IntDataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/LongDataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/record/datapoint/StringDataPoint.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/schema/MeasurementSchema.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/schema/Schema.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/schema/TimeseriesSchema.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/writer/ForceAppendTsFileWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/writer/IDataWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/writer/LocalTsFileOutput.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/writer/RestorableTsFileIOWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/writer/TsFileIOWriter.java
 delete mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/write/writer/TsFileOutput.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/common/LRUCacheTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/compress/CompressTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/compress/GZIPTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/compress/LZ4Test.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/compress/SnappyTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/constant/TestConstant.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/SDTEncoderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/bitpacking/IntPackerTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/bitpacking/LongPackerTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/BitmapDecoderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/FloatDecoderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/GorillaDecoderV1Test.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/GorillaDecoderV2Test.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/IntRleDecoderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/LongRleDecoderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/delta/DeltaBinaryEncoderIntegerTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/delta/DeltaBinaryEncoderLongTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/regular/RegularDataEncoderIntegerTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/encoding/decoder/regular/RegularDataEncoderLongTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/header/PageHeaderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/MetadataIndexNodeTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/TimeSeriesMetadataTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/TsFileMetadataTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/statistics/BooleanStatisticsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/statistics/DoubleStatisticsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/statistics/FloatStatisticsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/statistics/IntegerStatisticsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/statistics/LongStatisticsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/statistics/StringStatisticsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/utils/TestHelper.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/file/metadata/utils/Utils.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/ExpressionTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/GetAllDevicesTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/MeasurementChunkMetadataListMapIteratorTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/ReadInPartitionTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/ReadOnlyTsFileTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/read/ReadTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/read/TimePlainEncodeReadTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/TimeSeriesMetadataReadTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/TsFileRestorableReaderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/TsFileSequenceReaderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/common/BatchDataTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/common/FieldTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/common/PathTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/common/TimeRangeTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/controller/ChunkLoaderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/controller/IMetadataQuerierByFileImplTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/FilterSerializeTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/GroupByFilterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/GroupByMonthFilterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/IExpressionOptimizerTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/MinTimeMaxTimeFilterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/OperatorTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/filter/StatisticsFilterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/executor/QueryExecutorTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/NodeTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/ReadWriteTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/ReaderByTimestampTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/TimeGeneratorReadEmptyTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/TimeGeneratorReadWriteTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/TimeGeneratorTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/read/query/timegenerator/TsFileGeneratorForSeriesReaderByTimestamp.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/reader/FakedBatchReader.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/reader/FakedMultiBatchReader.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/reader/FakedTimeGenerator.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/reader/PageReaderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/read/reader/ReaderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/BloomFilterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/BytesUtilsTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/FileGenerator.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/FileUtils.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/FileUtilsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/PairTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/ReadWriteForEncodingUtilsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/ReadWriteIOUtilsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/ReadWriteStreamUtilsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/ReadWriteToBytesUtilsTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/RecordUtils.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/RecordUtilsTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/StringContainerTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/TsFileGeneratorForTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/utils/TsPrimitiveTypeTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/DefaultDeviceTemplateTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/write/PerfTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/ReadPageInMemTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/SameMeasurementsWithDifferentDataTypesTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/TsFileIOWriterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/TsFileReadWriteTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/TsFileWriterTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/write/WriteTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/schema/converter/SchemaBuilderTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/writer/ForceAppendTsFileWriterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/writer/MeasurementSchemaSerializeTest.java
 delete mode 100755 tsfile/src/test/java/org/apache/iotdb/tsfile/write/writer/PageWriterTest.java
 delete mode 100644 tsfile/src/test/java/org/apache/iotdb/tsfile/write/writer/RestorableTsFileIOWriterTest.java
 delete mode 100644 tsfile/src/test/resources/logback.xml
 delete mode 100644 zeppelin-interpreter/IoTDB-Zeppelin-Demo.zpln
 delete mode 100644 zeppelin-interpreter/pom.xml
 delete mode 100644 zeppelin-interpreter/src/main/java/org/apache/zeppelin/iotdb/IoTDBInterpreter.java
 delete mode 100644 zeppelin-interpreter/src/main/resources/interpreter-setting.json
 delete mode 100644 zeppelin-interpreter/src/test/java/org/apache/zeppelin/iotdb/IoTDBInterpreterTest.java

[iotdb] 02/02: clear

Posted by yu...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

yuyuankang pushed a commit to branch research/separation
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit f70fdcbeb913761208537efbeca86c1a33541a7e
Author: Ring-k <yu...@hotmail.com>
AuthorDate: Wed Mar 16 00:33:06 2022 +0800

    clear
---
 Jenkinsfile                                        |  210 --
 LICENSE                                            |  236 --
 LICENSE-binary                                     |  306 --
 NOTICE                                             |   24 -
 NOTICE-binary                                      |   24 -
 README.md                                          |   35 -
 README_ZH.md                                       |  374 ---
 RELEASE_NOTES.md                                   |  721 -----
 antlr/pom.xml                                      |   78 -
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4   | 1537 ----------
 asf.header                                         |   16 -
 checkstyle.xml                                     |  230 --
 cli/pom.xml                                        |  165 --
 cli/src/assembly/cli.xml                           |   40 -
 cli/src/assembly/resources/sbin/start-cli.bat      |   74 -
 cli/src/assembly/resources/sbin/start-cli.sh       |   81 -
 cli/src/assembly/resources/tools/export-csv.bat    |   56 -
 cli/src/assembly/resources/tools/export-csv.sh     |   53 -
 cli/src/assembly/resources/tools/import-csv.bat    |   57 -
 cli/src/assembly/resources/tools/import-csv.sh     |   53 -
 .../java/org/apache/iotdb/cli/AbstractCli.java     |  679 -----
 cli/src/main/java/org/apache/iotdb/cli/Cli.java    |  171 --
 cli/src/main/java/org/apache/iotdb/cli/WinCli.java |  178 --
 .../org/apache/iotdb/cli/utils/IoTPrinter.java     |  106 -
 .../apache/iotdb/exception/ArgsErrorException.java |   28 -
 .../org/apache/iotdb/tool/AbstractCsvTool.java     |  191 --
 .../main/java/org/apache/iotdb/tool/ExportCsv.java |  372 ---
 .../main/java/org/apache/iotdb/tool/ImportCsv.java |  458 ---
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |  234 --
 .../java/org/apache/iotdb/cli/AbstractScript.java  |   87 -
 .../org/apache/iotdb/cli/StartClientScriptIT.java  |  112 -
 .../org/apache/iotdb/tool/CsvLineSplitTest.java    |   33 -
 .../org/apache/iotdb/tool/ExportCsvTestIT.java     |  102 -
 .../org/apache/iotdb/tool/ImportCsvTestIT.java     |  102 -
 cli/src/test/resources/logback.xml                 |  122 -
 client-cpp/README.md                               |   63 -
 client-cpp/pom.xml                                 |  388 ---
 client-cpp/src/assembly/client-cpp.xml             |   61 -
 client-cpp/src/main/Session.cpp                    | 1168 --------
 client-cpp/src/main/Session.h                      |  669 -----
 client-cpp/src/test/cpp/sessionIT.cpp              |  294 --
 client-cpp/src/test/main.cpp                       |   40 -
 client-py/.flake8                                  |   33 -
 client-py/.gitignore                               |    5 -
 client-py/README.md                                |  209 --
 client-py/SessionExample.py                        |  177 --
 client-py/SessionTest.py                           |  243 --
 client-py/iotdb/IoTDBContainer.py                  |   51 -
 client-py/iotdb/Session.py                         |  756 -----
 client-py/iotdb/__init__.py                        |   17 -
 client-py/iotdb/utils/Field.py                     |  177 --
 client-py/iotdb/utils/IoTDBConstants.py            |   54 -
 client-py/iotdb/utils/IoTDBRpcDataSet.py           |  271 --
 client-py/iotdb/utils/RowRecord.py                 |   55 -
 client-py/iotdb/utils/SessionDataSet.py            |  181 --
 client-py/iotdb/utils/Tablet.py                    |  131 -
 client-py/iotdb/utils/__init__.py                  |   17 -
 client-py/pom.xml                                  |  123 -
 client-py/pyproject.toml                           |   45 -
 client-py/release.sh                               |   37 -
 client-py/setup.py                                 |   57 -
 client-py/tests/__init__.py                        |   17 -
 client-py/tests/test_dataframe.py                  |   41 -
 cluster/pom.xml                                    |  237 --
 cluster/src/assembly/cluster.xml                   |   31 -
 .../resources/conf/iotdb-cluster.properties        |  173 --
 cluster/src/assembly/resources/sbin/add-node.bat   |  108 -
 cluster/src/assembly/resources/sbin/add-node.sh    |   76 -
 cluster/src/assembly/resources/sbin/nodetool.bat   |   58 -
 cluster/src/assembly/resources/sbin/nodetool.sh    |   48 -
 cluster/src/assembly/resources/sbin/start-node.bat |  133 -
 cluster/src/assembly/resources/sbin/start-node.sh  |   97 -
 cluster/src/assembly/resources/sbin/stop-node.bat  |   27 -
 cluster/src/assembly/resources/sbin/stop-node.sh   |   39 -
 .../java/org/apache/iotdb/cluster/ClientMain.java  |  469 ---
 .../iotdb/cluster/ClusterFileFlushPolicy.java      |   78 -
 .../java/org/apache/iotdb/cluster/ClusterMain.java |  302 --
 .../apache/iotdb/cluster/RemoteTsFileResource.java |  149 -
 .../iotdb/cluster/client/DataClientProvider.java   |   95 -
 .../cluster/client/async/AsyncClientFactory.java   |   65 -
 .../cluster/client/async/AsyncClientPool.java      |  216 --
 .../cluster/client/async/AsyncDataClient.java      |  161 --
 .../client/async/AsyncDataHeartbeatClient.java     |   81 -
 .../cluster/client/async/AsyncMetaClient.java      |  135 -
 .../client/async/AsyncMetaHeartbeatClient.java     |   81 -
 .../cluster/client/sync/SyncClientAdaptor.java     |  516 ----
 .../cluster/client/sync/SyncClientFactory.java     |   40 -
 .../iotdb/cluster/client/sync/SyncClientPool.java  |  169 --
 .../iotdb/cluster/client/sync/SyncDataClient.java  |  116 -
 .../client/sync/SyncDataHeartbeatClient.java       |   77 -
 .../iotdb/cluster/client/sync/SyncMetaClient.java  |   99 -
 .../client/sync/SyncMetaHeartbeatClient.java       |   77 -
 .../apache/iotdb/cluster/config/ClusterConfig.java |  470 ---
 .../iotdb/cluster/config/ClusterConstant.java      |   66 -
 .../iotdb/cluster/config/ClusterDescriptor.java    |  386 ---
 .../iotdb/cluster/config/ConsistencyLevel.java     |   67 -
 .../iotdb/cluster/coordinator/Coordinator.java     |  691 -----
 .../iotdb/cluster/exception/AddSelfException.java  |   28 -
 .../exception/BadSeedUrlFormatException.java       |   30 -
 .../exception/CheckConsistencyException.java       |   37 -
 .../exception/ConfigInconsistentException.java     |   29 -
 .../cluster/exception/EmptyIntervalException.java  |   28 -
 .../cluster/exception/EntryCompactedException.java |   30 -
 .../exception/EntryUnavailableException.java       |   28 -
 .../GetEntriesWrongParametersException.java        |   27 -
 .../cluster/exception/LeaderUnknownException.java  |   31 -
 .../cluster/exception/LogExecutionException.java   |   27 -
 .../cluster/exception/MemberReadOnlyException.java |   33 -
 .../cluster/exception/NoHeaderNodeException.java   |   31 -
 .../cluster/exception/NotInSameGroupException.java |   32 -
 .../cluster/exception/NotManagedSlotException.java |   33 -
 .../PartitionTableUnavailableException.java        |   30 -
 .../iotdb/cluster/exception/PullFileException.java |   34 -
 .../cluster/exception/QueryTimeOutException.java   |   27 -
 .../cluster/exception/ReaderNotFoundException.java |   27 -
 .../cluster/exception/RequestTimeOutException.java |   34 -
 .../exception/SnapshotInstallationException.java   |   37 -
 .../exception/StartUpCheckFailureException.java    |   31 -
 .../exception/TruncateCommittedEntryException.java |   30 -
 .../cluster/exception/UnknownLogTypeException.java |   28 -
 .../exception/UnsupportedPlanException.java        |   29 -
 .../iotdb/cluster/log/CommitLogCallback.java       |   48 -
 .../apache/iotdb/cluster/log/CommitLogTask.java    |   65 -
 .../org/apache/iotdb/cluster/log/HardState.java    |  114 -
 .../java/org/apache/iotdb/cluster/log/Log.java     |  145 -
 .../org/apache/iotdb/cluster/log/LogApplier.java   |   35 -
 .../apache/iotdb/cluster/log/LogDispatcher.java    |  457 ---
 .../org/apache/iotdb/cluster/log/LogParser.java    |  100 -
 .../org/apache/iotdb/cluster/log/Snapshot.java     |   70 -
 .../iotdb/cluster/log/StableEntryManager.java      |   55 -
 .../cluster/log/applier/AsyncDataLogApplier.java   |  302 --
 .../iotdb/cluster/log/applier/BaseApplier.java     |  187 --
 .../iotdb/cluster/log/applier/DataLogApplier.java  |  139 -
 .../iotdb/cluster/log/applier/MetaLogApplier.java  |   69 -
 .../iotdb/cluster/log/catchup/CatchUpTask.java     |  400 ---
 .../iotdb/cluster/log/catchup/LogCatchUpTask.java  |  348 ---
 .../cluster/log/catchup/SnapshotCatchUpTask.java   |  158 --
 .../iotdb/cluster/log/logtypes/AddNodeLog.java     |   92 -
 .../iotdb/cluster/log/logtypes/CloseFileLog.java   |  124 -
 .../cluster/log/logtypes/EmptyContentLog.java      |   63 -
 .../iotdb/cluster/log/logtypes/LargeTestLog.java   |   78 -
 .../cluster/log/logtypes/PhysicalPlanLog.java      |  115 -
 .../iotdb/cluster/log/logtypes/RemoveNodeLog.java  |   87 -
 .../cluster/log/manage/CommittedEntryManager.java  |  289 --
 .../manage/FilePartitionedSnapshotLogManager.java  |  226 --
 .../log/manage/MetaSingleSnapshotLogManager.java   |   85 -
 .../log/manage/PartitionedSnapshotLogManager.java  |  118 -
 .../iotdb/cluster/log/manage/RaftLogManager.java   | 1017 -------
 .../log/manage/UnCommittedEntryManager.java        |  276 --
 .../log/manage/serializable/LogManagerMeta.java    |  143 -
 .../serializable/SyncLogDequeSerializer.java       | 1383 ---------
 .../iotdb/cluster/log/snapshot/FileSnapshot.java   |  641 -----
 .../cluster/log/snapshot/MetaSimpleSnapshot.java   |  301 --
 .../cluster/log/snapshot/PartitionedSnapshot.java  |  216 --
 .../cluster/log/snapshot/PullSnapshotTask.java     |  248 --
 .../log/snapshot/PullSnapshotTaskDescriptor.java   |  134 -
 .../cluster/log/snapshot/SnapshotFactory.java      |   28 -
 .../cluster/log/snapshot/SnapshotInstaller.java    |   32 -
 .../log/snapshot/TimeseriesSchemaSnapshot.java     |   31 -
 .../apache/iotdb/cluster/metadata/CMManager.java   | 1800 ------------
 .../apache/iotdb/cluster/metadata/MetaPuller.java  |  246 --
 .../cluster/partition/NodeAdditionResult.java      |   34 -
 .../iotdb/cluster/partition/NodeRemovalResult.java |   44 -
 .../iotdb/cluster/partition/PartitionGroup.java    |   64 -
 .../iotdb/cluster/partition/PartitionTable.java    |  131 -
 .../iotdb/cluster/partition/slot/SlotManager.java  |  320 ---
 .../partition/slot/SlotNodeAdditionResult.java     |   40 -
 .../partition/slot/SlotNodeRemovalResult.java      |   40 -
 .../cluster/partition/slot/SlotPartitionTable.java |  506 ----
 .../iotdb/cluster/partition/slot/SlotStrategy.java |   33 -
 .../cluster/query/ClusterConcatPathOptimizer.java  |   37 -
 .../cluster/query/ClusterDataQueryExecutor.java    |  326 ---
 .../cluster/query/ClusterPhysicalGenerator.java    |  125 -
 .../iotdb/cluster/query/ClusterPlanExecutor.java   |  639 -----
 .../iotdb/cluster/query/ClusterPlanRouter.java     |  467 ---
 .../apache/iotdb/cluster/query/ClusterPlanner.java |   58 -
 .../iotdb/cluster/query/ClusterQueryRouter.java    |   94 -
 .../iotdb/cluster/query/LocalQueryExecutor.java    |  967 -------
 .../iotdb/cluster/query/RemoteQueryContext.java    |   71 -
 .../query/aggregate/ClusterAggregateExecutor.java  |  102 -
 .../cluster/query/aggregate/ClusterAggregator.java |  283 --
 .../query/dataset/ClusterAlignByDeviceDataSet.java |   61 -
 .../cluster/query/fill/ClusterFillExecutor.java    |   68 -
 .../cluster/query/fill/ClusterLinearFill.java      |   76 -
 .../cluster/query/fill/ClusterPreviousFill.java    |  259 --
 .../cluster/query/fill/PreviousFillArguments.java  |   70 -
 .../iotdb/cluster/query/filter/SlotSgFilter.java   |   47 -
 .../cluster/query/filter/SlotTsFileFilter.java     |   62 -
 .../groupby/ClusterGroupByNoVFilterDataSet.java    |   67 -
 .../groupby/ClusterGroupByVFilterDataSet.java      |   82 -
 .../query/groupby/MergeGroupByExecutor.java        |  144 -
 .../query/groupby/RemoteGroupByExecutor.java       |  162 --
 .../query/last/ClusterLastQueryExecutor.java       |  277 --
 .../cluster/query/manage/ClusterQueryManager.java  |  133 -
 .../cluster/query/manage/QueryCoordinator.java     |   66 -
 .../cluster/query/reader/ClusterReaderFactory.java | 1044 -------
 .../cluster/query/reader/ClusterTimeGenerator.java |  211 --
 .../iotdb/cluster/query/reader/DataSourceInfo.java |  264 --
 .../iotdb/cluster/query/reader/EmptyReader.java    |  172 --
 .../cluster/query/reader/ManagedMergeReader.java   |   94 -
 .../cluster/query/reader/MergedReaderByTime.java   |   47 -
 .../reader/RemoteSeriesReaderByTimestamp.java      |  122 -
 .../query/reader/RemoteSimpleSeriesReader.java     |  167 --
 .../query/reader/mult/AbstractMultPointReader.java |   70 -
 .../reader/mult/AssignPathManagedMergeReader.java  |   92 -
 .../reader/mult/AssignPathPriorityMergeReader.java |   66 -
 .../query/reader/mult/IMultBatchReader.java        |   31 -
 .../cluster/query/reader/mult/MultBatchReader.java |   73 -
 .../query/reader/mult/MultDataSourceInfo.java      |  264 --
 .../cluster/query/reader/mult/MultEmptyReader.java |   52 -
 .../reader/mult/MultSeriesRawDataPointReader.java  |   55 -
 .../query/reader/mult/RemoteMultSeriesReader.java  |  222 --
 .../apache/iotdb/cluster/server/ClientServer.java  |  330 ---
 .../iotdb/cluster/server/DataClusterServer.java    |  966 -------
 .../iotdb/cluster/server/HardLinkCleaner.java      |  110 -
 .../iotdb/cluster/server/MetaClusterServer.java    |  369 ---
 .../apache/iotdb/cluster/server/NodeCharacter.java |   28 -
 .../cluster/server/PullSnapshotHintService.java    |  142 -
 .../apache/iotdb/cluster/server/RaftServer.java    |  263 --
 .../org/apache/iotdb/cluster/server/Response.java  |   58 -
 .../iotdb/cluster/server/StoppedMemberManager.java |  156 -
 .../handlers/caller/AppendGroupEntryHandler.java   |  157 -
 .../handlers/caller/AppendNodeEntryHandler.java    |  185 --
 .../server/handlers/caller/ElectionHandler.java    |  144 -
 .../server/handlers/caller/GenericHandler.java     |   94 -
 .../caller/GetChildNodeNextLevelHandler.java       |   59 -
 .../caller/GetChildNodeNextLevelPathHandler.java   |   60 -
 .../server/handlers/caller/GetDevicesHandler.java  |   60 -
 .../handlers/caller/GetNodesListHandler.java       |   59 -
 .../caller/GetTimeseriesSchemaHandler.java         |   59 -
 .../server/handlers/caller/HeartbeatHandler.java   |  148 -
 .../server/handlers/caller/JoinClusterHandler.java |   65 -
 .../server/handlers/caller/LogCatchUpHandler.java  |  106 -
 .../handlers/caller/LogCatchUpInBatchHandler.java  |  111 -
 .../server/handlers/caller/NodeStatusHandler.java  |   55 -
 .../handlers/caller/PreviousFillHandler.java       |   81 -
 .../caller/PullMeasurementSchemaHandler.java       |   73 -
 .../handlers/caller/PullSnapshotHandler.java       |   81 -
 .../caller/PullTimeseriesSchemaHandler.java        |   73 -
 .../handlers/caller/SnapshotCatchUpHandler.java    |   61 -
 .../server/handlers/caller/package-info.java       |   21 -
 .../handlers/forwarder/ForwardPlanHandler.java     |   68 -
 .../server/heartbeat/DataHeartbeatServer.java      |   83 -
 .../server/heartbeat/DataHeartbeatThread.java      |   74 -
 .../cluster/server/heartbeat/HeartbeatServer.java  |  212 --
 .../cluster/server/heartbeat/HeartbeatThread.java  |  412 ---
 .../server/heartbeat/MetaHeartbeatServer.java      |   91 -
 .../server/heartbeat/MetaHeartbeatThread.java      |   73 -
 .../cluster/server/member/DataGroupMember.java     |  868 ------
 .../cluster/server/member/MetaGroupMember.java     | 1812 ------------
 .../iotdb/cluster/server/member/RaftMember.java    | 1969 -------------
 .../iotdb/cluster/server/member/package-info.java  |   24 -
 .../iotdb/cluster/server/monitor/NodeReport.java   |  265 --
 .../iotdb/cluster/server/monitor/NodeStatus.java   |  118 -
 .../cluster/server/monitor/NodeStatusManager.java  |  183 --
 .../apache/iotdb/cluster/server/monitor/Peer.java  |   70 -
 .../apache/iotdb/cluster/server/monitor/Timer.java |  337 ---
 .../cluster/server/service/BaseAsyncService.java   |  176 --
 .../cluster/server/service/BaseSyncService.java    |  181 --
 .../cluster/server/service/DataAsyncService.java   |  456 ---
 .../cluster/server/service/DataSyncService.java    |  423 ---
 .../cluster/server/service/MetaAsyncService.java   |  209 --
 .../cluster/server/service/MetaSyncService.java    |  201 --
 .../iotdb/cluster/server/service/package-info.java |   24 -
 .../apache/iotdb/cluster/utils/ClientUtils.java    |   70 -
 .../iotdb/cluster/utils/ClusterConsistent.java     |   30 -
 .../apache/iotdb/cluster/utils/ClusterNode.java    |   86 -
 .../iotdb/cluster/utils/ClusterQueryUtils.java     |   68 -
 .../apache/iotdb/cluster/utils/ClusterUtils.java   |  356 ---
 .../org/apache/iotdb/cluster/utils/IOUtils.java    |   88 -
 .../iotdb/cluster/utils/NodeSerializeUtils.java    |   90 -
 .../apache/iotdb/cluster/utils/PartitionUtils.java |  400 ---
 .../apache/iotdb/cluster/utils/PlanSerializer.java |   53 -
 .../apache/iotdb/cluster/utils/StatusUtils.java    |  217 --
 .../cluster/utils/nodetool/ClusterMonitor.java     |  180 --
 .../utils/nodetool/ClusterMonitorMBean.java        |   84 -
 .../iotdb/cluster/utils/nodetool/NodeTool.java     |   43 -
 .../iotdb/cluster/utils/nodetool/Printer.java      |   38 -
 .../cluster/utils/nodetool/function/Host.java      |   77 -
 .../cluster/utils/nodetool/function/LogView.java   |   88 -
 .../utils/nodetool/function/NodeToolCmd.java       |  130 -
 .../cluster/utils/nodetool/function/Partition.java |  102 -
 .../cluster/utils/nodetool/function/Ring.java      |   45 -
 .../cluster/utils/nodetool/function/Status.java    |   48 -
 .../cluster/client/DataClientProviderTest.java     |  242 --
 .../cluster/client/async/AsyncClientPoolTest.java  |  211 --
 .../cluster/client/async/AsyncDataClientTest.java  |   88 -
 .../client/async/AsyncDataHeartbeatClientTest.java |   60 -
 .../cluster/client/async/AsyncMetaClientTest.java  |   88 -
 .../client/async/AsyncMetaHeartbeatClientTest.java |   61 -
 .../cluster/client/sync/SyncClientAdaptorTest.java |  433 ---
 .../cluster/client/sync/SyncClientPoolTest.java    |  167 --
 .../cluster/client/sync/SyncDataClientTest.java    |  126 -
 .../client/sync/SyncDataHeartbeatClientTest.java   |   66 -
 .../cluster/client/sync/SyncMetaClientTest.java    |  114 -
 .../client/sync/SyncMetaHeartbeatClientTest.java   |   66 -
 .../org/apache/iotdb/cluster/common/IoTDBTest.java |  181 --
 .../iotdb/cluster/common/TestAsyncClient.java      |   53 -
 .../cluster/common/TestAsyncClientFactory.java     |   55 -
 .../iotdb/cluster/common/TestAsyncDataClient.java  |  276 --
 .../iotdb/cluster/common/TestAsyncMetaClient.java  |   53 -
 .../iotdb/cluster/common/TestDataGroupMember.java  |   47 -
 .../apache/iotdb/cluster/common/TestException.java |   27 -
 .../org/apache/iotdb/cluster/common/TestLog.java   |   67 -
 .../iotdb/cluster/common/TestLogApplier.java       |   66 -
 .../iotdb/cluster/common/TestLogManager.java       |   39 -
 .../cluster/common/TestManagedSeriesReader.java    |   96 -
 .../iotdb/cluster/common/TestMetaGroupMember.java  |   40 -
 .../cluster/common/TestPartitionedLogManager.java  |   54 -
 .../apache/iotdb/cluster/common/TestSnapshot.java  |  110 -
 .../iotdb/cluster/common/TestSyncClient.java       |   47 -
 .../cluster/common/TestSyncClientFactory.java      |   75 -
 .../org/apache/iotdb/cluster/common/TestUtils.java |  419 ---
 .../cluster/integration/BaseSingleNodeTest.java    |   86 -
 .../iotdb/cluster/integration/SingleNodeTest.java  |   96 -
 .../iotdb/cluster/log/CommitLogCallbackTest.java   |   53 -
 .../iotdb/cluster/log/CommitLogTaskTest.java       |   75 -
 .../apache/iotdb/cluster/log/HardStateTest.java    |   49 -
 .../iotdb/cluster/log/LogDispatcherTest.java       |  268 --
 .../apache/iotdb/cluster/log/LogParserTest.java    |  101 -
 .../log/applier/AsyncDataLogApplierTest.java       |  174 --
 .../cluster/log/applier/DataLogApplierTest.java    |  376 ---
 .../cluster/log/applier/MetaLogApplierTest.java    |  129 -
 .../iotdb/cluster/log/catchup/CatchUpTaskTest.java |  399 ---
 .../cluster/log/catchup/LogCatchUpTaskTest.java    |  305 --
 .../log/catchup/SnapshotCatchUpTaskTest.java       |  286 --
 .../cluster/log/logtypes/SerializeLogTest.java     |  143 -
 .../log/manage/CommittedEntryManagerTest.java      |  625 ----
 .../FilePartitionedSnapshotLogManagerTest.java     |  109 -
 .../manage/MetaSingleSnapshotLogManagerTest.java   |   93 -
 .../cluster/log/manage/RaftLogManagerTest.java     | 1889 -------------
 .../log/manage/UnCommittedEntryManagerTest.java    |  695 -----
 .../serializable/SyncLogDequeSerializerTest.java   |  612 ----
 .../cluster/log/snapshot/DataSnapshotTest.java     |  188 --
 .../cluster/log/snapshot/FileSnapshotTest.java     |  306 --
 .../log/snapshot/MetaSimpleSnapshotTest.java       |  191 --
 .../log/snapshot/PartitionedSnapshotTest.java      |  123 -
 .../snapshot/PullSnapshotTaskDescriptorTest.java   |   64 -
 .../cluster/log/snapshot/PullSnapshotTaskTest.java |  327 ---
 .../iotdb/cluster/log/snapshot/SimpleSnapshot.java |  132 -
 .../iotdb/cluster/partition/MManagerWhiteBox.java  |   54 -
 .../iotdb/cluster/partition/SlotManagerTest.java   |  155 -
 .../cluster/partition/SlotPartitionTableTest.java  |  578 ----
 .../apache/iotdb/cluster/query/BaseQueryTest.java  |  127 -
 .../query/ClusterAggregateExecutorTest.java        |  162 --
 .../query/ClusterDataQueryExecutorTest.java        |  158 --
 .../cluster/query/ClusterFillExecutorTest.java     |  140 -
 .../query/ClusterPhysicalGeneratorTest.java        |   68 -
 .../cluster/query/ClusterPlanExecutorTest.java     |   91 -
 .../iotdb/cluster/query/ClusterPlannerTest.java    |   56 -
 .../cluster/query/ClusterQueryRouterTest.java      |  308 --
 .../iotdb/cluster/query/LoadConfigurationTest.java |  124 -
 .../ClusterGroupByNoVFilterDataSetTest.java        |   93 -
 .../groupby/ClusterGroupByVFilterDataSetTest.java  |  103 -
 .../query/groupby/MergeGroupByExecutorTest.java    |  123 -
 .../query/groupby/RemoteGroupByExecutorTest.java   |  174 --
 .../query/manage/ClusterQueryManagerTest.java      |  186 --
 .../cluster/query/manage/QueryCoordinatorTest.java |  125 -
 .../query/reader/ClusterTimeGeneratorTest.java     |   75 -
 .../cluster/query/reader/DatasourceInfoTest.java   |   87 -
 .../reader/RemoteSeriesReaderByTimestampTest.java  |  248 --
 .../query/reader/RemoteSimpleSeriesReaderTest.java |  224 --
 .../mult/AssignPathManagedMergeReaderTest.java     |  190 --
 .../mult/MultSeriesRawDataPointReaderTest.java     |   67 -
 .../reader/mult/RemoteMultSeriesReaderTest.java    |  286 --
 .../caller/AppendGroupEntryHandlerTest.java        |  187 --
 .../caller/AppendNodeEntryHandlerTest.java         |  174 --
 .../handlers/caller/ElectionHandlerTest.java       |  177 --
 .../server/handlers/caller/GenericHandlerTest.java |   58 -
 .../handlers/caller/HeartbeatHandlerTest.java      |  103 -
 .../handlers/caller/JoinClusterHandlerTest.java    |   67 -
 .../handlers/caller/LogCatchUpHandlerTest.java     |  127 -
 .../caller/PullMeasurementSchemaHandlerTest.java   |   92 -
 .../handlers/caller/PullSnapshotHandlerTest.java   |   84 -
 .../caller/SnapshotCatchUpHandlerTest.java         |   58 -
 .../handlers/forwarder/ForwardPlanHandlerTest.java |   59 -
 .../server/heartbeat/DataHeartbeatThreadTest.java  |  167 --
 .../server/heartbeat/HeartbeatThreadTest.java      |  255 --
 .../server/heartbeat/MetaHeartbeatThreadTest.java  |  223 --
 .../iotdb/cluster/server/member/BaseMember.java    |  315 ---
 .../cluster/server/member/DataGroupMemberTest.java | 1196 --------
 .../cluster/server/member/MetaGroupMemberTest.java | 1373 ---------
 .../cluster/server/member/RaftMemberTest.java      |  245 --
 .../org/apache/iotdb/cluster/utils/Constants.java  |   24 -
 .../iotdb/cluster/utils/SerializeUtilTest.java     |  194 --
 cluster/src/test/resources/logback.xml             |   45 -
 .../resources/node1conf/iotdb-cluster.properties   |   36 -
 .../resources/node1conf/iotdb-engine.properties    |   29 -
 .../resources/node2conf/iotdb-cluster.properties   |   36 -
 .../resources/node2conf/iotdb-engine.properties    |   29 -
 .../resources/node3conf/iotdb-cluster.properties   |   36 -
 .../resources/node3conf/iotdb-engine.properties    |   29 -
 code-coverage/README.md                            |   24 -
 code-coverage/copy-code-coverage-sources.sh        |   30 -
 code-coverage/pom.xml                              |  139 -
 codecov.yml                                        |   49 -
 compile-tools/README.md                            |  183 --
 compile-tools/pom.xml                              |  122 -
 compile-tools/thrift/pom.xml                       |  235 --
 cross-tests/pom.xml                                |  115 -
 .../tests/tools/importCsv/AbstractScript.java      |   99 -
 .../tests/tools/importCsv/ExportCsvTestIT.java     |  221 --
 .../tests/tools/importCsv/ImportCsvTestIT.java     |  335 ---
 .../src/test/resources/iotdb-engine.properties     |   21 -
 distribution/pom.xml                               |  145 -
 distribution/src/assembly/all.xml                  |  102 -
 distribution/src/assembly/cli.xml                  |   54 -
 distribution/src/assembly/client-cpp.xml           |   38 -
 distribution/src/assembly/cluster.xml              |   81 -
 distribution/src/assembly/common-files.xml         |   48 -
 distribution/src/assembly/grafana.xml              |   48 -
 distribution/src/assembly/server.xml               |   80 -
 docker/ReadMe.md                                   |   69 -
 docker/src/main/Dockerfile                         |   43 -
 docker/src/main/Dockerfile-0.10.0                  |   39 -
 docker/src/main/Dockerfile-0.10.1                  |   39 -
 docker/src/main/Dockerfile-0.11.0                  |   39 -
 docker/src/main/Dockerfile-0.11.1                  |   39 -
 docker/src/main/Dockerfile-0.11.2                  |   41 -
 docker/src/main/Dockerfile-0.8.1                   |   40 -
 docker/src/main/Dockerfile-0.9.0                   |   41 -
 docker/src/main/Dockerfile-0.9.1                   |   41 -
 docker/src/main/Dockerfile-0.9.1-jre8              |   41 -
 docs/Blog/Release0_93.md                           |   69 -
 docs/Blog/index.md                                 |   24 -
 docs/Community/Community-Powered By.md             |   52 -
 docs/Community/Community-Project Committers.md     |   22 -
 docs/Community/Feedback.md                         |   50 -
 docs/Community/Materials.md                        |  186 --
 docs/Development/Committer.md                      |   77 -
 docs/Development/ContributeGuide.md                |  153 -
 docs/Development/HowToCommit.md                    |  139 -
 docs/Development/VoteRelease.md                    |  190 --
 docs/Download/README.md                            |  123 -
 docs/README.md                                     |   21 -
 docs/SystemDesign/Architecture/Architecture.md     |   54 -
 docs/SystemDesign/Client/RPC.md                    |   56 -
 docs/SystemDesign/Connector/Hive-TsFile.md         |  114 -
 docs/SystemDesign/Connector/Spark-IOTDB.md         |   87 -
 docs/SystemDesign/Connector/Spark-TsFile.md        |  114 -
 docs/SystemDesign/DataQuery/AggregationQuery.md    |  136 -
 docs/SystemDesign/DataQuery/AlignByDeviceQuery.md  |  272 --
 docs/SystemDesign/DataQuery/DataQuery.md           |   46 -
 docs/SystemDesign/DataQuery/FillFunction.md        |  159 --
 docs/SystemDesign/DataQuery/GroupByFillQuery.md    |  177 --
 docs/SystemDesign/DataQuery/GroupByQuery.md        |  283 --
 docs/SystemDesign/DataQuery/LastQuery.md           |  137 -
 docs/SystemDesign/DataQuery/QueryFundamentals.md   |  161 --
 docs/SystemDesign/DataQuery/RawDataQuery.md        |  303 --
 docs/SystemDesign/DataQuery/SeriesReader.md        |  384 ---
 docs/SystemDesign/QueryEngine/PlanExecutor.md      |   26 -
 docs/SystemDesign/QueryEngine/Planner.md           |   65 -
 docs/SystemDesign/QueryEngine/QueryEngine.md       |   64 -
 .../QueryEngine/ResultSetConstruction.md           |  177 --
 docs/SystemDesign/SchemaManager/SchemaManager.md   |  329 ---
 .../SystemDesign/StorageEngine/DataManipulation.md |  104 -
 docs/SystemDesign/StorageEngine/DataPartition.md   |   86 -
 docs/SystemDesign/StorageEngine/FlushManager.md    |   84 -
 docs/SystemDesign/StorageEngine/MergeManager.md    |  107 -
 docs/SystemDesign/StorageEngine/Recover.md         |  106 -
 docs/SystemDesign/StorageEngine/StorageEngine.md   |   68 -
 docs/SystemDesign/StorageEngine/WAL.md             |   48 -
 docs/SystemDesign/Tools/Sync.md                    |  249 --
 docs/SystemDesign/TsFile/Format.md                 |  587 ----
 docs/SystemDesign/TsFile/Read.md                   |  559 ----
 docs/SystemDesign/TsFile/TsFile.md                 |   30 -
 docs/SystemDesign/TsFile/Write.md                  |  126 -
 docs/UserGuide/API/Programming-JDBC.md             |  203 --
 docs/UserGuide/API/Programming-Native-API.md       |  335 ---
 docs/UserGuide/API/Programming-Other-Languages.md  |  271 --
 docs/UserGuide/API/Programming-TsFile-API.md       |  555 ----
 .../Administration-Management/Administration.md    |  160 --
 docs/UserGuide/Appendix/Config-Manual.md           |  686 -----
 docs/UserGuide/Appendix/SQL-Reference.md           | 1145 --------
 docs/UserGuide/Appendix/Status-Codes.md            |  107 -
 docs/UserGuide/CLI/Command-Line-Interface.md       |  194 --
 docs/UserGuide/Cluster/Cluster-Setup-Example.md    |   47 -
 docs/UserGuide/Cluster/Cluster-Setup.md            |  244 --
 .../Collaboration-of-Edge-and-Cloud/Sync-Tool.md   |  186 --
 .../Programming-MQTT.md                            |  104 -
 .../Programming-Thrift.md                          |  157 -
 docs/UserGuide/Comparison/TSDB-Comparison.md       |  374 ---
 docs/UserGuide/Data-Concept/Compression.md         |   36 -
 .../Data-Concept/Data-Model-and-Terminology.md     |  240 --
 docs/UserGuide/Data-Concept/Data-Type.md           |   44 -
 docs/UserGuide/Data-Concept/Encoding.md            |   71 -
 docs/UserGuide/Data-Concept/SDT.md                 |  111 -
 .../UserGuide/Ecosystem Integration/Flink IoTDB.md |  213 --
 .../Ecosystem Integration/Flink TsFile.md          |  181 --
 docs/UserGuide/Ecosystem Integration/Grafana.md    |  164 --
 .../UserGuide/Ecosystem Integration/Hive TsFile.md |  171 --
 .../Ecosystem Integration/MapReduce TsFile.md      |  199 --
 .../UserGuide/Ecosystem Integration/Spark IoTDB.md |  166 --
 .../Ecosystem Integration/Spark TsFile.md          |  315 ---
 .../Ecosystem Integration/Writing Data on HDFS.md  |  171 --
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  176 --
 docs/UserGuide/FAQ/Frequently-asked-questions.md   |  152 -
 docs/UserGuide/IoTDB-Introduction/Architecture.md  |   38 -
 docs/UserGuide/IoTDB-Introduction/Features.md      |   50 -
 docs/UserGuide/IoTDB-Introduction/Publication.md   |   40 -
 docs/UserGuide/IoTDB-Introduction/Scenario.md      |   76 -
 docs/UserGuide/IoTDB-Introduction/What-is-IoTDB.md |   24 -
 .../DDL-Data-Definition-Language.md                |  544 ----
 .../DML-Data-Manipulation-Language.md              | 1521 ----------
 .../IoTDB-SQL-Language/Maintenance-Command.md      |  102 -
 docs/UserGuide/QuickStart/Files.md                 |   60 -
 docs/UserGuide/QuickStart/QuickStart.md            |  239 --
 docs/UserGuide/QuickStart/ServerFileList.md        |  160 --
 docs/UserGuide/QuickStart/WayToGetIoTDB.md         |  144 -
 docs/UserGuide/System-Tools/CSV-Tool.md            |  144 -
 docs/UserGuide/System-Tools/JMX-Tool.md            |   59 -
 .../UserGuide/System-Tools/Load-External-Tsfile.md |   82 -
 docs/UserGuide/System-Tools/MLogParser-Tool.md     |   38 -
 .../System-Tools/Monitor-and-Log-Tools.md          |  252 --
 docs/UserGuide/System-Tools/NodeTool.md            |  297 --
 .../System-Tools/Performance-Tracing-Tool.md       |   63 -
 .../Query-History-Visualization-Tool.md            |   31 -
 docs/UserGuide/System-Tools/Watermark-Tool.md      |  196 --
 docs/UserGuide/UDF/Triggers.md                     |  100 -
 docs/UserGuide/UDF/UDF-User-Defined-Function.md    |  587 ----
 docs/UserGuide/UserGuideReadme.md                  |   32 -
 docs/zh/Community/Community-Powered By.md          |   61 -
 docs/zh/Community/Community-Project Committers.md  |   22 -
 docs/zh/Community/Feedback.md                      |   46 -
 docs/zh/Development/Committer.md                   |   78 -
 docs/zh/Development/ContributeGuide.md             |  157 -
 docs/zh/Development/HowToCommit.md                 |  139 -
 docs/zh/Development/VoteRelease.md                 |  190 --
 docs/zh/Download/README.md                         |  107 -
 docs/zh/README.md                                  |   21 -
 docs/zh/SystemDesign/Architecture/Architecture.md  |   55 -
 docs/zh/SystemDesign/Client/RPC.md                 |   57 -
 docs/zh/SystemDesign/Connector/Hive-TsFile.md      |  121 -
 docs/zh/SystemDesign/Connector/Spark-IOTDB.md      |   89 -
 docs/zh/SystemDesign/Connector/Spark-TsFile.md     |  125 -
 docs/zh/SystemDesign/DataQuery/AggregationQuery.md |  134 -
 .../SystemDesign/DataQuery/AlignByDeviceQuery.md   |  270 --
 docs/zh/SystemDesign/DataQuery/DataQuery.md        |   48 -
 docs/zh/SystemDesign/DataQuery/FillFunction.md     |  159 --
 docs/zh/SystemDesign/DataQuery/GroupByFillQuery.md |  176 --
 docs/zh/SystemDesign/DataQuery/GroupByQuery.md     |  288 --
 docs/zh/SystemDesign/DataQuery/LastQuery.md        |  133 -
 docs/zh/SystemDesign/DataQuery/OrderByTimeQuery.md |  190 --
 .../zh/SystemDesign/DataQuery/QueryFundamentals.md |  144 -
 docs/zh/SystemDesign/DataQuery/RawDataQuery.md     |  323 ---
 docs/zh/SystemDesign/DataQuery/SeriesReader.md     |  384 ---
 docs/zh/SystemDesign/QueryEngine/PlanExecutor.md   |   26 -
 docs/zh/SystemDesign/QueryEngine/Planner.md        |   63 -
 docs/zh/SystemDesign/QueryEngine/QueryEngine.md    |   64 -
 .../QueryEngine/ResultSetConstruction.md           |  175 --
 .../zh/SystemDesign/SchemaManager/SchemaManager.md |  323 ---
 docs/zh/SystemDesign/StorageEngine/Compaction.md   |  258 --
 .../SystemDesign/StorageEngine/DataManipulation.md |  105 -
 .../zh/SystemDesign/StorageEngine/DataPartition.md |   86 -
 docs/zh/SystemDesign/StorageEngine/FileLists.md    |  156 -
 docs/zh/SystemDesign/StorageEngine/FlushManager.md |   84 -
 docs/zh/SystemDesign/StorageEngine/MergeManager.md |  112 -
 docs/zh/SystemDesign/StorageEngine/Recover.md      |  107 -
 .../zh/SystemDesign/StorageEngine/StorageEngine.md |   67 -
 docs/zh/SystemDesign/StorageEngine/WAL.md          |   48 -
 docs/zh/SystemDesign/Tools/Sync.md                 |  299 --
 docs/zh/SystemDesign/TsFile/Format.md              |  584 ----
 docs/zh/SystemDesign/TsFile/Read.md                |  566 ----
 docs/zh/SystemDesign/TsFile/TsFile.md              |   31 -
 docs/zh/SystemDesign/TsFile/Write.md               |  126 -
 docs/zh/UserGuide/API/Programming-JDBC.md          |  201 --
 docs/zh/UserGuide/API/Programming-Native-API.md    |  238 --
 .../UserGuide/API/Programming-Other-Languages.md   |  320 ---
 docs/zh/UserGuide/API/Programming-TsFile-API.md    |  549 ----
 .../Administration-Management/Administration.md    |  168 --
 docs/zh/UserGuide/Appendix/Config-Manual.md        |  715 -----
 docs/zh/UserGuide/Appendix/SQL-Reference.md        | 1113 --------
 docs/zh/UserGuide/Appendix/Status-Codes.md         |  106 -
 docs/zh/UserGuide/CLI/Command-Line-Interface.md    |  192 --
 docs/zh/UserGuide/Cluster/Cluster-Setup-Example.md |   46 -
 docs/zh/UserGuide/Cluster/Cluster-Setup.md         |  237 --
 .../Collaboration-of-Edge-and-Cloud/Sync-Tool.md   |  187 --
 .../Programming-MQTT.md                            |  106 -
 .../Programming-Thrift.md                          |  157 -
 docs/zh/UserGuide/Data-Concept/Compression.md      |   33 -
 .../Data-Concept/Data-Model-and-Terminology.md     |  236 --
 docs/zh/UserGuide/Data-Concept/Data-Type.md        |   42 -
 docs/zh/UserGuide/Data-Concept/Encoding.md         |   71 -
 docs/zh/UserGuide/Data-Concept/SDT.md              |  106 -
 .../UserGuide/Ecosystem Integration/Flink IoTDB.md |  122 -
 .../Ecosystem Integration/Flink TsFile.md          |  179 --
 docs/zh/UserGuide/Ecosystem Integration/Grafana.md |  164 --
 .../UserGuide/Ecosystem Integration/Hive TsFile.md |  174 --
 .../Ecosystem Integration/MapReduce TsFile.md      |  203 --
 .../UserGuide/Ecosystem Integration/Spark IoTDB.md |  170 --
 .../Ecosystem Integration/Spark TsFile.md          |  327 ---
 .../Ecosystem Integration/Writing Data on HDFS.md  |  171 --
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  179 --
 .../zh/UserGuide/FAQ/Frequently-asked-questions.md |  154 -
 .../UserGuide/IoTDB-Introduction/Architecture.md   |   38 -
 docs/zh/UserGuide/IoTDB-Introduction/Features.md   |   50 -
 .../zh/UserGuide/IoTDB-Introduction/Publication.md |   38 -
 docs/zh/UserGuide/IoTDB-Introduction/Scenario.md   |   76 -
 .../UserGuide/IoTDB-Introduction/What-is-IoTDB.md  |   24 -
 .../DDL-Data-Definition-Language.md                |  550 ----
 .../DML-Data-Manipulation-Language.md              | 1507 ----------
 .../IoTDB-SQL-Language/Maintenance-Command.md      |  101 -
 docs/zh/UserGuide/QuickStart/Files.md              |   61 -
 docs/zh/UserGuide/QuickStart/QuickStart.md         |  271 --
 docs/zh/UserGuide/QuickStart/ServerFileList.md     |  150 -
 docs/zh/UserGuide/QuickStart/WayToGetIoTDB.md      |  157 -
 docs/zh/UserGuide/System-Tools/CSV-Tool.md         |  144 -
 docs/zh/UserGuide/System-Tools/JMX-Tool.md         |   59 -
 .../UserGuide/System-Tools/Load-External-Tsfile.md |   79 -
 docs/zh/UserGuide/System-Tools/MLogParser-Tool.md  |   38 -
 .../System-Tools/Monitor-and-Log-Tools.md          |  286 --
 docs/zh/UserGuide/System-Tools/NodeTool.md         |  294 --
 .../System-Tools/Performance-Tracing-Tool.md       |   63 -
 .../Query-History-Visualization-Tool.md            |   30 -
 docs/zh/UserGuide/System-Tools/Watermark-Tool.md   |  196 --
 docs/zh/UserGuide/UDF/Triggers.md                  |  100 -
 docs/zh/UserGuide/UDF/UDF-User-Defined-Function.md |  591 ----
 docs/zh/UserGuide/UserGuideReadme.md               |   32 -
 docs/zh/chinese-render-template.latex              |  220 --
 example/client-cpp-example/README.md               |   48 -
 example/client-cpp-example/pom.xml                 |  183 --
 example/client-cpp-example/src/SessionExample.cpp  |  308 --
 example/flink/README.md                            |   40 -
 example/flink/pom.xml                              |   83 -
 .../org/apache/iotdb/flink/FlinkIoTDBSink.java     |   94 -
 .../org/apache/iotdb/flink/FlinkIoTDBSource.java   |   94 -
 .../apache/iotdb/flink/FlinkTsFileBatchSink.java   |  123 -
 .../apache/iotdb/flink/FlinkTsFileBatchSource.java |   76 -
 .../apache/iotdb/flink/FlinkTsFileStreamSink.java  |  124 -
 .../iotdb/flink/FlinkTsFileStreamSource.java       |   79 -
 .../java/org/apache/iotdb/flink/TsFileUtils.java   |  107 -
 example/hadoop/pom.xml                             |   39 -
 .../org/apache/iotdb/hadoop/tsfile/Constant.java   |   32 -
 .../iotdb/hadoop/tsfile/TSFMRReadExample.java      |  129 -
 .../iotdb/hadoop/tsfile/TSMRWriteExample.java      |  183 --
 .../apache/iotdb/hadoop/tsfile/TsFileHelper.java   |  141 -
 .../iotdb/hadoop/tsfile/TsFileWriteToHDFS.java     |   78 -
 example/jdbc/pom.xml                               |   43 -
 .../main/java/org/apache/iotdb/JDBCExample.java    |  107 -
 .../org/apache/iotdb/PrepareStatementDemo.java     |   79 -
 example/kafka/pom.xml                              |   49 -
 example/kafka/readme.md                            |   75 -
 .../main/java/org/apache/iotdb/kafka/Constant.java |   63 -
 .../java/org/apache/iotdb/kafka/KafkaConsumer.java |   90 -
 .../apache/iotdb/kafka/KafkaConsumerThread.java    |  104 -
 .../java/org/apache/iotdb/kafka/KafkaProducer.java |   64 -
 example/mqtt/README.md                             |   33 -
 example/mqtt/pom.xml                               |   39 -
 .../java/org/apache/iotdb/mqtt/MQTTClient.java     |   53 -
 example/pom.xml                                    |   91 -
 example/pulsar/pom.xml                             |   45 -
 .../java/org/apache/iotdb/pulsar/Constant.java     |   30 -
 .../org/apache/iotdb/pulsar/PulsarConsumer.java    |  113 -
 .../apache/iotdb/pulsar/PulsarConsumerThread.java  |   72 -
 .../org/apache/iotdb/pulsar/PulsarProducer.java    |   86 -
 example/rocketmq/pom.xml                           |   50 -
 example/rocketmq/readme.md                         |   83 -
 .../java/org/apache/iotdb/rocketmq/Constant.java   |   67 -
 .../apache/iotdb/rocketmq/RocketMQConsumer.java    |  206 --
 .../apache/iotdb/rocketmq/RocketMQProducer.java    |  100 -
 .../main/java/org/apache/iotdb/rocketmq/Utils.java |   38 -
 example/session/pom.xml                            |   43 -
 .../org/apache/iotdb/DataMigrationExample.java     |  186 --
 .../main/java/org/apache/iotdb/SessionExample.java |  630 -----
 .../java/org/apache/iotdb/SessionPoolExample.java  |  121 -
 .../src/main/java/org/apache/iotdb/Write.java      |   44 -
 example/tsfile/pom.xml                             |   39 -
 example/tsfile/readme.md                           |   84 -
 .../java/org/apache/iotdb/tsfile/Constant.java     |   31 -
 .../iotdb/tsfile/TsFileForceAppendWrite.java       |  115 -
 .../java/org/apache/iotdb/tsfile/TsFileRead.java   |   96 -
 .../apache/iotdb/tsfile/TsFileSequenceRead.java    |  142 -
 .../iotdb/tsfile/TsFileWriteWithTSRecord.java      |   81 -
 .../apache/iotdb/tsfile/TsFileWriteWithTablet.java |  107 -
 .../apache/iotdb/tsfile/tlsm_compaction.properties |  681 -----
 .../org/apache/iotdb/tsfile/tlsm_write.properties  |  681 -----
 example/udf/pom.xml                                |  124 -
 .../java/org/apache/iotdb/udf/UDTFExample.java     |   57 -
 flink-iotdb-connector/README.md                    |   58 -
 flink-iotdb-connector/pom.xml                      |   55 -
 .../iotdb/flink/DefaultIoTSerializationSchema.java |  128 -
 .../main/java/org/apache/iotdb/flink/Event.java    |   70 -
 .../java/org/apache/iotdb/flink/IoTDBSink.java     |  229 --
 .../java/org/apache/iotdb/flink/IoTDBSource.java   |  100 -
 .../apache/iotdb/flink/IoTSerializationSchema.java |   32 -
 .../apache/iotdb/flink/options/IoTDBOptions.java   |   70 -
 .../iotdb/flink/options/IoTDBSinkOptions.java      |  117 -
 .../iotdb/flink/options/IoTDBSourceOptions.java    |   51 -
 .../flink/DefaultIoTSerializationSchemaTest.java   |   54 -
 .../iotdb/flink/IoTDBSinkBatchInsertTest.java      |  116 -
 .../iotdb/flink/IoTDBSinkBatchTimerTest.java       |   82 -
 .../apache/iotdb/flink/IoTDBSinkInsertTest.java    |   72 -
 flink-tsfile-connector/README.md                   |  177 --
 flink-tsfile-connector/pom.xml                     |   84 -
 .../apache/iotdb/flink/tsfile/RowRecordParser.java |   47 -
 .../iotdb/flink/tsfile/RowRowRecordParser.java     |  122 -
 .../iotdb/flink/tsfile/RowTSRecordConverter.java   |  167 --
 .../iotdb/flink/tsfile/TSRecordConverter.java      |   62 -
 .../iotdb/flink/tsfile/TSRecordOutputFormat.java   |   99 -
 .../iotdb/flink/tsfile/TsFileInputFormat.java      |  173 --
 .../iotdb/flink/tsfile/TsFileOutputFormat.java     |  136 -
 .../iotdb/flink/tsfile/util/TSFileConfigUtil.java  |   64 -
 .../tsfile/RowTSRecordOutputFormatITCase.java      |   54 -
 .../flink/tsfile/RowTSRecordOutputFormatTest.java  |   75 -
 .../flink/tsfile/RowTsFileConnectorTestBase.java   |   77 -
 .../flink/tsfile/RowTsFileInputFormatITCase.java   |  108 -
 .../flink/tsfile/RowTsFileInputFormatTest.java     |   89 -
 .../flink/tsfile/RowTsFileInputFormatTestBase.java |   49 -
 .../tsfile/RowTsFileOutputFormatTestBase.java      |  120 -
 .../util/TSFileConfigUtilCompletenessTest.java     |   88 -
 .../apache/iotdb/flink/util/TsFileWriteUtil.java   |  233 --
 grafana/img/add_data_source.png                    |  Bin 108927 -> 0 bytes
 grafana/img/add_graph.png                          |  Bin 364163 -> 0 bytes
 grafana/img/edit_data_source.png                   |  Bin 177869 -> 0 bytes
 grafana/pom.xml                                    |  258 --
 grafana/readme.md                                  |  175 --
 grafana/readme_zh.md                               |  172 --
 .../web/grafana/TsfileWebDemoApplication.java      |   30 -
 .../apache/iotdb/web/grafana/bean/TimeValues.java  |   47 -
 .../iotdb/web/grafana/conf/MyConfiguration.java    |   41 -
 .../controller/DatabaseConnectController.java      |  227 --
 .../org/apache/iotdb/web/grafana/dao/BasicDao.java |   33 -
 .../iotdb/web/grafana/dao/impl/BasicDaoImpl.java   |  212 --
 .../grafana/service/DatabaseConnectService.java    |   34 -
 .../service/impl/DatabaseConnectServiceImpl.java   |   51 -
 grafana/src/main/resources/application.properties  |   39 -
 .../web/grafana/dao/impl/BasicDaoImplTest.java     |   52 -
 hadoop/README.md                                   |  212 --
 hadoop/pom.xml                                     |  185 --
 .../iotdb/hadoop/fileSystem/HDFSConfUtil.java      |  105 -
 .../apache/iotdb/hadoop/fileSystem/HDFSFile.java   |  435 ---
 .../apache/iotdb/hadoop/fileSystem/HDFSInput.java  |  142 -
 .../apache/iotdb/hadoop/fileSystem/HDFSOutput.java |  104 -
 .../org/apache/iotdb/hadoop/tsfile/IReaderSet.java |   38 -
 .../iotdb/hadoop/tsfile/TSFHadoopException.java    |   45 -
 .../apache/iotdb/hadoop/tsfile/TSFInputFormat.java |  289 --
 .../apache/iotdb/hadoop/tsfile/TSFInputSplit.java  |   39 -
 .../iotdb/hadoop/tsfile/TSFOutputFormat.java       |   58 -
 .../iotdb/hadoop/tsfile/TSFRecordReader.java       |  258 --
 .../iotdb/hadoop/tsfile/TSFRecordWriter.java       |   62 -
 .../iotdb/hadoop/tsfile/record/HDFSTSRecord.java   |  197 --
 .../apache/iotdb/hadoop/tsfile/TSFHadoopTest.java  |  190 --
 .../iotdb/hadoop/tsfile/TSFInputSplitTest.java     |   70 -
 .../iotdb/hadoop/tsfile/TsFileTestHelper.java      |  122 -
 .../iotdb/hadoop/tsfile/constant/TestConstant.java |   28 -
 hadoop/src/test/resources/logback.xml              |   41 -
 hive-connector/pom.xml                             |  215 --
 .../org/apache/iotdb/hive/TSFHiveInputFormat.java  |   52 -
 .../org/apache/iotdb/hive/TSFHiveOutputFormat.java |   75 -
 .../org/apache/iotdb/hive/TSFHiveRecordReader.java |  158 --
 .../org/apache/iotdb/hive/TSFHiveRecordWriter.java |   71 -
 .../org/apache/iotdb/hive/TsFileDeserializer.java  |  151 -
 .../java/org/apache/iotdb/hive/TsFileSerDe.java    |  173 --
 .../apache/iotdb/hive/TsFileSerDeException.java    |   40 -
 .../apache/iotdb/hive/TSFHiveInputFormatTest.java  |   88 -
 .../apache/iotdb/hive/TSFHiveRecordReaderTest.java |  135 -
 .../apache/iotdb/hive/TsFileDeserializerTest.java  |  119 -
 .../org/apache/iotdb/hive/TsFileSerDeTest.java     |  142 -
 .../org/apache/iotdb/hive/TsFileTestHelper.java    |  127 -
 .../apache/iotdb/hive/constant/TestConstant.java   |   28 -
 hive-connector/src/test/resources/logback.xml      |   39 -
 java-google-style.xml                              |  618 ----
 jdbc/README.md                                     |  272 --
 jdbc/osgi.bnd                                      |   31 -
 jdbc/pom.xml                                       |  266 --
 jdbc/src/main/feature/feature.xml                  |   36 -
 .../iotdb/jdbc/AbstractIoTDBJDBCResultSet.java     | 1126 --------
 .../main/java/org/apache/iotdb/jdbc/Activator.java |   41 -
 .../main/java/org/apache/iotdb/jdbc/Config.java    |   56 -
 .../main/java/org/apache/iotdb/jdbc/Constant.java  |   28 -
 .../org/apache/iotdb/jdbc/IoTDBConnection.java     |  547 ----
 .../apache/iotdb/jdbc/IoTDBConnectionParams.java   |  102 -
 .../org/apache/iotdb/jdbc/IoTDBDataSource.java     |  138 -
 .../apache/iotdb/jdbc/IoTDBDataSourceFactory.java  |   79 -
 .../apache/iotdb/jdbc/IoTDBDatabaseMetadata.java   | 1034 -------
 .../java/org/apache/iotdb/jdbc/IoTDBDriver.java    |   98 -
 .../org/apache/iotdb/jdbc/IoTDBJDBCResultSet.java  |  119 -
 .../iotdb/jdbc/IoTDBNonAlignJDBCResultSet.java     |  280 --
 .../apache/iotdb/jdbc/IoTDBPreparedStatement.java  |  501 ----
 .../org/apache/iotdb/jdbc/IoTDBResultMetadata.java |  232 --
 .../org/apache/iotdb/jdbc/IoTDBSQLException.java   |   41 -
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |  721 -----
 .../org/apache/iotdb/jdbc/IoTDBURLException.java   |   30 -
 .../src/main/java/org/apache/iotdb/jdbc/Utils.java |   72 -
 .../resources/services/META-INF/java.sql.Driver    |   19 -
 .../test/java/org/apache/iotdb/jdbc/BatchTest.java |  161 --
 .../org/apache/iotdb/jdbc/IoTDBConnectionTest.java |  108 -
 .../apache/iotdb/jdbc/IoTDBJDBCResultSetTest.java  |  405 ---
 .../iotdb/jdbc/IoTDBPreparedStatementTest.java     |  317 ---
 .../apache/iotdb/jdbc/IoTDBResultMetadataTest.java |  172 --
 .../org/apache/iotdb/jdbc/IoTDBStatementTest.java  |  104 -
 .../test/java/org/apache/iotdb/jdbc/UtilsTest.java |  116 -
 jenkins.pom                                        |   67 -
 licenses/CDDL License 1.1                          |   90 -
 licenses/Eclipse Public License 1.0 (EPL-1.0)      |   83 -
 .../Eclipse Public License version 2.0 (EPL-2.0)   |   81 -
 licenses/The 2-Clause BSD License                  |   14 -
 licenses/The 3-Clause BSD License                  |   16 -
 licenses/The MIT License (QOS.ch)                  |   21 -
 licenses/The MIT License (progressbar)             |   21 -
 mvnw.cmd                                           |  159 --
 mvnw.sh                                            |  270 --
 pom.xml                                            | 1368 ---------
 separation_py/SeparationServer.py                  |   31 -
 .../gen-java/SeparationTunningService.java         |  963 -------
 separation_py/gen-py/__init__.py                   |    0
 separation_py/org/__init__.py                      |    0
 separation_py/org/apache/__init__.py               |    0
 separation_py/org/apache/iotdb/__init__.py         |    0
 .../separation_py/SeparationTunningService-remote  |  117 -
 .../separation_py/SeparationTunningService.py      |  246 --
 .../org/apache/iotdb/separation_py/__init__.py     |    1 -
 .../org/apache/iotdb/separation_py/constants.py    |   14 -
 .../org/apache/iotdb/separation_py/hlsm.py         |   70 -
 .../org/apache/iotdb/separation_py/tools.py        |  188 --
 .../org/apache/iotdb/separation_py/ttypes.py       |   18 -
 separation_py/separation.thrift                    |    7 -
 server/file-changelists/TsFileMods-changelist.md   |   39 -
 .../file-changelists/TsFileResource-changelist.md  |   40 -
 server/file-changelists/conf-changelist.md         |  102 -
 server/file-changelists/mlog-changelist.md         |   30 -
 server/file-changelists/role-changelist.md         |   34 -
 .../system.properties-changelist.md                |   39 -
 server/file-changelists/tlog-changelist.md         |   20 -
 server/file-changelists/user-changelist.md         |   34 -
 server/file-changelists/wal-changelist.md          |   30 -
 server/pom.xml                                     |  321 ---
 server/server-changelist.md                        |   53 -
 .../resources/conf/iotdb-engine.properties         |  686 -----
 server/src/assembly/resources/conf/iotdb-env.bat   |  130 -
 server/src/assembly/resources/conf/iotdb-env.sh    |  219 --
 .../resources/conf/iotdb-sync-client.properties    |   35 -
 server/src/assembly/resources/conf/jmx.access      |   22 -
 server/src/assembly/resources/conf/jmx.password    |   22 -
 .../src/assembly/resources/conf/logback-tool.xml   |   22 -
 server/src/assembly/resources/conf/logback.xml     |  282 --
 .../src/assembly/resources/sbin/start-server.bat   |  126 -
 server/src/assembly/resources/sbin/start-server.sh |   82 -
 server/src/assembly/resources/sbin/stop-server.bat |   38 -
 server/src/assembly/resources/sbin/stop-server.sh  |   35 -
 .../assembly/resources/tools/detect-watermark.bat  |   65 -
 .../assembly/resources/tools/detect-watermark.sh   |   46 -
 .../assembly/resources/tools/mlog/mLogParser.bat   |   62 -
 .../assembly/resources/tools/mlog/mLogParser.sh    |   48 -
 .../assembly/resources/tools/start-WalChecker.bat  |  111 -
 .../assembly/resources/tools/start-WalChecker.sh   |   90 -
 .../assembly/resources/tools/start-sync-client.bat |   71 -
 .../assembly/resources/tools/start-sync-client.sh  |   54 -
 .../assembly/resources/tools/stop-sync-client.bat  |   23 -
 .../assembly/resources/tools/stop-sync-client.sh   |   30 -
 .../tools/tsfileToolSet/print-iotdb-data-dir.bat   |   62 -
 .../tools/tsfileToolSet/print-iotdb-data-dir.sh    |   48 -
 .../tsfileToolSet/print-tsfile-resource-files.bat  |   61 -
 .../tsfileToolSet/print-tsfile-resource-files.sh   |   59 -
 .../tools/tsfileToolSet/print-tsfile-sketch.bat    |   62 -
 .../tools/tsfileToolSet/print-tsfile-sketch.sh     |   48 -
 server/src/assembly/server.xml                     |   40 -
 .../org/apache/iotdb/db/auth/AuthException.java    |   37 -
 .../org/apache/iotdb/db/auth/AuthorityChecker.java |  166 --
 .../iotdb/db/auth/authorizer/BasicAuthorizer.java  |  406 ---
 .../iotdb/db/auth/authorizer/IAuthorizer.java      |  261 --
 .../db/auth/authorizer/LocalFileAuthorizer.java    |   44 -
 .../iotdb/db/auth/authorizer/OpenIdAuthorizer.java |  282 --
 .../apache/iotdb/db/auth/entity/PathPrivilege.java |  127 -
 .../apache/iotdb/db/auth/entity/PrivilegeType.java |   61 -
 .../java/org/apache/iotdb/db/auth/entity/Role.java |  143 -
 .../java/org/apache/iotdb/db/auth/entity/User.java |  231 --
 .../iotdb/db/auth/role/BasicRoleManager.java       |  189 --
 .../apache/iotdb/db/auth/role/IRoleAccessor.java   |   64 -
 .../apache/iotdb/db/auth/role/IRoleManager.java    |  101 -
 .../iotdb/db/auth/role/LocalFileRoleAccessor.java  |  191 --
 .../iotdb/db/auth/role/LocalFileRoleManager.java   |   26 -
 .../iotdb/db/auth/user/BasicUserManager.java       |  331 ---
 .../apache/iotdb/db/auth/user/IUserAccessor.java   |   64 -
 .../apache/iotdb/db/auth/user/IUserManager.java    |  150 -
 .../iotdb/db/auth/user/LocalFileUserAccessor.java  |  245 --
 .../iotdb/db/auth/user/LocalFileUserManager.java   |   28 -
 .../org/apache/iotdb/db/concurrent/HashLock.java   |   62 -
 .../IoTDBDefaultThreadExceptionHandler.java        |   33 -
 .../db/concurrent/IoTDBThreadPoolFactory.java      |  145 -
 .../iotdb/db/concurrent/IoTThreadFactory.java      |   58 -
 .../org/apache/iotdb/db/concurrent/ThreadName.java |   57 -
 .../iotdb/db/concurrent/WrappedRunnable.java       |   46 -
 .../java/org/apache/iotdb/db/conf/IoTDBConfig.java | 2180 --------------
 .../org/apache/iotdb/db/conf/IoTDBConfigCheck.java |  547 ----
 .../org/apache/iotdb/db/conf/IoTDBConstant.java    |  154 -
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  | 1210 --------
 .../iotdb/db/conf/ServerConfigConsistent.java      |   34 -
 .../iotdb/db/conf/adapter/CompressionRatio.java    |  190 --
 .../db/conf/directories/DirectoryManager.java      |  192 --
 .../directories/strategy/DirectoryStrategy.java    |   70 -
 .../strategy/MaxDiskUsableSpaceFirstStrategy.java  |   55 -
 .../MinFolderOccupiedSpaceFirstStrategy.java       |   61 -
 .../strategy/RandomOnDiskUsableSpaceStrategy.java  |   65 -
 .../directories/strategy/SequenceStrategy.java     |   63 -
 .../db/cost/statistic/ConcurrentCircularArray.java |   67 -
 .../iotdb/db/cost/statistic/Measurement.java       |  425 ---
 .../iotdb/db/cost/statistic/MeasurementMBean.java  |   60 -
 .../apache/iotdb/db/cost/statistic/Operation.java  |   38 -
 .../org/apache/iotdb/db/engine/StorageEngine.java  |  954 -------
 .../iotdb/db/engine/cache/AccountableString.java   |   64 -
 .../db/engine/cache/CacheHitRatioMonitor.java      |  115 -
 .../engine/cache/CacheHitRatioMonitorMXBean.java   |   42 -
 .../apache/iotdb/db/engine/cache/ChunkCache.java   |  213 --
 .../iotdb/db/engine/cache/LRULinkedHashMap.java    |  138 -
 .../db/engine/cache/TimeSeriesMetadataCache.java   |  333 ---
 .../compaction/CompactionMergeTaskPoolManager.java |  193 --
 .../db/engine/compaction/CompactionStrategy.java   |   42 -
 .../db/engine/compaction/TsFileManagement.java     |  461 ---
 .../level/LevelCompactionTsFileManagement.java     |  869 ------
 ...TraditionalLevelCompactionTsFileManagement.java |  792 ------
 .../no/NoCompactionTsFileManagement.java           |  290 --
 .../compaction/utils/CompactionLogAnalyzer.java    |  112 -
 .../engine/compaction/utils/CompactionLogger.java  |   77 -
 .../utils/CompactionSeparateFileUtils.java         |  250 --
 .../engine/compaction/utils/CompactionUtils.java   |  427 ---
 .../db/engine/fileSystem/SystemFileFactory.java    |   69 -
 .../iotdb/db/engine/flush/CloseFileListener.java   |   28 -
 .../iotdb/db/engine/flush/FlushListener.java       |   46 -
 .../apache/iotdb/db/engine/flush/FlushManager.java |  176 --
 .../iotdb/db/engine/flush/FlushManagerMBean.java   |   31 -
 .../iotdb/db/engine/flush/MemTableFlushTask.java   |  328 ---
 .../iotdb/db/engine/flush/NotifyFlushMemTable.java |   46 -
 .../iotdb/db/engine/flush/TsFileFlushPolicy.java   |   48 -
 .../db/engine/flush/pool/AbstractPoolManager.java  |   91 -
 .../engine/flush/pool/FlushSubTaskPoolManager.java |   74 -
 .../db/engine/flush/pool/FlushTaskPoolManager.java |   76 -
 .../iotdb/db/engine/memtable/AbstractMemTable.java |  359 ---
 .../apache/iotdb/db/engine/memtable/IMemTable.java |  140 -
 .../db/engine/memtable/IWritableMemChunk.java      |   95 -
 .../db/engine/memtable/PrimitiveMemTable.java      |   66 -
 .../iotdb/db/engine/memtable/WritableMemChunk.java |  220 --
 .../iotdb/db/engine/merge/manage/MergeContext.java |   90 -
 .../iotdb/db/engine/merge/manage/MergeFuture.java  |  151 -
 .../iotdb/db/engine/merge/manage/MergeManager.java |  410 ---
 .../db/engine/merge/manage/MergeManagerMBean.java  |   26 -
 .../db/engine/merge/manage/MergeResource.java      |  293 --
 .../db/engine/merge/manage/MergeThreadPool.java    |   54 -
 .../apache/iotdb/db/engine/merge/package-info.java |   25 -
 .../iotdb/db/engine/merge/recover/LogAnalyzer.java |  326 ---
 .../iotdb/db/engine/merge/recover/MergeLogger.java |  131 -
 .../merge/selector/IFileQueryMemMeasurement.java   |   36 -
 .../engine/merge/selector/IMergeFileSelector.java  |   35 -
 .../engine/merge/selector/IMergePathSelector.java  |   31 -
 .../merge/selector/MaxFileMergeFileSelector.java   |  359 ---
 .../merge/selector/MaxSeriesMergeFileSelector.java |  115 -
 .../engine/merge/selector/MergeFileStrategy.java   |   27 -
 .../engine/merge/selector/NaivePathSelector.java   |   55 -
 .../iotdb/db/engine/merge/task/MergeCallback.java  |   40 -
 .../iotdb/db/engine/merge/task/MergeFileTask.java  |  408 ---
 .../db/engine/merge/task/MergeMultiChunkTask.java  |  740 -----
 .../iotdb/db/engine/merge/task/MergeTask.java      |  276 --
 .../db/engine/merge/task/RecoverMergeTask.java     |  300 --
 .../iotdb/db/engine/modification/Deletion.java     |  107 -
 .../iotdb/db/engine/modification/Modification.java |   97 -
 .../db/engine/modification/ModificationFile.java   |  170 --
 .../io/LocalTextModificationAccessor.java          |  200 --
 .../engine/modification/io/ModificationReader.java |   39 -
 .../engine/modification/io/ModificationWriter.java |   45 -
 .../iotdb/db/engine/modification/package-info.java |   21 -
 .../db/engine/querycontext/QueryDataSource.java    |   78 -
 .../db/engine/querycontext/ReadOnlyMemChunk.java   |  158 --
 .../db/engine/storagegroup/StorageGroupInfo.java   |  135 -
 .../engine/storagegroup/StorageGroupProcessor.java | 2989 --------------------
 .../iotdb/db/engine/storagegroup/TsFileLock.java   |  110 -
 .../db/engine/storagegroup/TsFileProcessor.java    | 1209 --------
 .../engine/storagegroup/TsFileProcessorInfo.java   |   52 -
 .../db/engine/storagegroup/TsFileResource.java     |  898 ------
 .../storagegroup/timeindex/DeviceTimeIndex.java    |  307 --
 .../storagegroup/timeindex/FileTimeIndex.java      |  211 --
 .../engine/storagegroup/timeindex/ITimeIndex.java  |  150 -
 .../storagegroup/timeindex/TimeIndexLevel.java     |   52 -
 .../virtualSg/HashVirtualPartitioner.java          |   63 -
 .../storagegroup/virtualSg/VirtualPartitioner.java |   39 -
 .../virtualSg/VirtualStorageGroupManager.java      |  408 ---
 .../iotdb/db/engine/trigger/api/TriggerEvent.java  |   35 -
 .../db/engine/upgrade/UpgradeCheckStatus.java      |   40 -
 .../apache/iotdb/db/engine/upgrade/UpgradeLog.java |   88 -
 .../iotdb/db/engine/upgrade/UpgradeTask.java       |  169 --
 .../version/SimpleFileVersionController.java       |  156 -
 .../engine/version/SysTimeVersionController.java   |   38 -
 .../iotdb/db/engine/version/VersionController.java |   44 -
 .../iotdb/db/exception/BatchProcessException.java  |   39 -
 .../exception/DiskSpaceInsufficientException.java  |   34 -
 .../apache/iotdb/db/exception/IoTDBException.java  |   67 -
 .../db/exception/LoadConfigurationException.java   |   36 -
 .../iotdb/db/exception/LoadEmptyFileException.java |   27 -
 .../iotdb/db/exception/LoadFileException.java      |   33 -
 .../apache/iotdb/db/exception/MergeException.java  |   31 -
 .../db/exception/PartitionViolationException.java  |   27 -
 .../db/exception/QueryIdNotExsitException.java     |   28 -
 .../exception/QueryInBatchStatementException.java  |   33 -
 .../iotdb/db/exception/ShutdownException.java      |   40 -
 .../iotdb/db/exception/StartupException.java       |   40 -
 .../iotdb/db/exception/StorageEngineException.java |   46 -
 .../exception/StorageGroupProcessorException.java  |   34 -
 .../db/exception/SyncConnectionException.java      |   38 -
 .../SyncDeviceOwnerConflictException.java          |   39 -
 .../iotdb/db/exception/SystemCheckException.java   |   33 -
 .../db/exception/TsFileProcessorException.java     |   34 -
 .../db/exception/UDFRegistrationException.java     |   34 -
 .../iotdb/db/exception/WriteProcessException.java  |   47 -
 .../db/exception/WriteProcessRejectException.java  |   34 -
 .../exception/index/DistanceMetricException.java   |   28 -
 .../index/IllegalIndexParamException.java          |   28 -
 .../db/exception/index/IndexManagerException.java  |   34 -
 .../db/exception/index/IndexRuntimeException.java  |   32 -
 .../db/exception/index/QueryIndexException.java    |   29 -
 .../index/UnsupportedIndexTypeException.java       |   32 -
 .../metadata/AliasAlreadyExistException.java       |   35 -
 .../metadata/DataTypeMismatchException.java        |   31 -
 .../exception/metadata/DeleteFailedException.java  |   39 -
 .../metadata/IllegalParameterOfPathException.java  |   30 -
 .../exception/metadata/IllegalPathException.java   |   32 -
 .../db/exception/metadata/MetadataException.java   |   63 -
 .../metadata/PathAlreadyExistException.java        |   35 -
 .../exception/metadata/PathNotExistException.java  |   52 -
 .../metadata/StorageGroupAlreadySetException.java  |   43 -
 .../metadata/StorageGroupNotSetException.java      |   34 -
 .../exception/query/LogicalOperatorException.java  |   54 -
 .../exception/query/LogicalOptimizeException.java  |   45 -
 .../db/exception/query/OutOfTTLException.java      |   40 -
 .../iotdb/db/exception/query/PathException.java    |   38 -
 .../exception/query/PathNumOverLimitException.java |   37 -
 .../db/exception/query/QueryProcessException.java  |   48 -
 .../query/QueryTimeoutRuntimeException.java        |   34 -
 .../query/UnSupportedFillTypeException.java        |   33 -
 .../exception/runtime/FlushRunTimeException.java   |   29 -
 .../db/exception/runtime/RPCServiceException.java  |   32 -
 .../db/exception/runtime/SQLParserException.java   |   35 -
 .../runtime/StorageEngineFailureException.java     |   33 -
 .../iotdb/db/index/common/IndexConstant.java       |   36 -
 .../apache/iotdb/db/index/common/IndexType.java    |   84 -
 .../apache/iotdb/db/index/common/IndexUtils.java   |   35 -
 .../apache/iotdb/db/metadata/MLogTxtWriter.java    |  267 --
 .../org/apache/iotdb/db/metadata/MManager.java     | 1966 -------------
 .../java/org/apache/iotdb/db/metadata/MTree.java   | 1572 ----------
 .../apache/iotdb/db/metadata/MeasurementMeta.java  |   85 -
 .../org/apache/iotdb/db/metadata/MetaUtils.java    |  140 -
 .../org/apache/iotdb/db/metadata/Metadata.java     |  120 -
 .../apache/iotdb/db/metadata/MetadataConstant.java |   46 -
 .../iotdb/db/metadata/MetadataOperationType.java   |   36 -
 .../org/apache/iotdb/db/metadata/PartialPath.java  |  315 ---
 .../org/apache/iotdb/db/metadata/TagLogFile.java   |  169 --
 .../iotdb/db/metadata/logfile/MLogReader.java      |   75 -
 .../iotdb/db/metadata/logfile/MLogTxtReader.java   |   78 -
 .../iotdb/db/metadata/logfile/MLogWriter.java      |  418 ---
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |  306 --
 .../iotdb/db/metadata/mnode/MeasurementMNode.java  |  170 --
 .../iotdb/db/metadata/mnode/StorageGroupMNode.java |   63 -
 .../apache/iotdb/db/metrics/server/JettyUtil.java  |  107 -
 .../iotdb/db/metrics/server/MetricsSystem.java     |   82 -
 .../iotdb/db/metrics/server/QueryServlet.java      |   56 -
 .../iotdb/db/metrics/server/ServerArgument.java    |  324 ---
 .../iotdb/db/metrics/server/SqlArgument.java       |   84 -
 .../apache/iotdb/db/metrics/sink/ConsoleSink.java  |   54 -
 .../iotdb/db/metrics/sink/MetricsServletSink.java  |   53 -
 .../org/apache/iotdb/db/metrics/sink/Sink.java     |   28 -
 .../apache/iotdb/db/metrics/source/JvmSource.java  |   50 -
 .../iotdb/db/metrics/source/MetricsSource.java     |  134 -
 .../org/apache/iotdb/db/metrics/source/Source.java |   24 -
 .../apache/iotdb/db/metrics/ui/MetricsPage.java    |  187 --
 .../apache/iotdb/db/metrics/ui/MetricsWebUI.java   |   68 -
 .../org/apache/iotdb/db/monitor/IStatistic.java    |   54 -
 .../apache/iotdb/db/monitor/MonitorConstants.java  |   47 -
 .../org/apache/iotdb/db/monitor/StatMonitor.java   |  308 --
 .../apache/iotdb/db/monitor/StatMonitorMBean.java  |   38 -
 .../apache/iotdb/db/mqtt/BrokerAuthenticator.java  |   47 -
 .../apache/iotdb/db/mqtt/JSONPayloadFormatter.java |   84 -
 .../java/org/apache/iotdb/db/mqtt/Message.java     |   76 -
 .../apache/iotdb/db/mqtt/PayloadFormatManager.java |   45 -
 .../org/apache/iotdb/db/mqtt/PayloadFormatter.java |   40 -
 .../org/apache/iotdb/db/mqtt/PublishHandler.java   |  128 -
 .../main/java/org/apache/iotdb/db/qp/Planner.java  |  227 --
 .../apache/iotdb/db/qp/constant/SQLConstant.java   |  294 --
 .../apache/iotdb/db/qp/executor/IPlanExecutor.java |  127 -
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  | 1790 ------------
 .../org/apache/iotdb/db/qp/logical/Operator.java   |  156 -
 .../apache/iotdb/db/qp/logical/RootOperator.java   |   30 -
 .../db/qp/logical/crud/BasicFunctionOperator.java  |  170 --
 .../db/qp/logical/crud/BasicOperatorType.java      |  189 --
 .../db/qp/logical/crud/DeleteDataOperator.java     |   49 -
 .../iotdb/db/qp/logical/crud/FilterOperator.java   |  301 --
 .../iotdb/db/qp/logical/crud/FromOperator.java     |   45 -
 .../iotdb/db/qp/logical/crud/FunctionOperator.java |   48 -
 .../iotdb/db/qp/logical/crud/InOperator.java       |  210 --
 .../iotdb/db/qp/logical/crud/InsertOperator.java   |   56 -
 .../iotdb/db/qp/logical/crud/QueryOperator.java    |  253 --
 .../iotdb/db/qp/logical/crud/SFWOperator.java      |   98 -
 .../iotdb/db/qp/logical/crud/SelectOperator.java   |  116 -
 .../db/qp/logical/sys/AlterTimeSeriesOperator.java |  106 -
 .../iotdb/db/qp/logical/sys/AuthorOperator.java    |  225 --
 .../db/qp/logical/sys/ClearCacheOperator.java      |   29 -
 .../iotdb/db/qp/logical/sys/CountOperator.java     |   46 -
 .../db/qp/logical/sys/CreateFunctionOperator.java  |   58 -
 .../db/qp/logical/sys/CreateIndexOperator.java     |   61 -
 .../db/qp/logical/sys/CreateSnapshotOperator.java  |   30 -
 .../qp/logical/sys/CreateTimeSeriesOperator.java   |  108 -
 .../db/qp/logical/sys/CreateTriggerOperator.java   |   82 -
 .../iotdb/db/qp/logical/sys/DataAuthOperator.java  |   43 -
 .../db/qp/logical/sys/DeletePartitionOperator.java |   52 -
 .../qp/logical/sys/DeleteStorageGroupOperator.java |   42 -
 .../qp/logical/sys/DeleteTimeSeriesOperator.java   |   43 -
 .../db/qp/logical/sys/DropFunctionOperator.java    |   40 -
 .../iotdb/db/qp/logical/sys/DropIndexOperator.java |   41 -
 .../db/qp/logical/sys/DropTriggerOperator.java     |   40 -
 .../iotdb/db/qp/logical/sys/FlushOperator.java     |   52 -
 .../iotdb/db/qp/logical/sys/KillQueryOperator.java |   42 -
 .../qp/logical/sys/LoadConfigurationOperator.java  |   43 -
 .../iotdb/db/qp/logical/sys/LoadDataOperator.java  |   46 -
 .../iotdb/db/qp/logical/sys/LoadFilesOperator.java |   51 -
 .../iotdb/db/qp/logical/sys/MergeOperator.java     |   29 -
 .../iotdb/db/qp/logical/sys/MoveFileOperator.java  |   45 -
 .../db/qp/logical/sys/RemoveFileOperator.java      |   39 -
 .../db/qp/logical/sys/SetStorageGroupOperator.java |   40 -
 .../iotdb/db/qp/logical/sys/SetTTLOperator.java    |   51 -
 .../db/qp/logical/sys/ShowChildNodesOperator.java  |   36 -
 .../db/qp/logical/sys/ShowChildPathsOperator.java  |   36 -
 .../db/qp/logical/sys/ShowDevicesOperator.java     |   63 -
 .../db/qp/logical/sys/ShowFunctionsOperator.java   |   37 -
 .../db/qp/logical/sys/ShowMergeStatusOperator.java |   30 -
 .../iotdb/db/qp/logical/sys/ShowOperator.java      |   34 -
 .../qp/logical/sys/ShowStorageGroupOperator.java   |   36 -
 .../iotdb/db/qp/logical/sys/ShowTTLOperator.java   |   40 -
 .../db/qp/logical/sys/ShowTimeSeriesOperator.java  |   88 -
 .../db/qp/logical/sys/ShowTriggersOperator.java    |   39 -
 .../db/qp/logical/sys/StartTriggerOperator.java    |   40 -
 .../db/qp/logical/sys/StopTriggerOperator.java     |   40 -
 .../iotdb/db/qp/logical/sys/TracingOperator.java   |   36 -
 .../org/apache/iotdb/db/qp/physical/BatchPlan.java |   53 -
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |  433 ---
 .../iotdb/db/qp/physical/crud/AggregationPlan.java |  137 -
 .../db/qp/physical/crud/AlignByDevicePlan.java     |  150 -
 .../db/qp/physical/crud/DeletePartitionPlan.java   |   53 -
 .../iotdb/db/qp/physical/crud/DeletePlan.java      |  164 --
 .../iotdb/db/qp/physical/crud/FillQueryPlan.java   |   61 -
 .../db/qp/physical/crud/GroupByTimeFillPlan.java   |   43 -
 .../iotdb/db/qp/physical/crud/GroupByTimePlan.java |   99 -
 .../db/qp/physical/crud/InsertMultiTabletPlan.java |  367 ---
 .../iotdb/db/qp/physical/crud/InsertPlan.java      |  175 --
 .../iotdb/db/qp/physical/crud/InsertRowPlan.java   |  571 ----
 .../physical/crud/InsertRowsOfOneDevicePlan.java   |  197 --
 .../iotdb/db/qp/physical/crud/InsertRowsPlan.java  |  274 --
 .../db/qp/physical/crud/InsertTabletPlan.java      |  604 ----
 .../iotdb/db/qp/physical/crud/LastQueryPlan.java   |   56 -
 .../iotdb/db/qp/physical/crud/QueryIndexPlan.java  |   76 -
 .../iotdb/db/qp/physical/crud/QueryPlan.java       |  139 -
 .../db/qp/physical/crud/RawDataQueryPlan.java      |  109 -
 .../apache/iotdb/db/qp/physical/crud/UDFPlan.java  |   48 -
 .../apache/iotdb/db/qp/physical/crud/UDTFPlan.java |  141 -
 .../db/qp/physical/sys/AlterTimeSeriesPlan.java    |  212 --
 .../iotdb/db/qp/physical/sys/AuthorPlan.java       |  422 ---
 .../iotdb/db/qp/physical/sys/ChangeAliasPlan.java  |  115 -
 .../db/qp/physical/sys/ChangeTagOffsetPlan.java    |  115 -
 .../iotdb/db/qp/physical/sys/ClearCachePlan.java   |   38 -
 .../apache/iotdb/db/qp/physical/sys/CountPlan.java |   53 -
 .../db/qp/physical/sys/CreateFunctionPlan.java     |   58 -
 .../iotdb/db/qp/physical/sys/CreateIndexPlan.java  |  180 --
 .../qp/physical/sys/CreateMultiTimeSeriesPlan.java |  383 ---
 .../db/qp/physical/sys/CreateSnapshotPlan.java     |   39 -
 .../db/qp/physical/sys/CreateTimeSeriesPlan.java   |  311 --
 .../db/qp/physical/sys/CreateTriggerPlan.java      |   77 -
 .../iotdb/db/qp/physical/sys/DataAuthPlan.java     |  100 -
 .../db/qp/physical/sys/DeleteStorageGroupPlan.java |   84 -
 .../db/qp/physical/sys/DeleteTimeSeriesPlan.java   |  106 -
 .../iotdb/db/qp/physical/sys/DropFunctionPlan.java |   46 -
 .../iotdb/db/qp/physical/sys/DropIndexPlan.java    |  129 -
 .../iotdb/db/qp/physical/sys/DropTriggerPlan.java  |   46 -
 .../apache/iotdb/db/qp/physical/sys/FlushPlan.java |  244 --
 .../iotdb/db/qp/physical/sys/KillQueryPlan.java    |   45 -
 .../db/qp/physical/sys/LoadConfigurationPlan.java  |  144 -
 .../iotdb/db/qp/physical/sys/LoadDataPlan.java     |   73 -
 .../apache/iotdb/db/qp/physical/sys/MNodePlan.java |  116 -
 .../db/qp/physical/sys/MeasurementMNodePlan.java   |  153 -
 .../apache/iotdb/db/qp/physical/sys/MergePlan.java |   42 -
 .../iotdb/db/qp/physical/sys/OperateFilePlan.java  |   91 -
 .../db/qp/physical/sys/SetStorageGroupPlan.java    |  100 -
 .../iotdb/db/qp/physical/sys/SetTTLPlan.java       |  102 -
 .../db/qp/physical/sys/ShowChildNodesPlan.java     |   39 -
 .../db/qp/physical/sys/ShowChildPathsPlan.java     |   39 -
 .../iotdb/db/qp/physical/sys/ShowDevicesPlan.java  |   65 -
 .../db/qp/physical/sys/ShowFunctionsPlan.java      |   34 -
 .../db/qp/physical/sys/ShowMergeStatusPlan.java    |   27 -
 .../apache/iotdb/db/qp/physical/sys/ShowPlan.java  |  122 -
 .../qp/physical/sys/ShowQueryProcesslistPlan.java  |   26 -
 .../db/qp/physical/sys/ShowStorageGroupPlan.java   |   36 -
 .../iotdb/db/qp/physical/sys/ShowTTLPlan.java      |   42 -
 .../db/qp/physical/sys/ShowTimeSeriesPlan.java     |  123 -
 .../iotdb/db/qp/physical/sys/ShowTriggersPlan.java |   35 -
 .../iotdb/db/qp/physical/sys/StartTriggerPlan.java |   46 -
 .../iotdb/db/qp/physical/sys/StopTriggerPlan.java  |   46 -
 .../db/qp/physical/sys/StorageGroupMNodePlan.java  |  110 -
 .../iotdb/db/qp/physical/sys/TracingPlan.java      |   45 -
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    | 2142 --------------
 .../iotdb/db/qp/strategy/LogicalGenerator.java     |   70 -
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |  965 -------
 .../apache/iotdb/db/qp/strategy/SQLParseError.java |   40 -
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |  492 ----
 .../qp/strategy/optimizer/DnfFilterOptimizer.java  |  165 --
 .../db/qp/strategy/optimizer/IFilterOptimizer.java |   29 -
 .../qp/strategy/optimizer/ILogicalOptimizer.java   |   31 -
 .../optimizer/MergeSingleFilterOptimizer.java      |  179 --
 .../qp/strategy/optimizer/RemoveNotOptimizer.java  |  102 -
 .../apache/iotdb/db/qp/utils/DatetimeUtils.java    |  625 ----
 .../db/query/aggregation/AggregateResult.java      |  317 ---
 .../db/query/aggregation/AggregationType.java      |  107 -
 .../db/query/aggregation/impl/AvgAggrResult.java   |  202 --
 .../db/query/aggregation/impl/CountAggrResult.java |  119 -
 .../aggregation/impl/FirstValueAggrResult.java     |  151 -
 .../aggregation/impl/FirstValueDescAggrResult.java |   81 -
 .../aggregation/impl/LastValueAggrResult.java      |  132 -
 .../aggregation/impl/LastValueDescAggrResult.java  |  111 -
 .../query/aggregation/impl/MaxTimeAggrResult.java  |  112 -
 .../aggregation/impl/MaxTimeDescAggrResult.java    |   93 -
 .../query/aggregation/impl/MaxValueAggrResult.java |  119 -
 .../query/aggregation/impl/MinTimeAggrResult.java  |  130 -
 .../aggregation/impl/MinTimeDescAggrResult.java    |   69 -
 .../query/aggregation/impl/MinValueAggrResult.java |  117 -
 .../db/query/aggregation/impl/SumAggrResult.java   |  144 -
 .../iotdb/db/query/context/QueryContext.java       |  112 -
 .../iotdb/db/query/control/FileReaderManager.java  |  289 --
 .../iotdb/db/query/control/QueryFileManager.java   |  125 -
 .../db/query/control/QueryResourceManager.java     |  237 --
 .../iotdb/db/query/control/QueryTimeManager.java   |  186 --
 .../iotdb/db/query/control/TracingManager.java     |  234 --
 .../db/query/dataset/AlignByDeviceDataSet.java     |  274 --
 .../db/query/dataset/DirectAlignByTimeDataSet.java |   34 -
 .../db/query/dataset/DirectNonAlignDataSet.java    |   32 -
 .../apache/iotdb/db/query/dataset/ListDataSet.java |   61 -
 .../db/query/dataset/NonAlignEngineDataSet.java    |  353 ---
 .../dataset/RawQueryDataSetWithValueFilter.java    |  217 --
 .../dataset/RawQueryDataSetWithoutValueFilter.java |  507 ----
 .../apache/iotdb/db/query/dataset/ShowDataSet.java |   79 -
 .../iotdb/db/query/dataset/ShowDevicesDataSet.java |   77 -
 .../iotdb/db/query/dataset/ShowDevicesResult.java  |   74 -
 .../apache/iotdb/db/query/dataset/ShowResult.java  |   49 -
 .../db/query/dataset/ShowTimeSeriesResult.java     |  168 --
 .../db/query/dataset/ShowTimeseriesDataSet.java    |  109 -
 .../iotdb/db/query/dataset/SingleDataSet.java      |   52 -
 .../iotdb/db/query/dataset/UDFInputDataSet.java    |   34 -
 .../db/query/dataset/UDTFAlignByTimeDataSet.java   |  303 --
 .../apache/iotdb/db/query/dataset/UDTFDataSet.java |  177 --
 .../db/query/dataset/UDTFNonAlignDataSet.java      |  216 --
 .../dataset/groupby/GroupByEngineDataSet.java      |  181 --
 .../db/query/dataset/groupby/GroupByExecutor.java  |   40 -
 .../query/dataset/groupby/GroupByFillDataSet.java  |  220 --
 .../query/dataset/groupby/GroupByTimeDataSet.java  |   97 -
 .../groupby/GroupByWithValueFilterDataSet.java     |  284 --
 .../groupby/GroupByWithoutValueFilterDataSet.java  |  193 --
 .../dataset/groupby/LocalGroupByExecutor.java      |  353 ---
 .../db/query/executor/AggregationExecutor.java     |  514 ----
 .../iotdb/db/query/executor/FillQueryExecutor.java |  131 -
 .../iotdb/db/query/executor/IQueryRouter.java      |   68 -
 .../iotdb/db/query/executor/LastQueryExecutor.java |  290 --
 .../iotdb/db/query/executor/QueryRouter.java       |  304 --
 .../db/query/executor/RawDataQueryExecutor.java    |  221 --
 .../iotdb/db/query/executor/UDTFQueryExecutor.java |  109 -
 .../apache/iotdb/db/query/executor/fill/IFill.java |   73 -
 .../db/query/executor/fill/LastPointReader.java    |  242 --
 .../iotdb/db/query/executor/fill/LinearFill.java   |  234 --
 .../iotdb/db/query/executor/fill/PreviousFill.java |  120 -
 .../db/query/externalsort/ExternalSortJob.java     |   43 -
 .../query/externalsort/ExternalSortJobEngine.java  |   52 -
 .../db/query/externalsort/ExternalSortJobPart.java |   43 -
 .../externalsort/ExternalSortJobScheduler.java     |   40 -
 .../iotdb/db/query/externalsort/LineMerger.java    |   55 -
 .../MultiSourceExternalSortJobPart.java            |   50 -
 .../externalsort/SimpleExternalSortEngine.java     |  178 --
 .../SingleSourceExternalSortJobPart.java           |   39 -
 .../adapter/ByTimestampReaderAdapter.java          |   73 -
 .../serialize/IExternalSortFileDeserializer.java   |   32 -
 .../serialize/IExternalSortFileSerializer.java     |   30 -
 .../FixLengthIExternalSortFileDeserializer.java    |  267 --
 .../impl/FixLengthTimeValuePairSerializer.java     |  169 --
 .../db/query/factory/AggregateResultFactory.java   |  143 -
 .../apache/iotdb/db/query/filter/TsFileFilter.java |   31 -
 .../iotdb/db/query/pool/QueryTaskPoolManager.java  |   78 -
 .../db/query/reader/chunk/ChunkDataIterator.java   |   79 -
 .../db/query/reader/chunk/ChunkReaderWrap.java     |   96 -
 .../db/query/reader/chunk/DiskChunkLoader.java     |   49 -
 .../reader/chunk/DiskChunkReaderByTimestamp.java   |   82 -
 .../db/query/reader/chunk/MemChunkLoader.java      |   49 -
 .../db/query/reader/chunk/MemChunkReader.java      |  106 -
 .../iotdb/db/query/reader/chunk/MemPageReader.java |   79 -
 .../chunk/metadata/DiskChunkMetadataLoader.java    |  122 -
 .../chunk/metadata/MemChunkMetadataLoader.java     |   76 -
 .../resource/CachedUnseqResourceMergeReader.java   |   42 -
 .../reader/series/BaseManagedSeriesReader.java     |   45 -
 .../db/query/reader/series/IAggregateReader.java   |   57 -
 .../db/query/reader/series/IReaderByTimestamp.java |   47 -
 .../query/reader/series/ManagedSeriesReader.java   |   37 -
 .../query/reader/series/SeriesAggregateReader.java |  147 -
 .../reader/series/SeriesRawDataBatchReader.java    |  195 --
 .../reader/series/SeriesRawDataPointReader.java    |   87 -
 .../iotdb/db/query/reader/series/SeriesReader.java | 1200 --------
 .../reader/series/SeriesReaderByTimestamp.java     |  169 --
 .../universal/CachedPriorityMergeReader.java       |   96 -
 .../reader/universal/DescPriorityMergeReader.java  |   55 -
 .../iotdb/db/query/reader/universal/Element.java   |   72 -
 .../reader/universal/PriorityMergeReader.java      |  180 --
 .../query/timegenerator/ServerTimeGenerator.java   |  149 -
 .../org/apache/iotdb/db/query/udf/api/UDF.java     |   40 -
 .../org/apache/iotdb/db/query/udf/api/UDTF.java    |  120 -
 .../apache/iotdb/db/query/udf/api/access/Row.java  |  128 -
 .../iotdb/db/query/udf/api/access/RowIterator.java |   47 -
 .../iotdb/db/query/udf/api/access/RowWindow.java   |   62 -
 .../db/query/udf/api/collector/PointCollector.java |  138 -
 .../api/customizer/config/UDFConfigurations.java   |   38 -
 .../api/customizer/config/UDTFConfigurations.java  |  106 -
 .../parameter/UDFParameterValidator.java           |  211 --
 .../api/customizer/parameter/UDFParameters.java    |  153 -
 .../api/customizer/strategy/AccessStrategy.java    |   58 -
 .../strategy/RowByRowAccessStrategy.java           |   61 -
 .../strategy/SlidingSizeWindowAccessStrategy.java  |  124 -
 .../strategy/SlidingTimeWindowAccessStrategy.java  |  261 --
 .../UDFAttributeNotProvidedException.java          |   27 -
 .../db/query/udf/api/exception/UDFException.java   |   31 -
 .../UDFInputSeriesDataTypeNotValidException.java   |   43 -
 .../UDFInputSeriesIndexNotValidException.java      |   30 -
 .../UDFInputSeriesNumberNotValidException.java     |   38 -
 .../exception/UDFParameterNotValidException.java   |   27 -
 .../db/query/udf/builtin/BuiltinFunction.java      |   73 -
 .../apache/iotdb/db/query/udf/builtin/UDTFAbs.java |   70 -
 .../iotdb/db/query/udf/builtin/UDTFAcos.java       |   28 -
 .../iotdb/db/query/udf/builtin/UDTFAsin.java       |   28 -
 .../iotdb/db/query/udf/builtin/UDTFAtan.java       |   28 -
 .../iotdb/db/query/udf/builtin/UDTFBottomK.java    |  115 -
 .../iotdb/db/query/udf/builtin/UDTFCeil.java       |   28 -
 .../db/query/udf/builtin/UDTFCommonDerivative.java |   64 -
 .../udf/builtin/UDTFCommonValueDifference.java     |   62 -
 .../iotdb/db/query/udf/builtin/UDTFContains.java   |   56 -
 .../apache/iotdb/db/query/udf/builtin/UDTFCos.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFDegrees.java    |   28 -
 .../iotdb/db/query/udf/builtin/UDTFDerivative.java |   58 -
 .../apache/iotdb/db/query/udf/builtin/UDTFExp.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFFloor.java      |   28 -
 .../apache/iotdb/db/query/udf/builtin/UDTFLog.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFLog10.java      |   28 -
 .../iotdb/db/query/udf/builtin/UDTFMatches.java    |   58 -
 .../iotdb/db/query/udf/builtin/UDTFMath.java       |   90 -
 .../udf/builtin/UDTFNonNegativeDerivative.java     |   64 -
 .../builtin/UDTFNonNegativeValueDifference.java    |   62 -
 .../iotdb/db/query/udf/builtin/UDTFRadians.java    |   28 -
 .../iotdb/db/query/udf/builtin/UDTFRound.java      |   28 -
 .../iotdb/db/query/udf/builtin/UDTFSelectK.java    |  176 --
 .../iotdb/db/query/udf/builtin/UDTFSign.java       |   28 -
 .../apache/iotdb/db/query/udf/builtin/UDTFSin.java |   28 -
 .../iotdb/db/query/udf/builtin/UDTFSqrt.java       |   28 -
 .../apache/iotdb/db/query/udf/builtin/UDTFTan.java |   28 -
 .../db/query/udf/builtin/UDTFTimeDifference.java   |   57 -
 .../iotdb/db/query/udf/builtin/UDTFTopK.java       |  111 -
 .../db/query/udf/builtin/UDTFValueDifference.java  |   52 -
 .../iotdb/db/query/udf/builtin/UDTFValueTrend.java |   74 -
 .../iotdb/db/query/udf/core/access/RowImpl.java    |   97 -
 .../db/query/udf/core/access/RowIteratorImpl.java  |   62 -
 .../db/query/udf/core/access/RowWindowImpl.java    |   80 -
 .../db/query/udf/core/context/UDFContext.java      |  142 -
 .../db/query/udf/core/executor/UDTFExecutor.java   |  117 -
 .../iotdb/db/query/udf/core/input/InputLayer.java  |  571 ----
 .../iotdb/db/query/udf/core/input/SafetyLine.java  |   77 -
 .../db/query/udf/core/reader/LayerPointReader.java |   49 -
 .../db/query/udf/core/reader/LayerRowReader.java   |   39 -
 .../udf/core/reader/LayerRowWindowReader.java      |   37 -
 .../core/transformer/RawQueryPointTransformer.java |   73 -
 .../db/query/udf/core/transformer/Transformer.java |   94 -
 .../core/transformer/UDFQueryRowTransformer.java   |   46 -
 .../transformer/UDFQueryRowWindowTransformer.java  |   47 -
 .../udf/core/transformer/UDFQueryTransformer.java  |  102 -
 .../iotdb/db/query/udf/datastructure/Cache.java    |   96 -
 .../query/udf/datastructure/SerializableList.java  |  166 --
 .../primitive/ElasticSerializableIntList.java      |   99 -
 .../query/udf/datastructure/primitive/IntList.java |   33 -
 .../primitive/SerializableIntList.java             |  133 -
 .../datastructure/primitive/WrappedIntArray.java   |   51 -
 .../row/ElasticSerializableRowRecordList.java      |  261 --
 .../row/SerializableRowRecordList.java             |  237 --
 .../tv/ElasticSerializableBinaryTVList.java        |  132 -
 .../tv/ElasticSerializableTVList.java              |  319 ---
 .../datastructure/tv/SerializableBinaryTVList.java |   82 -
 .../tv/SerializableBooleanTVList.java              |   72 -
 .../datastructure/tv/SerializableDoubleTVList.java |   72 -
 .../datastructure/tv/SerializableFloatTVList.java  |   72 -
 .../datastructure/tv/SerializableIntTVList.java    |   72 -
 .../datastructure/tv/SerializableLongTVList.java   |   72 -
 .../udf/datastructure/tv/SerializableTVList.java   |  100 -
 .../udf/service/TemporaryQueryDataFileService.java |  141 -
 .../iotdb/db/query/udf/service/UDFClassLoader.java |   85 -
 .../query/udf/service/UDFClassLoaderManager.java   |  125 -
 .../iotdb/db/query/udf/service/UDFLogWriter.java   |   70 -
 .../udf/service/UDFRegistrationInformation.java    |   82 -
 .../query/udf/service/UDFRegistrationService.java  |  431 ---
 .../apache/iotdb/db/rescon/CachedStringPool.java   |   42 -
 .../apache/iotdb/db/rescon/MemTableManager.java    |  111 -
 .../iotdb/db/rescon/PrimitiveArrayManager.java     |  312 --
 .../org/apache/iotdb/db/rescon/SystemInfo.java     |  254 --
 .../apache/iotdb/db/rescon/TVListAllocator.java    |   94 -
 .../iotdb/db/rescon/TVListAllocatorMBean.java      |   24 -
 .../org/apache/iotdb/db/rescon/package-info.java   |   24 -
 .../iotdb/db/separation/statistics/Collector.java  |   14 -
 .../statistics/SeparationTuningClient.java         |   86 -
 .../statistics/SeparationTunningService.java       | 1105 --------
 .../java/org/apache/iotdb/db/service/IService.java |   49 -
 .../java/org/apache/iotdb/db/service/IoTDB.java    |  207 --
 .../org/apache/iotdb/db/service/IoTDBMBean.java    |   27 -
 .../apache/iotdb/db/service/IoTDBShutdownHook.java |   39 -
 .../org/apache/iotdb/db/service/JMXService.java    |  101 -
 .../org/apache/iotdb/db/service/MQTTService.java   |  115 -
 .../apache/iotdb/db/service/MetricsService.java    |  207 --
 .../iotdb/db/service/MetricsServiceMBean.java      |   32 -
 .../org/apache/iotdb/db/service/RPCService.java    |  103 -
 .../apache/iotdb/db/service/RPCServiceMBean.java   |   34 -
 .../iotdb/db/service/RPCServiceThriftHandler.java  |   52 -
 .../apache/iotdb/db/service/RegisterManager.java   |   85 -
 .../org/apache/iotdb/db/service/ServiceType.java   |   74 -
 .../org/apache/iotdb/db/service/StartupCheck.java  |   28 -
 .../org/apache/iotdb/db/service/StartupChecks.java |   78 -
 .../org/apache/iotdb/db/service/StaticResps.java   |   59 -
 .../org/apache/iotdb/db/service/TSServiceImpl.java | 2021 -------------
 .../org/apache/iotdb/db/service/UpgradeSevice.java |  119 -
 .../iotdb/db/service/thrift/ThriftService.java     |  163 --
 .../db/service/thrift/ThriftServiceThread.java     |  180 --
 .../apache/iotdb/db/sync/conf/SyncConstant.java    |   81 -
 .../iotdb/db/sync/conf/SyncSenderConfig.java       |  127 -
 .../iotdb/db/sync/conf/SyncSenderDescriptor.java   |  124 -
 .../org/apache/iotdb/db/sync/package-info.java     |   38 -
 .../iotdb/db/sync/receiver/SyncServerManager.java  |  123 -
 .../db/sync/receiver/SyncServerManagerMBean.java   |   34 -
 .../db/sync/receiver/SyncServerThriftHandler.java  |   56 -
 .../iotdb/db/sync/receiver/load/FileLoader.java    |  203 --
 .../db/sync/receiver/load/FileLoaderManager.java   |  213 --
 .../iotdb/db/sync/receiver/load/IFileLoader.java   |   50 -
 .../iotdb/db/sync/receiver/load/ILoadLogger.java   |   57 -
 .../iotdb/db/sync/receiver/load/LoadLogger.java    |   72 -
 .../iotdb/db/sync/receiver/load/LoadType.java      |   25 -
 .../receiver/recover/ISyncReceiverLogAnalyzer.java |   33 -
 .../sync/receiver/recover/ISyncReceiverLogger.java |   50 -
 .../receiver/recover/SyncReceiverLogAnalyzer.java  |  154 -
 .../sync/receiver/recover/SyncReceiverLogger.java  |   72 -
 .../db/sync/receiver/transfer/SyncServiceImpl.java |  357 ---
 .../db/sync/sender/manage/ISyncFileManager.java    |   72 -
 .../db/sync/sender/manage/SyncFileManager.java     |  291 --
 .../sender/recover/ISyncSenderLogAnalyzer.java     |   47 -
 .../db/sync/sender/recover/ISyncSenderLogger.java  |   67 -
 .../sync/sender/recover/SyncSenderLogAnalyzer.java |  128 -
 .../db/sync/sender/recover/SyncSenderLogger.java   |   72 -
 .../iotdb/db/sync/sender/transfer/ISyncClient.java |   95 -
 .../iotdb/db/sync/sender/transfer/SyncClient.java  |  752 -----
 .../apache/iotdb/db/tools/IoTDBDataDirViewer.java  |  164 --
 .../iotdb/db/tools/TsFileResourcePrinter.java      |   87 -
 .../apache/iotdb/db/tools/TsFileRewriteTool.java   |  481 ----
 .../apache/iotdb/db/tools/TsFileSketchTool.java    |  247 --
 .../java/org/apache/iotdb/db/tools/WalChecker.java |  134 -
 .../org/apache/iotdb/db/tools/mlog/MLogParser.java |  207 --
 .../db/tools/upgrade/TsFileOnlineUpgradeTool.java  |  290 --
 .../db/tools/virtualsg/DeviceMappingViewer.java    |   63 -
 .../watermark/GroupedLSBWatermarkEncoder.java      |  150 -
 .../db/tools/watermark/WatermarkDetector.java      |  226 --
 .../iotdb/db/tools/watermark/WatermarkEncoder.java |   36 -
 .../java/org/apache/iotdb/db/utils/AuthUtils.java  |  319 ---
 .../org/apache/iotdb/db/utils/CommonUtils.java     |  212 --
 .../iotdb/db/utils/CopyOnReadLinkedList.java       |   72 -
 .../iotdb/db/utils/EncodingInferenceUtils.java     |   54 -
 .../org/apache/iotdb/db/utils/FileLoaderUtils.java |  184 --
 .../org/apache/iotdb/db/utils/FilePathUtils.java   |  259 --
 .../java/org/apache/iotdb/db/utils/FileUtils.java  |   49 -
 .../java/org/apache/iotdb/db/utils/IOUtils.java    |  182 --
 .../java/org/apache/iotdb/db/utils/MathUtils.java  |   80 -
 .../java/org/apache/iotdb/db/utils/MemUtils.java   |  187 --
 .../java/org/apache/iotdb/db/utils/MergeUtils.java |  301 --
 .../java/org/apache/iotdb/db/utils/MmapUtil.java   |   35 -
 .../org/apache/iotdb/db/utils/OpenFileNumUtil.java |  290 --
 .../apache/iotdb/db/utils/QueryDataSetUtils.java   |  258 --
 .../java/org/apache/iotdb/db/utils/QueryUtils.java |  107 -
 .../apache/iotdb/db/utils/RandomDeleteCache.java   |   76 -
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |  244 --
 .../org/apache/iotdb/db/utils/SerializeUtils.java  |  561 ----
 .../org/apache/iotdb/db/utils/StatusUtils.java     |   46 -
 .../java/org/apache/iotdb/db/utils/SyncUtils.java  |  109 -
 .../java/org/apache/iotdb/db/utils/TestOnly.java   |   34 -
 .../apache/iotdb/db/utils/TimeValuePairUtils.java  |  110 -
 .../apache/iotdb/db/utils/TypeInferenceUtils.java  |  103 -
 .../org/apache/iotdb/db/utils/UpgradeUtils.java    |  165 --
 .../iotdb/db/utils/datastructure/BinaryTVList.java |  230 --
 .../db/utils/datastructure/BooleanTVList.java      |  230 --
 .../iotdb/db/utils/datastructure/DoubleTVList.java |  234 --
 .../iotdb/db/utils/datastructure/FloatTVList.java  |  234 --
 .../iotdb/db/utils/datastructure/IntTVList.java    |  228 --
 .../iotdb/db/utils/datastructure/LongTVList.java   |  228 --
 .../iotdb/db/utils/datastructure/TVList.java       |  574 ----
 .../iotdb/db/utils/datastructure/TimeSelector.java |  155 -
 .../apache/iotdb/db/writelog/WALFlushListener.java |   50 -
 .../iotdb/db/writelog/io/BatchLogReader.java       |   83 -
 .../apache/iotdb/db/writelog/io/ILogReader.java    |   50 -
 .../apache/iotdb/db/writelog/io/ILogWriter.java    |   50 -
 .../org/apache/iotdb/db/writelog/io/LogWriter.java |  133 -
 .../iotdb/db/writelog/io/MultiFileLogReader.java   |   76 -
 .../iotdb/db/writelog/io/SingleFileLogReader.java  |  142 -
 .../writelog/manager/MultiFileLogNodeManager.java  |  165 --
 .../db/writelog/manager/WriteLogNodeManager.java   |   49 -
 .../db/writelog/node/ExclusiveWriteLogNode.java    |  377 ---
 .../iotdb/db/writelog/node/WriteLogNode.java       |   86 -
 .../iotdb/db/writelog/recover/LogReplayer.java     |  206 --
 .../writelog/recover/TsFileRecoverPerformer.java   |  242 --
 .../org.apache.iotdb.db.mqtt.PayloadFormatter      |   20 -
 .../src/main/resources/iotdb/ui/static/index.html  |   79 -
 .../main/resources/iotdb/ui/static/iotdb-logo.png  |  Bin 1187 -> 0 bytes
 .../src/main/resources/iotdb/ui/static/webui.css   |  194 --
 .../apache/iotdb/db/auth/AuthorityCheckerTest.java |  236 --
 .../auth/authorizer/LocalFileAuthorizerTest.java   |  333 ---
 .../db/auth/authorizer/OpenIdAuthorizerTest.java   |   97 -
 .../iotdb/db/auth/entity/PathPrivilegeTest.java    |   41 -
 .../org/apache/iotdb/db/auth/entity/RoleTest.java  |   41 -
 .../org/apache/iotdb/db/auth/entity/UserTest.java  |   43 -
 .../db/auth/role/LocalFileRoleAccessorTest.java    |   95 -
 .../db/auth/role/LocalFileRoleManagerTest.java     |  148 -
 .../db/auth/user/LocalFileUserAccessorTest.java    |  112 -
 .../db/auth/user/LocalFileUserManagerTest.java     |  202 --
 .../IoTDBDefaultThreadExceptionHandlerTest.java    |   80 -
 .../db/concurrent/IoTDBThreadPoolFactoryTest.java  |  218 --
 .../apache/iotdb/db/conf/IoTDBDescriptorTest.java  |   75 -
 .../db/conf/adapter/CompressionRatioTest.java      |  152 -
 .../strategy/DirectoryStrategyTest.java            |  206 --
 .../org/apache/iotdb/db/constant/TestConstant.java |  106 -
 .../db/cost/statistic/PerformanceStatTest.java     |  105 -
 .../iotdb/db/engine/MetadataManagerHelper.java     |  158 --
 .../db/engine/compaction/CompactionChunkTest.java  |  238 --
 .../compaction/LevelCompactionCacheTest.java       |  127 -
 .../engine/compaction/LevelCompactionLogTest.java  |   87 -
 .../compaction/LevelCompactionMergeTest.java       |  233 --
 .../engine/compaction/LevelCompactionModsTest.java |  135 -
 .../compaction/LevelCompactionMoreDataTest.java    |  239 --
 .../compaction/LevelCompactionRecoverTest.java     |  703 -----
 .../compaction/LevelCompactionSelectorTest.java    |   76 -
 .../db/engine/compaction/LevelCompactionTest.java  |  234 --
 .../LevelCompactionTsFileManagementTest.java       |  228 --
 .../NoCompactionTsFileManagementTest.java          |  235 --
 .../db/engine/memtable/MemTableFlushTaskTest.java  |  103 -
 .../db/engine/memtable/MemTableTestUtils.java      |   65 -
 .../db/engine/memtable/MemtableBenchmark.java      |   64 -
 .../db/engine/memtable/PrimitiveMemTableTest.java  |  244 --
 .../engine/merge/MaxFileMergeFileSelectorTest.java |  239 --
 .../merge/MaxSeriesMergeFileSelectorTest.java      |  108 -
 .../apache/iotdb/db/engine/merge/MergeLogTest.java |   92 -
 .../iotdb/db/engine/merge/MergeManagerTest.java    |  176 --
 .../iotdb/db/engine/merge/MergeOverLapTest.java    |  226 --
 .../iotdb/db/engine/merge/MergePerfTest.java       |  108 -
 .../iotdb/db/engine/merge/MergeTaskTest.java       |  578 ----
 .../apache/iotdb/db/engine/merge/MergeTest.java    |  232 --
 .../iotdb/db/engine/merge/MergeUpgradeTest.java    |  190 --
 .../engine/modification/DeletionFileNodeTest.java  |  351 ---
 .../db/engine/modification/DeletionQueryTest.java  |  346 ---
 .../engine/modification/ModificationFileTest.java  |  103 -
 .../io/LocalTextModificationAccessorTest.java      |   81 -
 .../storagegroup/FileNodeManagerBenchmark.java     |  133 -
 .../storagegroup/StorageGroupProcessorTest.java    |  629 ----
 .../iotdb/db/engine/storagegroup/TTLTest.java      |  435 ---
 .../engine/storagegroup/TsFileProcessorTest.java   |  356 ---
 .../virtualSg/HashVirtualPartitionerTest.java      |   63 -
 .../version/SimpleFileVersionControllerTest.java   |   56 -
 .../version/SysTimeVersionControllerTest.java      |   44 -
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  967 -------
 .../integration/IOTDBGroupByInnerIntervalIT.java   |  341 ---
 .../apache/iotdb/db/integration/IOTDBInsertIT.java |  126 -
 .../iotdb/db/integration/IoTDBAddSubDeviceIT.java  |  248 --
 .../apache/iotdb/db/integration/IoTDBAliasIT.java  |  338 ---
 .../iotdb/db/integration/IoTDBAlignByDeviceIT.java | 1277 ---------
 .../org/apache/iotdb/db/integration/IoTDBAsIT.java |  608 ----
 .../db/integration/IoTDBAutoCreateSchemaIT.java    |  250 --
 .../iotdb/db/integration/IoTDBCheckConfigIT.java   |  161 --
 .../iotdb/db/integration/IoTDBClearCacheIT.java    |  174 --
 .../apache/iotdb/db/integration/IoTDBCloseIT.java  |  197 --
 .../iotdb/db/integration/IoTDBCompleteIT.java      |  487 ----
 .../iotdb/db/integration/IoTDBCompressTypeIT.java  |  109 -
 .../db/integration/IoTDBCreateSnapshotIT.java      |  187 --
 .../db/integration/IoTDBCreateTimeseriesIT.java    |  157 -
 .../apache/iotdb/db/integration/IoTDBDaemonIT.java |  470 ---
 .../db/integration/IoTDBDeleteStorageGroupIT.java  |  169 --
 .../db/integration/IoTDBDeleteTimeseriesIT.java    |  179 --
 .../iotdb/db/integration/IoTDBDeletionIT.java      |  427 ---
 .../iotdb/db/integration/IoTDBDisableAlignIT.java  |  419 ---
 .../iotdb/db/integration/IoTDBEncodingIT.java      |  291 --
 .../db/integration/IoTDBEngineTimeGeneratorIT.java |  283 --
 .../iotdb/db/integration/IoTDBExecuteBatchIT.java  |  197 --
 .../iotdb/db/integration/IoTDBFilePathUtilsIT.java |  110 -
 .../apache/iotdb/db/integration/IoTDBFillIT.java   |  882 ------
 .../db/integration/IoTDBFloatPrecisionIT.java      |  174 --
 .../db/integration/IoTDBFlushQueryMergeIT.java     |  214 --
 .../iotdb/db/integration/IoTDBGroupByFillIT.java   |  850 ------
 .../integration/IoTDBGroupByFillWithRangeIT.java   |  182 --
 .../iotdb/db/integration/IoTDBGroupByMonthIT.java  |  272 --
 .../iotdb/db/integration/IoTDBInsertNaNIT.java     |  203 --
 .../db/integration/IoTDBInsertWithQueryIT.java     |  532 ----
 .../iotdb/db/integration/IoTDBKillQueryIT.java     |   81 -
 .../iotdb/db/integration/IoTDBLargeDataIT.java     |  395 ---
 .../apache/iotdb/db/integration/IoTDBLastIT.java   |  559 ----
 .../db/integration/IoTDBLevelCompactionIT.java     | 1200 --------
 .../iotdb/db/integration/IoTDBLimitSlimitIT.java   |  208 --
 ...IoTDBLoadExternalTsFileWithTimePartitionIT.java |  210 --
 .../db/integration/IoTDBLoadExternalTsfileIT.java  |  706 -----
 .../apache/iotdb/db/integration/IoTDBMergeIT.java  |  386 ---
 .../iotdb/db/integration/IoTDBMetadataFetchIT.java |  639 -----
 .../iotdb/db/integration/IoTDBMultiDeviceIT.java   |  308 --
 .../IoTDBMultiOverlappedChunkInUnseqIT.java        |  120 -
 .../db/integration/IoTDBMultiOverlappedPageIT.java |  180 --
 .../iotdb/db/integration/IoTDBMultiSeriesIT.java   |  512 ----
 .../db/integration/IoTDBMultiStatementsIT.java     |  202 --
 .../db/integration/IoTDBNewTsFileCompactionIT.java | 1057 -------
 .../iotdb/db/integration/IoTDBNumberPathIT.java    |  484 ----
 .../db/integration/IoTDBOverlappedPageIT.java      |  158 --
 .../iotdb/db/integration/IoTDBQueryDemoIT.java     |  486 ----
 .../db/integration/IoTDBQueryMemoryControlIT.java  |  299 --
 .../iotdb/db/integration/IoTDBQueryTimeoutIT.java  |  151 -
 .../iotdb/db/integration/IoTDBQuotedPathIT.java    |  149 -
 .../iotdb/db/integration/IoTDBRecoverIT.java       |  435 ---
 .../db/integration/IoTDBRecoverUnclosedIT.java     |  288 --
 .../db/integration/IoTDBRemovePartitionIT.java     |  330 ---
 .../iotdb/db/integration/IoTDBRestartIT.java       |  408 ---
 .../iotdb/db/integration/IoTDBResultSetIT.java     |  126 -
 .../db/integration/IoTDBRpcCompressionIT.java      |  151 -
 .../IoTDBSameMeasurementsDifferentTypesIT.java     |  187 --
 .../iotdb/db/integration/IoTDBSensorUpdateIT.java  |   85 -
 .../db/integration/IoTDBSequenceDataQueryIT.java   |  319 ---
 .../iotdb/db/integration/IoTDBSeriesReaderIT.java  |  490 ----
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   | 1279 ---------
 .../integration/IoTDBSortedShowTimeseriesIT.java   |  335 ---
 .../iotdb/db/integration/IoTDBTagAlterIT.java      |  640 -----
 .../apache/iotdb/db/integration/IoTDBTagIT.java    | 1161 --------
 .../iotdb/db/integration/IoTDBTimeZoneIT.java      |  163 --
 .../iotdb/db/integration/IoTDBTracingIT.java       |   70 -
 .../apache/iotdb/db/integration/IoTDBTtlIT.java    |  213 --
 .../iotdb/db/integration/IoTDBUDFManagementIT.java |  460 ---
 .../db/integration/IoTDBUDFWindowQueryIT.java      |  557 ----
 .../integration/IoTDBUDTFAlignByTimeQueryIT.java   |  846 ------
 .../db/integration/IoTDBUDTFBuiltinFunctionIT.java |  285 --
 .../db/integration/IoTDBUDTFHybridQueryIT.java     |  181 --
 .../db/integration/IoTDBUDTFNonAlignQueryIT.java   |  368 ---
 .../iotdb/db/integration/IoTDBVersionIT.java       |   70 -
 .../aggregation/IoTDBAggregationByLevelIT.java     |  358 ---
 .../aggregation/IoTDBAggregationDeleteIT.java      |   91 -
 .../aggregation/IoTDBAggregationIT.java            | 1029 -------
 .../aggregation/IoTDBAggregationLargeDataIT.java   |  991 -------
 .../aggregation/IoTDBAggregationSmallDataIT.java   |  774 -----
 .../db/integration/auth/IoTDBAuthorizationIT.java  | 1082 -------
 .../iotdb/db/metadata/MManagerAdvancedTest.java    |  230 --
 .../iotdb/db/metadata/MManagerBasicTest.java       |  810 ------
 .../iotdb/db/metadata/MManagerImproveTest.java     |  187 --
 .../org/apache/iotdb/db/metadata/MTreeTest.java    |  870 ------
 .../apache/iotdb/db/metadata/MetaUtilsTest.java    |  114 -
 .../apache/iotdb/db/metadata/PartialPathTest.java  |  113 -
 .../apache/iotdb/db/metadata/mnode/MNodeTest.java  |   98 -
 .../iotdb/db/monitor/IoTDBStatMonitorTest.java     |  177 --
 .../iotdb/db/mqtt/BrokerAuthenticatorTest.java     |   52 -
 .../iotdb/db/mqtt/JSONPayloadFormatTest.java       |   71 -
 .../iotdb/db/mqtt/PayloadFormatManagerTest.java    |   35 -
 .../apache/iotdb/db/mqtt/PublishHandlerTest.java   |   62 -
 .../java/org/apache/iotdb/db/qp/PlannerTest.java   |  256 --
 .../iotdb/db/qp/bench/QueryParseBenchmark.java     |   45 -
 .../iotdb/db/qp/logical/IndexLogicalPlanTest.java  |  156 -
 .../iotdb/db/qp/logical/LogicalPlanSmallTest.java  |  364 ---
 .../iotdb/db/qp/other/TSPlanContextAuthorTest.java |   91 -
 .../iotdb/db/qp/physical/ConcatOptimizerTest.java  |  138 -
 .../physical/IndexSubMatchingPhysicalPlanTest.java |  163 --
 .../IndexWholeMatchingPhysicalPlanTest.java        |  168 --
 .../db/qp/physical/InsertTabletMultiPlanTest.java  |  103 -
 .../iotdb/db/qp/physical/InsertTabletPlanTest.java |  109 -
 .../db/qp/physical/PhysicalPlanSerializeTest.java  |  284 --
 .../iotdb/db/qp/physical/PhysicalPlanTest.java     | 1218 --------
 .../iotdb/db/qp/physical/SerializationTest.java    |  151 -
 .../iotdb/db/qp/sql/IoTDBsqlVisitorTest.java       |   99 -
 .../db/qp/utils/DatetimeQueryDataSetUtilsTest.java |  199 --
 .../db/query/aggregation/AggregateResultTest.java  |  269 --
 .../query/aggregation/DescAggregateResultTest.java |  127 -
 .../db/query/control/FileReaderManagerTest.java    |  148 -
 .../db/query/control/QueryResourceManagerTest.java |   29 -
 .../iotdb/db/query/control/TracingManagerTest.java |  114 -
 .../dataset/EngineDataSetWithValueFilterTest.java  |  156 -
 .../iotdb/db/query/dataset/ListDataSetTest.java    |  149 -
 .../db/query/dataset/ShowDevicesResultTest.java    |   42 -
 .../db/query/dataset/ShowTimeSeriesResultTest.java |   66 -
 .../iotdb/db/query/dataset/SingleDataSetTest.java  |  130 -
 .../query/dataset/UDTFAlignByTimeDataSetTest.java  |  692 -----
 .../dataset/groupby/GroupByEngineDataSetTest.java  |  504 ----
 .../dataset/groupby/GroupByFillDataSetTest.java    |  194 --
 .../dataset/groupby/GroupByLevelDataSetTest.java   |  151 -
 .../dataset/groupby/GroupByTimeDataSetTest.java    |  225 --
 .../query/externalsort/ExternalSortEngineTest.java |  193 --
 .../db/query/externalsort/FakeChunkReaderWrap.java |   43 -
 ...ExternalSortFileSerializerDeserializerTest.java |  131 -
 .../reader/series/SeriesAggregateReaderTest.java   |  136 -
 .../reader/series/SeriesReaderByTimestampTest.java |   98 -
 .../db/query/reader/series/SeriesReaderTest.java   |  188 --
 .../query/reader/series/SeriesReaderTestUtil.java  |  234 --
 .../query/reader/universal/FakedSeriesReader.java  |   85 -
 .../reader/universal/PriorityMergeReaderTest.java  |   85 -
 .../reader/universal/PriorityMergeReaderTest2.java |   60 -
 .../ElasticSerializableRowRecordListTest.java      |  233 --
 .../ElasticSerializableTVListTest.java             |  268 --
 .../iotdb/db/query/udf/datastructure/LRUCache.java |   59 -
 .../db/query/udf/datastructure/LRUCacheTest.java   |  115 -
 .../SerializableBinaryTVListTest.java              |   85 -
 .../SerializableBooleanTVListTest.java             |   85 -
 .../SerializableDoubleTVListTest.java              |   84 -
 .../datastructure/SerializableFloatTVListTest.java |   83 -
 .../datastructure/SerializableIntTVListTest.java   |   83 -
 .../udf/datastructure/SerializableListTest.java    |   43 -
 .../datastructure/SerializableLongTVListTest.java  |   83 -
 .../SerializableRowRecordListTest.java             |  183 --
 .../udf/datastructure/SerializableTVListTest.java  |   38 -
 .../iotdb/db/query/udf/example/Accumulator.java    |   95 -
 .../apache/iotdb/db/query/udf/example/Adder.java   |   94 -
 .../apache/iotdb/db/query/udf/example/Counter.java |   83 -
 .../org/apache/iotdb/db/query/udf/example/Max.java |   76 -
 .../iotdb/db/query/udf/example/Multiplier.java     |   65 -
 .../SlidingSizeWindowConstructorTester0.java       |   59 -
 .../SlidingSizeWindowConstructorTester1.java       |   66 -
 .../SlidingTimeWindowConstructionTester.java       |   74 -
 .../db/query/udf/example/TerminateTester.java      |   69 -
 .../iotdb/db/query/udf/example/ValidateTester.java |   46 -
 .../org/apache/iotdb/db/script/EnvScriptIT.java    |  128 -
 .../db/sync/receiver/load/FileLoaderTest.java      |  411 ---
 .../recover/SyncReceiverLogAnalyzerTest.java       |  232 --
 .../receiver/recover/SyncReceiverLoggerTest.java   |  115 -
 .../db/sync/sender/manage/SyncFileManagerTest.java |  350 ---
 .../sender/recover/SyncSenderLogAnalyzerTest.java  |  201 --
 .../sync/sender/recover/SyncSenderLoggerTest.java  |  112 -
 .../db/sync/sender/transfer/SyncClientTest.java    |  161 --
 .../apache/iotdb/db/tools/IoTDBWatermarkTest.java  |  247 --
 .../org/apache/iotdb/db/tools/MLogParserTest.java  |  191 --
 .../org/apache/iotdb/db/tools/WalCheckerTest.java  |  172 --
 .../iotdb/db/utils/CopyOnReadLinkedListTest.java   |   67 -
 .../iotdb/db/utils/EncodingInferenceUtilsTest.java |   50 -
 .../apache/iotdb/db/utils/EnvironmentUtils.java    |  322 ---
 .../apache/iotdb/db/utils/FilePathUtilsTest.java   |  124 -
 .../iotdb/db/utils/MathQueryDataSetUtilsTest.java  |   68 -
 .../org/apache/iotdb/db/utils/MemUtilsTest.java    |  113 -
 .../apache/iotdb/db/utils/OpenFileNumUtilTest.java |  294 --
 .../java/org/apache/iotdb/db/utils/RandomNum.java  |   65 -
 .../org/apache/iotdb/db/utils/SchemaUtilsTest.java |   71 -
 .../apache/iotdb/db/utils/SerializeUtilsTest.java  |  287 --
 .../iotdb/db/utils/TsFileRewriteToolTest.java      |  330 ---
 .../iotdb/db/utils/TypeInferenceUtilsTest.java     |   99 -
 .../db/utils/datastructure/BinaryTVListTest.java   |   58 -
 .../db/utils/datastructure/BooleanTVListTest.java  |   66 -
 .../db/utils/datastructure/DoubleTVListTest.java   |   76 -
 .../db/utils/datastructure/FloatTVListTest.java    |   76 -
 .../db/utils/datastructure/IntTVListTest.java      |   75 -
 .../db/utils/datastructure/LongTVListTest.java     |   98 -
 .../db/utils/datastructure/PrecisionTest.java      |  143 -
 .../db/utils/datastructure/TimeSelectorTest.java   |  218 --
 .../iotdb/db/writelog/IoTDBLogFileSizeTest.java    |  221 --
 .../apache/iotdb/db/writelog/PerformanceTest.java  |  219 --
 .../iotdb/db/writelog/WriteLogNodeManagerTest.java |  185 --
 .../apache/iotdb/db/writelog/WriteLogNodeTest.java |  324 ---
 .../iotdb/db/writelog/io/LogWriterReaderTest.java  |   97 -
 .../db/writelog/io/MultiFileLogReaderTest.java     |   89 -
 .../db/writelog/recover/DeviceStringTest.java      |  132 -
 .../iotdb/db/writelog/recover/LogReplayerTest.java |  281 --
 .../recover/RecoverResourceFromReaderTest.java     |  263 --
 .../db/writelog/recover/SeqTsFileRecoverTest.java  |  327 ---
 .../writelog/recover/UnseqTsFileRecoverTest.java   |  276 --
 server/src/test/resources/iotdb-engine.properties  |   24 -
 server/src/test/resources/logback.xml              |   58 -
 server/src/test/resources/start-sync-test.sh       |   54 -
 server/src/test/resources/stop-sync-test.sh        |   29 -
 service-rpc/pom.xml                                |  156 -
 .../org/apache/iotdb/rpc/AutoResizingBuffer.java   |   76 -
 .../iotdb/rpc/AutoScalingBufferReadTransport.java  |   86 -
 .../iotdb/rpc/AutoScalingBufferWriteTransport.java |   65 -
 .../apache/iotdb/rpc/BatchExecutionException.java  |   46 -
 .../apache/iotdb/rpc/IoTDBConnectionException.java |   36 -
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |  509 ----
 .../org/apache/iotdb/rpc/NonOpenTransport.java     |   43 -
 .../org/apache/iotdb/rpc/RedirectException.java    |   52 -
 .../main/java/org/apache/iotdb/rpc/RpcStat.java    |   50 -
 .../org/apache/iotdb/rpc/RpcTransportFactory.java  |   72 -
 .../main/java/org/apache/iotdb/rpc/RpcUtils.java   |  276 --
 .../iotdb/rpc/StatementExecutionException.java     |   47 -
 .../org/apache/iotdb/rpc/SynchronizedHandler.java  |   55 -
 .../rpc/TCompressedElasticFramedTransport.java     |   98 -
 .../apache/iotdb/rpc/TElasticFramedTransport.java  |  145 -
 .../java/org/apache/iotdb/rpc/TSStatusCode.java    |  101 -
 .../iotdb/rpc/TSnappyElasticFramedTransport.java   |   78 -
 .../rpc/TimeoutChangeableTFastFramedTransport.java |   69 -
 .../TimeoutChangeableTSnappyFramedTransport.java   |   70 -
 .../iotdb/rpc/TimeoutChangeableTransport.java      |   28 -
 session/pom.xml                                    |  153 -
 .../main/java/org/apache/iotdb/session/Config.java |   37 -
 .../java/org/apache/iotdb/session/Session.java     | 1544 ----------
 .../apache/iotdb/session/SessionConnection.java    |  689 -----
 .../org/apache/iotdb/session/SessionDataSet.java   |  281 --
 .../org/apache/iotdb/session/SessionUtils.java     |   91 -
 .../iotdb/session/pool/SessionDataSetWrapper.java  |  100 -
 .../org/apache/iotdb/session/pool/SessionPool.java | 1164 --------
 .../iotdb/session/IoTDBSessionComplexIT.java       |  803 ------
 .../iotdb/session/IoTDBSessionIteratorIT.java      |  343 ---
 .../apache/iotdb/session/IoTDBSessionSimpleIT.java |  684 -----
 .../apache/iotdb/session/SessionCacheLeaderUT.java |  821 ------
 .../java/org/apache/iotdb/session/SessionUT.java   |  202 --
 .../apache/iotdb/session/pool/SessionPoolTest.java |  309 --
 session/src/test/resources/iotdb-engine.properties |   20 -
 site/README-zh.md                                  |  208 --
 site/README.md                                     |  214 --
 site/iotdb-doap.rdf                                |   80 -
 site/pom.xml                                       |  885 ------
 site/src/main/.vuepress/config.js                  | 1687 -----------
 site/src/main/.vuepress/enhanceApp.js              |   31 -
 site/src/main/.vuepress/public/img/arrow.png       |  Bin 88 -> 0 bytes
 .../public/img/contributor-avatar/jlq.png          |  Bin 98500 -> 0 bytes
 .../public/img/contributor-avatar/kfx.jpeg         |  Bin 119029 -> 0 bytes
 .../public/img/contributor-avatar/user.svg         |   51 -
 .../public/img/contributor-avatar/xdh.jpg          |  Bin 123718 -> 0 bytes
 .../public/img/contributor-avatar/xww.jpg          |  Bin 64538 -> 0 bytes
 .../public/img/contributor-avatar/yrzh.jpg         |  Bin 99556 -> 0 bytes
 .../.vuepress/public/img/contributor-avatar/yt.jpg |  Bin 115804 -> 0 bytes
 .../public/img/contributor-avatar/zss.jpg          |  Bin 91455 -> 0 bytes
 site/src/main/.vuepress/public/img/home-Slide1.png |  Bin 323108 -> 0 bytes
 site/src/main/.vuepress/public/img/home-Slide2.png |  Bin 323620 -> 0 bytes
 site/src/main/.vuepress/public/img/home-Slide3.png |  Bin 324332 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon1.png  |  Bin 30032 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon2.png  |  Bin 4463 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon3.png  |  Bin 10753 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon4.png  |  Bin 8681 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon5.png  |  Bin 1531 -> 0 bytes
 site/src/main/.vuepress/public/img/home-icon6.png  |  Bin 11537 -> 0 bytes
 site/src/main/.vuepress/public/img/logo.png        |  Bin 21687 -> 0 bytes
 site/src/main/.vuepress/public/img/tools.jpg       |  Bin 294103 -> 0 bytes
 site/src/main/.vuepress/styles/index.styl          |   23 -
 site/src/main/.vuepress/styles/palette.styl        |   23 -
 .../theme/components/AlgoliaSearchBox.vue          |  172 --
 .../.vuepress/theme/components/DropdownLink.vue    |  196 --
 .../theme/components/DropdownTransition.vue        |   50 -
 site/src/main/.vuepress/theme/components/Home.vue  |  179 --
 .../main/.vuepress/theme/components/NavLink.vue    |   65 -
 .../main/.vuepress/theme/components/NavLinks.vue   |  166 --
 .../src/main/.vuepress/theme/components/Navbar.vue |  139 -
 site/src/main/.vuepress/theme/components/Page.vue  |  283 --
 .../main/.vuepress/theme/components/Sidebar.vue    |   76 -
 .../.vuepress/theme/components/SidebarButton.vue   |   44 -
 .../.vuepress/theme/components/SidebarGroup.vue    |  146 -
 .../.vuepress/theme/components/SidebarLink.vue     |  126 -
 .../.vuepress/theme/components/SidebarLinks.vue    |  103 -
 .../.vuepress/theme/global-components/Badge.vue    |   61 -
 .../theme/global-components/Contributor.vue        |  390 ---
 .../.vuepress/theme/global-components/IoTDB.vue    |  302 --
 .../.vuepress/theme/global-components/IoTDBZH.vue  |  296 --
 site/src/main/.vuepress/theme/index.js             |   63 -
 site/src/main/.vuepress/theme/layouts/404.vue      |   43 -
 site/src/main/.vuepress/theme/layouts/Layout.vue   |  166 --
 site/src/main/.vuepress/theme/styles/arrow.styl    |   39 -
 site/src/main/.vuepress/theme/styles/code.styl     |  166 --
 .../main/.vuepress/theme/styles/custom-blocks.styl |   47 -
 site/src/main/.vuepress/theme/styles/index.styl    |  229 --
 site/src/main/.vuepress/theme/styles/mobile.styl   |   54 -
 site/src/main/.vuepress/theme/styles/toc.styl      |   20 -
 site/src/main/.vuepress/theme/styles/wrapper.styl  |   26 -
 site/src/main/.vuepress/theme/util/index.js        |  256 --
 site/src/main/deploy.js                            |   25 -
 site/src/main/package.json                         |   44 -
 spark-iotdb-connector/Readme.md                    |  168 --
 spark-iotdb-connector/pom.xml                      |  142 -
 .../org/apache/iotdb/spark/db/SQLConstant.java     |   28 -
 .../org/apache/iotdb/spark/db/Converter.scala      |   85 -
 .../org/apache/iotdb/spark/db/DefaultSource.scala  |   43 -
 .../org/apache/iotdb/spark/db/IoTDBOptions.scala   |   43 -
 .../scala/org/apache/iotdb/spark/db/IoTDBRDD.scala |  133 -
 .../org/apache/iotdb/spark/db/IoTDBRelation.scala  |  117 -
 .../org/apache/iotdb/spark/db/Transformer.scala    |  172 --
 .../scala/org/apache/iotdb/spark/db/package.scala  |   36 -
 .../src/test/resources/iotdb-engine.properties     |   21 -
 .../apache/iotdb/spark/db/EnvironmentUtils.java    |  268 --
 .../org/apache/iotdb/spark/db/IoTDBTest.scala      |  153 -
 spark-tsfile/README.md                             |  335 ---
 spark-tsfile/pom.xml                               |  125 -
 .../iotdb/spark/tsfile/io/TsFileOutputFormat.java  |   46 -
 .../iotdb/spark/tsfile/io/TsFileRecordWriter.java  |   58 -
 .../org/apache/iotdb/spark/tsfile/qp/Executor.java |   46 -
 .../iotdb/spark/tsfile/qp/QueryProcessor.java      |  197 --
 .../spark/tsfile/qp/common/BasicOperator.java      |   66 -
 .../spark/tsfile/qp/common/FilterOperator.java     |  153 -
 .../iotdb/spark/tsfile/qp/common/Operator.java     |   44 -
 .../iotdb/spark/tsfile/qp/common/SQLConstant.java  |  144 -
 .../iotdb/spark/tsfile/qp/common/SingleQuery.java  |   65 -
 .../iotdb/spark/tsfile/qp/common/TSQueryPlan.java  |   68 -
 .../qp/exception/BasicOperatorException.java       |   29 -
 .../tsfile/qp/exception/DNFOptimizeException.java  |   29 -
 .../qp/exception/LogicalOptimizeException.java     |   29 -
 .../tsfile/qp/exception/MergeFilterException.java  |   28 -
 .../qp/exception/QueryOperatorException.java       |   28 -
 .../qp/exception/QueryProcessorException.java      |   37 -
 .../tsfile/qp/exception/RemoveNotException.java    |   29 -
 .../tsfile/qp/optimizer/DNFFilterOptimizer.java    |  155 -
 .../tsfile/qp/optimizer/IFilterOptimizer.java      |   31 -
 .../qp/optimizer/MergeSingleFilterOptimizer.java   |  143 -
 .../tsfile/qp/optimizer/PhysicalOptimizer.java     |  242 --
 .../tsfile/qp/optimizer/RemoveNotOptimizer.java    |   97 -
 .../org/apache/iotdb/spark/tsfile/Converter.scala  |  145 -
 .../apache/iotdb/spark/tsfile/DefaultSource.scala  |  294 --
 .../iotdb/spark/tsfile/NarrowConverter.scala       |  596 ----
 .../spark/tsfile/NarrowTsFileOutputWriter.scala    |   50 -
 .../apache/iotdb/spark/tsfile/Transformer.scala    |  175 --
 .../iotdb/spark/tsfile/TsFileWriterFactory.scala   |   42 -
 .../apache/iotdb/spark/tsfile/WideConverter.scala  |  501 ----
 .../spark/tsfile/WideTsFileOutputWriter.scala      |   53 -
 .../org/apache/iotdb/spark/tsfile/package.scala    |   62 -
 .../apache/iotdb/spark/constant/TestConstant.java  |   28 -
 .../org/apache/iotdb/spark/tool/TsFileExample.java |  114 -
 .../apache/iotdb/spark/tool/TsFileWriteTool.java   |  279 --
 .../apache/iotdb/spark/tsfile/ConverterTest.scala  |  269 --
 .../apache/iotdb/spark/tsfile/HDFSInputTest.java   |   81 -
 .../org/apache/iotdb/spark/tsfile/TSFileSuit.scala |  641 -----
 test/e2e/base/docker-compose.yaml                  |   51 -
 test/e2e/cases/README.md                           |   53 -
 test/e2e/cases/cli/README.md                       |   24 -
 test/e2e/cases/cli/cleanup.sh                      |   27 -
 test/e2e/cases/cli/docker-compose.yaml             |   41 -
 test/e2e/cases/cli/res/init.sql                    |   26 -
 test/e2e/cases/cli/run.sh                          |   48 -
 thrift-cluster/README.md                           |   22 -
 thrift-cluster/pom.xml                             |   67 -
 thrift-cluster/rpc-changelist.md                   |  181 --
 thrift-cluster/src/main/thrift/cluster.thrift      |  512 ----
 thrift-sync/README.md                              |   22 -
 thrift-sync/pom.xml                                |   67 -
 thrift-sync/rpc-changelist.md                      |  181 --
 thrift-sync/src/main/thrift/sync.thrift            |   51 -
 thrift/README.md                                   |   22 -
 thrift/pom.xml                                     |   98 -
 thrift/rpc-changelist.md                           |  181 --
 thrift/src/main/thrift/rpc.thrift                  |  372 ---
 tools/check_sigs.sh                                |   67 -
 tools/clean-site.sh                                |   35 -
 tools/common.sh                                    |  202 --
 tools/download_staged_release.sh                   |  143 -
 tsfile/README.md                                   |   63 -
 tsfile/format-changelist.md                        |   56 -
 tsfile/pom.xml                                     |  184 --
 .../iotdb/tsfile/common/cache/Accountable.java     |   26 -
 .../apache/iotdb/tsfile/common/cache/Cache.java    |   30 -
 .../apache/iotdb/tsfile/common/cache/LRUCache.java |   67 -
 .../iotdb/tsfile/common/conf/TSFileConfig.java     |  413 ---
 .../iotdb/tsfile/common/conf/TSFileDescriptor.java |  167 --
 .../tsfile/common/constant/JsonFormatConstant.java |   43 -
 .../tsfile/common/constant/QueryConstant.java      |   32 -
 .../tsfile/common/constant/TsFileConstant.java     |   34 -
 .../apache/iotdb/tsfile/compress/ICompressor.java  |  260 --
 .../iotdb/tsfile/compress/IUnCompressor.java       |  315 ---
 .../tsfile/encoding/bitpacking/IntPacker.java      |  162 --
 .../tsfile/encoding/bitpacking/LongPacker.java     |  176 --
 .../tsfile/encoding/decoder/BitmapDecoder.java     |  221 --
 .../iotdb/tsfile/encoding/decoder/Decoder.java     |  149 -
 .../encoding/decoder/DeltaBinaryDecoder.java       |  247 --
 .../encoding/decoder/DoublePrecisionDecoderV1.java |  117 -
 .../encoding/decoder/DoublePrecisionDecoderV2.java |   53 -
 .../tsfile/encoding/decoder/FloatDecoder.java      |  146 -
 .../tsfile/encoding/decoder/GorillaDecoderV1.java  |  128 -
 .../tsfile/encoding/decoder/GorillaDecoderV2.java  |  123 -
 .../tsfile/encoding/decoder/IntGorillaDecoder.java |   90 -
 .../tsfile/encoding/decoder/IntRleDecoder.java     |  124 -
 .../encoding/decoder/LongGorillaDecoder.java       |   89 -
 .../tsfile/encoding/decoder/LongRleDecoder.java    |  119 -
 .../tsfile/encoding/decoder/PlainDecoder.java      |   88 -
 .../encoding/decoder/RegularDataDecoder.java       |  282 --
 .../iotdb/tsfile/encoding/decoder/RleDecoder.java  |  230 --
 .../encoding/decoder/SinglePrecisionDecoderV1.java |  113 -
 .../encoding/decoder/SinglePrecisionDecoderV2.java |   53 -
 .../tsfile/encoding/encoder/BitmapEncoder.java     |  133 -
 .../encoding/encoder/DeltaBinaryEncoder.java       |  336 ---
 .../encoding/encoder/DoublePrecisionEncoderV1.java |  117 -
 .../encoding/encoder/DoublePrecisionEncoderV2.java |   55 -
 .../iotdb/tsfile/encoding/encoder/Encoder.java     |  111 -
 .../tsfile/encoding/encoder/FloatEncoder.java      |  138 -
 .../tsfile/encoding/encoder/GorillaEncoderV1.java  |   84 -
 .../tsfile/encoding/encoder/GorillaEncoderV2.java  |  105 -
 .../tsfile/encoding/encoder/IntGorillaEncoder.java |  158 --
 .../tsfile/encoding/encoder/IntRleEncoder.java     |  129 -
 .../encoding/encoder/LongGorillaEncoder.java       |  158 --
 .../tsfile/encoding/encoder/LongRleEncoder.java    |  122 -
 .../tsfile/encoding/encoder/PlainEncoder.java      |  138 -
 .../encoding/encoder/RegularDataEncoder.java       |  364 ---
 .../iotdb/tsfile/encoding/encoder/RleEncoder.java  |  333 ---
 .../iotdb/tsfile/encoding/encoder/SDTEncoder.java  |  452 ---
 .../encoding/encoder/SinglePrecisionEncoderV1.java |  113 -
 .../encoding/encoder/SinglePrecisionEncoderV2.java |   55 -
 .../tsfile/encoding/encoder/TSEncodingBuilder.java |  299 --
 .../exception/NotCompatibleTsFileException.java    |   28 -
 .../tsfile/exception/NotImplementedException.java  |   40 -
 .../iotdb/tsfile/exception/NullFieldException.java |   26 -
 .../tsfile/exception/TsFileRuntimeException.java   |   44 -
 .../tsfile/exception/cache/CacheException.java     |   44 -
 .../CompressionTypeNotSupportedException.java      |   43 -
 .../encoding/TsFileDecodingException.java          |   47 -
 .../encoding/TsFileEncodingException.java          |   47 -
 .../filter/QueryFilterOptimizationException.java   |   34 -
 .../exception/filter/StatisticsClassException.java |   34 -
 .../filter/UnSupportFilterDataTypeException.java   |   35 -
 .../exception/write/NoMeasurementException.java    |   29 -
 .../tsfile/exception/write/PageException.java      |   37 -
 .../write/TsFileNotCompleteException.java          |   39 -
 .../write/UnSupportedDataTypeException.java        |   30 -
 .../write/UnknownColumnTypeException.java          |   34 -
 .../exception/write/WriteProcessException.java     |   37 -
 .../org/apache/iotdb/tsfile/file/MetaMarker.java   |   52 -
 .../iotdb/tsfile/file/header/ChunkGroupHeader.java |  121 -
 .../iotdb/tsfile/file/header/ChunkHeader.java      |  281 --
 .../iotdb/tsfile/file/header/PageHeader.java       |  141 -
 .../tsfile/file/metadata/ChunkGroupMetadata.java   |   42 -
 .../iotdb/tsfile/file/metadata/ChunkMetadata.java  |  309 --
 .../file/metadata/MetadataIndexConstructor.java    |  159 --
 .../tsfile/file/metadata/MetadataIndexEntry.java   |   70 -
 .../tsfile/file/metadata/MetadataIndexNode.java    |  150 -
 .../tsfile/file/metadata/TimeseriesMetadata.java   |  259 --
 .../iotdb/tsfile/file/metadata/TsFileMetadata.java |  152 -
 .../file/metadata/enums/CompressionType.java       |  100 -
 .../file/metadata/enums/MetadataIndexNodeType.java |   98 -
 .../tsfile/file/metadata/enums/TSDataType.java     |  118 -
 .../tsfile/file/metadata/enums/TSEncoding.java     |   85 -
 .../file/metadata/statistics/BinaryStatistics.java |  222 --
 .../metadata/statistics/BooleanStatistics.java     |  235 --
 .../file/metadata/statistics/DoubleStatistics.java |  280 --
 .../file/metadata/statistics/FloatStatistics.java  |  272 --
 .../metadata/statistics/IntegerStatistics.java     |  272 --
 .../file/metadata/statistics/LongStatistics.java   |  281 --
 .../file/metadata/statistics/Statistics.java       |  456 ---
 .../iotdb/tsfile/fileSystem/FSFactoryProducer.java |   64 -
 .../org/apache/iotdb/tsfile/fileSystem/FSType.java |   25 -
 .../fileInputFactory/FileInputFactory.java         |   27 -
 .../fileInputFactory/HDFSInputFactory.java         |   58 -
 .../fileInputFactory/LocalFSInputFactory.java      |   44 -
 .../fileOutputFactory/FileOutputFactory.java       |   27 -
 .../fileOutputFactory/HDFSOutputFactory.java       |   58 -
 .../fileOutputFactory/LocalFSOutputFactory.java    |   45 -
 .../tsfile/fileSystem/fsFactory/FSFactory.java     |  139 -
 .../tsfile/fileSystem/fsFactory/HDFSFactory.java   |  237 --
 .../fileSystem/fsFactory/LocalFSFactory.java       |  154 -
 .../apache/iotdb/tsfile/read/ReadOnlyTsFile.java   |   60 -
 .../apache/iotdb/tsfile/read/TimeValuePair.java    |   81 -
 .../iotdb/tsfile/read/TsFileCheckStatus.java       |   26 -
 .../iotdb/tsfile/read/TsFileRestorableReader.java  |   71 -
 .../iotdb/tsfile/read/TsFileSequenceReader.java    | 1360 ---------
 .../iotdb/tsfile/read/UnClosedTsFileReader.java    |   44 -
 .../apache/iotdb/tsfile/read/common/BatchData.java |  602 ----
 .../iotdb/tsfile/read/common/BatchDataFactory.java |   44 -
 .../org/apache/iotdb/tsfile/read/common/Chunk.java |  171 --
 .../tsfile/read/common/DescReadBatchData.java      |   83 -
 .../tsfile/read/common/DescReadWriteBatchData.java |  373 ---
 .../tsfile/read/common/ExceptionBatchData.java     |   37 -
 .../org/apache/iotdb/tsfile/read/common/Field.java |  227 --
 .../org/apache/iotdb/tsfile/read/common/Path.java  |  164 --
 .../apache/iotdb/tsfile/read/common/RowRecord.java |   79 -
 .../iotdb/tsfile/read/common/SignalBatchData.java  |   43 -
 .../apache/iotdb/tsfile/read/common/TimeRange.java |  373 ---
 .../read/controller/CachedChunkLoaderImpl.java     |   73 -
 .../iotdb/tsfile/read/controller/IChunkLoader.java |   33 -
 .../read/controller/IChunkMetadataLoader.java      |   32 -
 .../tsfile/read/controller/IMetadataQuerier.java   |   67 -
 .../read/controller/MetadataQuerierByFileImpl.java |  268 --
 .../tsfile/read/expression/ExpressionType.java     |   47 -
 .../tsfile/read/expression/IBinaryExpression.java  |   30 -
 .../iotdb/tsfile/read/expression/IExpression.java  |   28 -
 .../tsfile/read/expression/IUnaryExpression.java   |   28 -
 .../tsfile/read/expression/QueryExpression.java    |  102 -
 .../read/expression/impl/BinaryExpression.java     |  133 -
 .../read/expression/impl/GlobalTimeExpression.java |   61 -
 .../expression/impl/SingleSeriesExpression.java    |   68 -
 .../read/expression/util/ExpressionOptimizer.java  |  235 --
 .../read/expression/util/ExpressionPrinter.java    |   60 -
 .../iotdb/tsfile/read/filter/GroupByFilter.java    |  148 -
 .../tsfile/read/filter/GroupByMonthFilter.java     |  187 --
 .../iotdb/tsfile/read/filter/TimeFilter.java       |  125 -
 .../iotdb/tsfile/read/filter/ValueFilter.java      |  130 -
 .../tsfile/read/filter/basic/BinaryFilter.java     |   92 -
 .../iotdb/tsfile/read/filter/basic/Filter.java     |   68 -
 .../tsfile/read/filter/basic/UnaryFilter.java      |   99 -
 .../tsfile/read/filter/factory/FilterFactory.java  |   90 -
 .../read/filter/factory/FilterSerializeId.java     |   34 -
 .../tsfile/read/filter/factory/FilterType.java     |   36 -
 .../tsfile/read/filter/operator/AndFilter.java     |   73 -
 .../iotdb/tsfile/read/filter/operator/Eq.java      |   97 -
 .../iotdb/tsfile/read/filter/operator/Gt.java      |   95 -
 .../iotdb/tsfile/read/filter/operator/GtEq.java    |   95 -
 .../iotdb/tsfile/read/filter/operator/In.java      |  125 -
 .../iotdb/tsfile/read/filter/operator/Lt.java      |   95 -
 .../iotdb/tsfile/read/filter/operator/LtEq.java    |   95 -
 .../iotdb/tsfile/read/filter/operator/NotEq.java   |   97 -
 .../tsfile/read/filter/operator/NotFilter.java     |  115 -
 .../tsfile/read/filter/operator/OrFilter.java      |   75 -
 .../query/dataset/DataSetWithTimeGenerator.java    |   88 -
 .../query/dataset/DataSetWithoutTimeGenerator.java |  179 --
 .../tsfile/read/query/dataset/EmptyDataSet.java    |   40 -
 .../tsfile/read/query/dataset/QueryDataSet.java    |  170 --
 .../query/executor/ExecutorWithTimeGenerator.java  |  127 -
 .../tsfile/read/query/executor/QueryExecutor.java  |   29 -
 .../tsfile/read/query/executor/TsFileExecutor.java |  197 --
 .../read/query/timegenerator/TimeGenerator.java    |  135 -
 .../query/timegenerator/TsFileTimeGenerator.java   |   58 -
 .../read/query/timegenerator/node/AndNode.java     |  105 -
 .../read/query/timegenerator/node/LeafNode.java    |   92 -
 .../tsfile/read/query/timegenerator/node/Node.java |   30 -
 .../read/query/timegenerator/node/NodeType.java    |   26 -
 .../read/query/timegenerator/node/OrNode.java      |  118 -
 .../tsfile/read/reader/BatchDataIterator.java      |   54 -
 .../iotdb/tsfile/read/reader/IBatchReader.java     |   32 -
 .../iotdb/tsfile/read/reader/IChunkReader.java     |   35 -
 .../iotdb/tsfile/read/reader/IPageReader.java      |   40 -
 .../iotdb/tsfile/read/reader/IPointReader.java     |   34 -
 .../iotdb/tsfile/read/reader/LocalTsFileInput.java |  151 -
 .../iotdb/tsfile/read/reader/TsFileInput.java      |  130 -
 .../tsfile/read/reader/chunk/ChunkReader.java      |  238 --
 .../read/reader/chunk/ChunkReaderByTimestamp.java  |   44 -
 .../iotdb/tsfile/read/reader/page/PageReader.java  |  195 --
 .../reader/series/AbstractFileSeriesReader.java    |   92 -
 .../read/reader/series/EmptyFileSeriesReader.java  |   57 -
 .../read/reader/series/FileSeriesReader.java       |   51 -
 .../reader/series/FileSeriesReaderByTimestamp.java |  154 -
 .../java/org/apache/iotdb/tsfile/utils/Binary.java |  121 -
 .../org/apache/iotdb/tsfile/utils/BloomFilter.java |  144 -
 .../org/apache/iotdb/tsfile/utils/BytesUtils.java  |  877 ------
 .../java/org/apache/iotdb/tsfile/utils/Loader.java |   56 -
 .../apache/iotdb/tsfile/utils/Murmur128Hash.java   |  184 --
 .../java/org/apache/iotdb/tsfile/utils/Pair.java   |   83 -
 .../org/apache/iotdb/tsfile/utils/PublicBAOS.java  |   89 -
 .../iotdb/tsfile/utils/RamUsageEstimator.java      |  926 ------
 .../tsfile/utils/ReadWriteForEncodingUtils.java    |  341 ---
 .../iotdb/tsfile/utils/ReadWriteIOUtils.java       |  910 ------
 .../apache/iotdb/tsfile/utils/StringContainer.java |  388 ---
 .../apache/iotdb/tsfile/utils/TsPrimitiveType.java |  465 ---
 .../tsfile/v2/file/footer/ChunkGroupFooterV2.java  |   87 -
 .../iotdb/tsfile/v2/file/header/ChunkHeaderV2.java |  113 -
 .../iotdb/tsfile/v2/file/header/PageHeaderV2.java  |   49 -
 .../tsfile/v2/file/metadata/ChunkMetadataV2.java   |   51 -
 .../v2/file/metadata/MetadataIndexEntryV2.java     |   35 -
 .../v2/file/metadata/MetadataIndexNodeV2.java      |   45 -
 .../v2/file/metadata/TimeseriesMetadataV2.java     |   43 -
 .../tsfile/v2/file/metadata/TsFileMetadataV2.java  |   76 -
 .../v2/file/metadata/statistics/StatisticsV2.java  |  104 -
 .../tsfile/v2/read/TsFileSequenceReaderForV2.java  |  623 ----
 .../tsfile/v2/read/reader/page/PageReaderV2.java   |   94 -
 .../apache/iotdb/tsfile/write/TsFileWriter.java    |  365 ---
 .../tsfile/write/chunk/ChunkGroupWriterImpl.java   |  168 --
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |  460 ---
 .../tsfile/write/chunk/IChunkGroupWriter.java      |   91 -
 .../iotdb/tsfile/write/chunk/IChunkWriter.java     |   90 -
 .../apache/iotdb/tsfile/write/page/PageWriter.java |  291 --
 .../apache/iotdb/tsfile/write/record/TSRecord.java |   82 -
 .../apache/iotdb/tsfile/write/record/Tablet.java   |  235 --
 .../write/record/datapoint/BooleanDataPoint.java   |   62 -
 .../tsfile/write/record/datapoint/DataPoint.java   |  150 -
 .../write/record/datapoint/DoubleDataPoint.java    |   62 -
 .../write/record/datapoint/FloatDataPoint.java     |   62 -
 .../write/record/datapoint/IntDataPoint.java       |   62 -
 .../write/record/datapoint/LongDataPoint.java      |   62 -
 .../write/record/datapoint/StringDataPoint.java    |   63 -
 .../tsfile/write/schema/MeasurementSchema.java     |  326 ---
 .../apache/iotdb/tsfile/write/schema/Schema.java   |  108 -
 .../tsfile/write/schema/TimeseriesSchema.java      |  273 --
 .../write/writer/ForceAppendTsFileWriter.java      |   86 -
 .../iotdb/tsfile/write/writer/IDataWriter.java     |   21 -
 .../tsfile/write/writer/LocalTsFileOutput.java     |   89 -
 .../write/writer/RestorableTsFileIOWriter.java     |  244 --
 .../iotdb/tsfile/write/writer/TsFileIOWriter.java  |  460 ---
 .../iotdb/tsfile/write/writer/TsFileOutput.java    |   91 -
 .../apache/iotdb/tsfile/common/LRUCacheTest.java   |   55 -
 .../apache/iotdb/tsfile/compress/CompressTest.java |  106 -
 .../org/apache/iotdb/tsfile/compress/GZIPTest.java |   89 -
 .../org/apache/iotdb/tsfile/compress/LZ4Test.java  |   68 -
 .../apache/iotdb/tsfile/compress/SnappyTest.java   |   86 -
 .../apache/iotdb/tsfile/constant/TestConstant.java |   30 -
 .../iotdb/tsfile/encoding/SDTEncoderTest.java      |  177 --
 .../tsfile/encoding/bitpacking/IntPackerTest.java  |   79 -
 .../tsfile/encoding/bitpacking/LongPackerTest.java |  131 -
 .../tsfile/encoding/decoder/BitmapDecoderTest.java |   97 -
 .../tsfile/encoding/decoder/FloatDecoderTest.java  |  233 --
 .../encoding/decoder/GorillaDecoderV1Test.java     |  258 --
 .../encoding/decoder/GorillaDecoderV2Test.java     |  594 ----
 .../tsfile/encoding/decoder/IntRleDecoderTest.java |  218 --
 .../encoding/decoder/LongRleDecoderTest.java       |  221 --
 .../delta/DeltaBinaryEncoderIntegerTest.java       |  110 -
 .../decoder/delta/DeltaBinaryEncoderLongTest.java  |  201 --
 .../regular/RegularDataEncoderIntegerTest.java     |  157 -
 .../regular/RegularDataEncoderLongTest.java        |  252 --
 .../iotdb/tsfile/file/header/PageHeaderTest.java   |  108 -
 .../file/metadata/MetadataIndexNodeTest.java       |   50 -
 .../file/metadata/TimeSeriesMetadataTest.java      |  110 -
 .../tsfile/file/metadata/TsFileMetadataTest.java   |  106 -
 .../metadata/statistics/BooleanStatisticsTest.java |   83 -
 .../metadata/statistics/DoubleStatisticsTest.java  |   94 -
 .../metadata/statistics/FloatStatisticsTest.java   |   94 -
 .../metadata/statistics/IntegerStatisticsTest.java |   93 -
 .../metadata/statistics/LongStatisticsTest.java    |  121 -
 .../metadata/statistics/StringStatisticsTest.java  |   85 -
 .../tsfile/file/metadata/utils/TestHelper.java     |   73 -
 .../iotdb/tsfile/file/metadata/utils/Utils.java    |  170 --
 .../apache/iotdb/tsfile/read/ExpressionTest.java   |   61 -
 .../iotdb/tsfile/read/GetAllDevicesTest.java       |   85 -
 ...easurementChunkMetadataListMapIteratorTest.java |  197 --
 .../iotdb/tsfile/read/ReadInPartitionTest.java     |  230 --
 .../iotdb/tsfile/read/ReadOnlyTsFileTest.java      |  168 --
 .../org/apache/iotdb/tsfile/read/ReadTest.java     |  386 ---
 .../iotdb/tsfile/read/TimePlainEncodeReadTest.java |  379 ---
 .../tsfile/read/TimeSeriesMetadataReadTest.java    |   89 -
 .../tsfile/read/TsFileRestorableReaderTest.java    |   65 -
 .../tsfile/read/TsFileSequenceReaderTest.java      |  128 -
 .../iotdb/tsfile/read/common/BatchDataTest.java    |   82 -
 .../apache/iotdb/tsfile/read/common/FieldTest.java |   32 -
 .../apache/iotdb/tsfile/read/common/PathTest.java  |   49 -
 .../iotdb/tsfile/read/common/TimeRangeTest.java    |  432 ---
 .../tsfile/read/controller/ChunkLoaderTest.java    |   66 -
 .../controller/IMetadataQuerierByFileImplTest.java |  150 -
 .../tsfile/read/filter/FilterSerializeTest.java    |  100 -
 .../tsfile/read/filter/GroupByFilterTest.java      |  122 -
 .../tsfile/read/filter/GroupByMonthFilterTest.java |  226 --
 .../read/filter/IExpressionOptimizerTest.java      |  260 --
 .../read/filter/MinTimeMaxTimeFilterTest.java      |  214 --
 .../iotdb/tsfile/read/filter/OperatorTest.java     |  176 --
 .../tsfile/read/filter/StatisticsFilterTest.java   |  108 -
 .../read/query/executor/QueryExecutorTest.java     |  156 -
 .../tsfile/read/query/timegenerator/NodeTest.java  |  100 -
 .../read/query/timegenerator/ReadWriteTest.java    |  183 --
 .../query/timegenerator/ReaderByTimestampTest.java |  109 -
 .../timegenerator/TimeGeneratorReadEmptyTest.java  |  146 -
 .../timegenerator/TimeGeneratorReadWriteTest.java  |  182 --
 .../query/timegenerator/TimeGeneratorTest.java     |   90 -
 .../TsFileGeneratorForSeriesReaderByTimestamp.java |  267 --
 .../iotdb/tsfile/read/reader/FakedBatchReader.java |   55 -
 .../tsfile/read/reader/FakedMultiBatchReader.java  |   59 -
 .../tsfile/read/reader/FakedTimeGenerator.java     |   76 -
 .../iotdb/tsfile/read/reader/PageReaderTest.java   |  315 ---
 .../iotdb/tsfile/read/reader/ReaderTest.java       |  135 -
 .../apache/iotdb/tsfile/utils/BloomFilterTest.java |   66 -
 .../apache/iotdb/tsfile/utils/BytesUtilsTest.java  |  383 ---
 .../apache/iotdb/tsfile/utils/FileGenerator.java   |  312 --
 .../org/apache/iotdb/tsfile/utils/FileUtils.java   |   83 -
 .../apache/iotdb/tsfile/utils/FileUtilsTest.java   |   51 -
 .../org/apache/iotdb/tsfile/utils/PairTest.java    |   72 -
 .../utils/ReadWriteForEncodingUtilsTest.java       |   55 -
 .../iotdb/tsfile/utils/ReadWriteIOUtilsTest.java   |  140 -
 .../tsfile/utils/ReadWriteStreamUtilsTest.java     |  157 -
 .../tsfile/utils/ReadWriteToBytesUtilsTest.java    |   66 -
 .../org/apache/iotdb/tsfile/utils/RecordUtils.java |  113 -
 .../apache/iotdb/tsfile/utils/RecordUtilsTest.java |  186 --
 .../iotdb/tsfile/utils/StringContainerTest.java    |  175 --
 .../iotdb/tsfile/utils/TsFileGeneratorForTest.java |  250 --
 .../iotdb/tsfile/utils/TsPrimitiveTypeTest.java    |   60 -
 .../tsfile/write/DefaultDeviceTemplateTest.java    |  109 -
 .../org/apache/iotdb/tsfile/write/PerfTest.java    |  234 --
 .../iotdb/tsfile/write/ReadPageInMemTest.java      |  189 --
 ...SameMeasurementsWithDifferentDataTypesTest.java |  212 --
 .../iotdb/tsfile/write/TsFileIOWriterTest.java     |  122 -
 .../iotdb/tsfile/write/TsFileReadWriteTest.java    |  251 --
 .../iotdb/tsfile/write/TsFileWriterTest.java       |  314 --
 .../org/apache/iotdb/tsfile/write/WriteTest.java   |  284 --
 .../write/schema/converter/SchemaBuilderTest.java  |  127 -
 .../write/writer/ForceAppendTsFileWriterTest.java  |  121 -
 .../writer/MeasurementSchemaSerializeTest.java     |   57 -
 .../iotdb/tsfile/write/writer/PageWriterTest.java  |  219 --
 .../write/writer/RestorableTsFileIOWriterTest.java |  467 ---
 tsfile/src/test/resources/logback.xml              |  124 -
 zeppelin-interpreter/IoTDB-Zeppelin-Demo.zpln      |  377 ---
 zeppelin-interpreter/pom.xml                       |  151 -
 .../apache/zeppelin/iotdb/IoTDBInterpreter.java    |  296 --
 .../src/main/resources/interpreter-setting.json    |   70 -
 .../zeppelin/iotdb/IoTDBInterpreterTest.java       |  382 ---
 2262 files changed, 383884 deletions(-)

diff --git a/Jenkinsfile b/Jenkinsfile
deleted file mode 100644
index f1f57b3..0000000
--- a/Jenkinsfile
+++ /dev/null
@@ -1,210 +0,0 @@
-#!groovy
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-pipeline {
-
-    agent {
-        node {
-            label 'ubuntu'
-        }
-    }
-
-    environment {
-        // Testfails will be handled by the jenkins junit steps and mark the build as unstable.
-        MVN_TEST_FAIL_IGNORE = '-Dmaven.test.failure.ignore=true'
-    }
-
-    tools {
-        maven 'maven_3_latest'
-        jdk 'jdk_11_latest'
-    }
-
-    options {
-        timeout(time: 1, unit: 'HOURS')
-        // When we have test-fails e.g. we don't need to run the remaining steps
-        skipStagesAfterUnstable()
-    }
-
-    stages {
-        stage('Initialization') {
-            steps {
-                echo 'Building Branch: ' + env.BRANCH_NAME
-                echo 'Using PATH = ' + env.PATH
-            }
-        }
-
-        stage('Checkout') {
-            steps {
-                echo 'Checking out branch ' + env.BRANCH_NAME
-                checkout scm
-            }
-        }
-
-        stage('Build (not master)') {
-            when {
-                expression {
-                    env.BRANCH_NAME != 'master'
-                }
-            }
-            steps {
-                echo 'Building'
-                sh 'mvn ${MVN_TEST_FAIL_IGNORE} ${MVN_LOCAL_REPO_OPT} clean install'
-            }
-            post {
-                always {
-                    junit(testResults: '**/surefire-reports/*.xml', allowEmptyResults: true)
-                    junit(testResults: '**/failsafe-reports/*.xml', allowEmptyResults: true)
-                }
-            }
-        }
-
-        stage('Build') {
-            when {
-                branch 'master'
-            }
-            steps {
-                echo 'Building'
-                sh 'mvn clean'
-                // We'll deploy to a relative directory so we can
-                // deploy new versions only if the entire build succeeds
-                sh 'mvn ${MVN_TEST_FAIL_IGNORE} -DaltDeploymentRepository=snapshot-repo::default::file:./local-snapshots-dir -P client-cpp clean deploy -P get-jar-with-dependencies'
-            }
-            post {
-                always {
-                    junit(testResults: '**/surefire-reports/*.xml', allowEmptyResults: true)
-                    junit(testResults: '**/failsafe-reports/*.xml', allowEmptyResults: true)
-                }
-            }
-        }
-
-        stage('Code Quality') {
-            when {
-                branch 'master'
-            }
-            steps {
-                echo 'Checking Code Quality on SonarCloud'
-                // Main parameters
-                script {
-                    // Then run the analysis
-                    // 'my-sonarcloud-token' needs to be defined for this job and contains the user token
-                    withCredentials([string(credentialsId: 'xiangdong-iotdb-sonarcloud-token', variable: 'SONAR_TOKEN')]) {
-                        sh "mvn verify sonar:sonar -Dsonar.branch.name=master -Dsonar.host.url=https://sonarcloud.io -Dsonar.organization=apache -Dsonar.projectKey=apache_incubator-iotdb -Dsonar.login=${SONAR_TOKEN} -DskipTests"
-                    }
-                }
-            }
-        }
-
-
-        stage('Deploy') {
-            when {
-                branch 'master'
-            }
-            steps {
-                echo 'Deploying'
-                // Deploy the artifacts using the wagon-maven-plugin.
-                sh 'mvn -f jenkins.pom -X -P deploy-snapshots -P client-cpp wagon:upload -P get-jar-with-dependencies'
-            }
-        }
-
-        stage('Deploy site') {
-            when {
-                branch 'master'
-            }
-            // Only the nodes labeled 'git-websites' have the credentials to commit to the.
-            agent {
-                node {
-                    label 'git-websites'
-                }
-            }
-            steps {
-                // Publish the site with the scm-publish plugin.
-                sh 'mvn -P site -P compile-site -P compile-site-0.12 -P compile-site-0.11 -P compile-site-0.10 -P compile-site-0.9 -P compile-site-0.8 compile scm-publish:publish-scm -pl site'
-
-                // Clean up the snapshots directory (freeing up more space after deploying).
-                dir("target") {
-                    deleteDir()
-                }
-            }
-        }
-
-        stage('Cleanup') {
-            steps {
-                echo 'Cleaning up the workspace'
-                deleteDir()
-            }
-        }
-    }
-
-    // Send out notifications on unsuccessful builds.
-    post {
-        // If this build failed, send an email to the list.
-        failure {
-            script {
-                if(env.BRANCH_NAME == "master") {
-                    emailext(
-                        subject: "[BUILD-FAILURE]: Job '${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]'",
-                        body: """
-BUILD-FAILURE: Job '${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]':
-
-Check console output at "<a href="${env.BUILD_URL}">${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]</a>"
-""",
-                        to: "dev@iotdb.apache.org"
-                    )
-                }
-            }
-        }
-
-        // If this build didn't fail, but there were failing tests, send an email to the list.
-        unstable {
-            script {
-                if(env.BRANCH_NAME == "master") {
-                    emailext(
-                        subject: "[BUILD-UNSTABLE]: Job '${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]'",
-                        body: """
-BUILD-UNSTABLE: Job '${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]':
-
-Check console output at "<a href="${env.BUILD_URL}">${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]</a>"
-""",
-                        to: "dev@iotdb.apache.org"
-                    )
-                }
-            }
-        }
-
-        // Send an email, if the last build was not successful and this one is.
-        success {
-            script {
-                if ((env.BRANCH_NAME == "master") && (currentBuild.previousBuild != null) && (currentBuild.previousBuild.result != 'SUCCESS')) {
-                    emailext (
-                        subject: "[BUILD-STABLE]: Job '${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]'",
-                        body: """
-BUILD-STABLE: Job '${env.JOB_NAME} [${env.BRANCH_NAME}] [${env.BUILD_NUMBER}]':
-
-Is back to normal.
-""",
-                        to: "dev@iotdb.apache.org"
-                    )
-                }
-            }
-        }
-    }
-
-}
\ No newline at end of file
diff --git a/LICENSE b/LICENSE
deleted file mode 100644
index d84f2bd..0000000
--- a/LICENSE
+++ /dev/null
@@ -1,236 +0,0 @@
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
-
---------------------------------------------------------------------------------
-                           APACHE IOTDB SUBCOMPONENTS
---------------------------------------------------------------------------------
-
-The following class is copied from maven-wrapper (https://github.com/takari/maven-wrapper),
-which is under Apache License 2.0:
-
-./.mvn/wrapper/MavenWrapperDownloader.java
-
---------------------------------------------------------------------------------
-
-The following class is modified from Apache commons-collections
-
-./tsfile/src/main/java/org/apache/iotdb/tsfile/utils/Murmur128Hash.java
-Relevant pr is: https://github.com/apache/commons-collections/pull/83/
-
---------------------------------------------------------------------------------
-
-The following files include code modified from Michael Burman's gorilla-tsc project.
-
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/GorillaEncoderV2.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/IntGorillaEncoder.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/LongGorillaEncoder.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/SinglePrecisionEncoderV2.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/encoder/DoublePrecisionEncoderV2.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/GorillaDecoderV2.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/IntGorillaDecoder.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/LongGorillaDecoder.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/SinglePrecisionDecoderV2.java
-./tsfile/src/main/java/org/apache/iotdb/tsfile/encoding/decoder/DoublePrecisionDecoderV2.java
-
-Copyright: 2016-2018 Michael Burman and/or other contributors
-Project page: https://github.com/burmanm/gorilla-tsc
-License: http://www.apache.org/licenses/LICENSE-2.0
diff --git a/LICENSE-binary b/LICENSE-binary
deleted file mode 100644
index cc1b475..0000000
--- a/LICENSE-binary
+++ /dev/null
@@ -1,306 +0,0 @@
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
-
-
-================================================================
-APACHE IOTDB SUBCOMPONENTS:
-
-Apache IoTDB project includes a number of submodules with separate copyright notices
-and license terms. Your use of these submodules is subject to the terms and
-conditions of the following licenses.
-
-================================================================
-
-The binary distribution of this product bundles these dependencies under the
-following license. See licenses/ for text of these licenses.
-
-Apache Software Foundation License 2.0
---------------------------------------
-commons-cli:commons-cli:1.3.1
-commons-codec:commons-codec:1.13
-org.apache.commons:commons-collections4:4.0
-commons-io:commons-io:2.5
-org.apache.commons:commons-lang3:3.8.1
-commons-lang:commons-lang:2.6
-com.nimbusds:content-type:2.0
-com.google.code.gson:gson:2.8.6
-com.google.guava.guava:24.1.1
-com.fasterxml.jackson.core:jackson-annotations:2.10.0
-com.fasterxml.jackson.core:jackson-core:2.10.0
-com.fasterxml.jackson.core:jackson-databind:2.10.0
-javax.inject:javax.inject:1
-net.jpountz.lz4:1.3.0
-com.github.stephenc.jcip:jcip-annotations:1.0-1
-org.eclipse.jetty:jetty-http:9.4.24.v20191120
-org.eclipse.jetty:jetty-io:9.4.24.v20191120
-org.eclipse.jetty:jetty-security:9.4.24.v20191120
-org.eclipse.jetty:jetty-server:9.4.24.v20191120
-org.eclipse.jetty:jetty-servlet:9.4.24.v20191120
-org.eclipse.jetty:jetty-util:9.4.24.v20191120
-org.eclipse.jetty:jetty-webapp:9.4.24.v20191120
-org.eclipse.jetty:jetty-xml:9.4.24.v20191120
-io.jsonwebtoken:jjwt-api:0.10.7
-io.jsonwebtoken:jjwt-impl:0.10.7
-io.jsonwebtoken:jjwt-jackson:0.10.7
-net.minidev:json-smart:2.3
-com.google.code.findbugs:jsr305:3.0.2
-com.nimbusds:lang-tag:1.4.4
-com.librato.metrics:librato-java:2.1.0
-org.apache.thrift:libthrift:0.13.0
-io.dropwizard.metrics:metrics-core:3.2.6
-io.dropwizard.metrics:metrics-json:3.2.6
-io.dropwizard.metrics:metrics-jvm:3.2.6
-com.librato.metrics:metrics-librato:5.1.0
-io.moquette:moquette-broker:0.13
-io.netty:netty-buffer:4.1.27.Final
-io.netty:netty-codec:4.1.27.Final
-io.netty:netty-codec-http:4.1.27.Final
-io.netty:netty-codec-mqtt:4.1.27.Final
-io.netty:netty-common:4.1.27.Final
-io.netty:netty-handler:4.1.27.Final
-io.netty:netty-resolver:4.1.27.Final
-io.netty:netty-transport:4.1.27.Final
-io.netty:netty-transport-native-epoll:4.1.27.Final:linux-x86_64
-io.netty:netty-transport-native-unix-common:4.1.27.Final
-com.nimbusds:nimbus-jose-jwt:8.14.1
-com.nimbusds:oauth2-oidc-sdk:8.3
-org.osgi:org.osgi.core:6.0.0
-org.osgi:osgi.cmpn:6.0.0
-org.ops4j.pax.jdbc:pax-jdbc-common:1.4.5
-org.xerial.snappy:snappy-java:1.1.7.2
-io.airlift.airline:0.8
-net.minidev:accessors-smart:1.2
-
-
-BSD 2-Clause
-------------
-jline:jline:2.14.5
-
-
-BSD 3-Clause
-------------
-org.antlr:antlr-runtime:4.8-1
-org.ow2.asm:asm:5.0.4
-org.jline:jline:3.10.0
-
-
-MIT License
-------------
-org.slf4j:slf4j-api
-me.tongfei:progressbar:0.7.3
-com.bugsnag:bugsnag:3.6.1
-org.slf4j:jcl-over-slf4j:1.7.25
-
-
-EPL 1.0
-------------
-com.h2database:h2-mvstore:1.4.199
-ch.qos.logback:logback-classic:1.2.3
-ch.qos.logback:logback-core:1.2.3
-
-
-CDDL 1.1
-------------
-javax.annotation:javax.annotation-api:1.3.2
-javax.servlet:javax.servlet-api:3.1.0
-javax.xml.bind:jaxb-api:2.4.0-b180725.0427
-org.glassfish.jaxb:jaxb-runtime:2.4.0-b180725.0644
\ No newline at end of file
diff --git a/NOTICE b/NOTICE
deleted file mode 100644
index e983e45..0000000
--- a/NOTICE
+++ /dev/null
@@ -1,24 +0,0 @@
-Apache IoTDB
-Copyright 2018-2021 The Apache Software Foundation.
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).
-
-============================================================================
-
-IoTDB project uses 4 Chinese Patents:
-* 201711384490X
-* 201810111712.9
-* 201711322631.5
-* 201711319331.1
-
-According to the Apache 2.0 License. The owner of the patents, Tsinghua University,
-grant the users the right to the use of patent under the requirement of Apache 2.0 License.
-
-============================================================================
-
-Apache Commons Collections
-Copyright 2001-2019 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).
\ No newline at end of file
diff --git a/NOTICE-binary b/NOTICE-binary
deleted file mode 100644
index e983e45..0000000
--- a/NOTICE-binary
+++ /dev/null
@@ -1,24 +0,0 @@
-Apache IoTDB
-Copyright 2018-2021 The Apache Software Foundation.
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).
-
-============================================================================
-
-IoTDB project uses 4 Chinese Patents:
-* 201711384490X
-* 201810111712.9
-* 201711322631.5
-* 201711319331.1
-
-According to the Apache 2.0 License. The owner of the patents, Tsinghua University,
-grant the users the right to the use of patent under the requirement of Apache 2.0 License.
-
-============================================================================
-
-Apache Commons Collections
-Copyright 2001-2019 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).
\ No newline at end of file
diff --git a/README.md b/README.md
deleted file mode 100644
index 388e4bd..0000000
--- a/README.md
+++ /dev/null
@@ -1,35 +0,0 @@
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-
-
-
-# Compaction Policy Tuning Extension
-This is an extension of IoTDB, which implements the compaction policy tuning module. To use the module, several parameters of IoTDB should be considered. The introduction of IoTDB can be found [here](https://github.com/apache/iotdb.git).
-
-```aidl
-enable_separation_tuning=true   # to enable the tuning algorithm
-delay_num = 10000               # the size of delay set to analyze
-total_capacity=512              # the capacity of the MemTable
-```
-
-The tuning server should be started before the database, which is  "separation_py/SeparationServer.py". The default IP is "127.0.0.1", and the default port is "8989".
-
-When running IoTDB, a tuning client would be started, which is org.apache.iotdb.db.separation.statistics.SeparationTuningClient. It will constantly send the collected delay samples to the server and tune the compaction policy accordingly.
\ No newline at end of file
diff --git a/README_ZH.md b/README_ZH.md
deleted file mode 100644
index b27fc9d..0000000
--- a/README_ZH.md
+++ /dev/null
@@ -1,374 +0,0 @@
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-[English](./README.md) | [中文](./README_ZH.md)
-
-# IoTDB
-[![Build Status](https://www.travis-ci.org/apache/iotdb.svg?branch=master)](https://www.travis-ci.org/apache/iotdb)
-[![coveralls](https://coveralls.io/repos/github/apache/iotdb/badge.svg?branch=master)](https://coveralls.io/repos/github/apache/iotdb/badge.svg?branch=master)
-[![GitHub release](https://img.shields.io/github/release/apache/iotdb.svg)](https://github.com/apache/iotdb/releases)
-[![License](https://img.shields.io/badge/license-Apache%202-4EB1BA.svg)](https://www.apache.org/licenses/LICENSE-2.0.html)
-![](https://github-size-badge.herokuapp.com/apache/iotdb.svg)
-![](https://img.shields.io/github/downloads/apache/iotdb/total.svg)
-![](https://img.shields.io/badge/platform-win10%20%7C%20macox%20%7C%20linux-yellow.svg)
-![](https://img.shields.io/badge/java--language-1.8-blue.svg)
-[![Language grade: Java](https://img.shields.io/lgtm/grade/java/g/apache/iotdb.svg?logo=lgtm&logoWidth=18)](https://lgtm.com/projects/g/apache/iotdb/context:java)
-[![IoTDB Website](https://img.shields.io/website-up-down-green-red/https/shields.io.svg?label=iotdb-website)](https://iotdb.apache.org/)
-[![Maven Version](https://maven-badges.herokuapp.com/maven-central/org.apache.iotdb/iotdb-parent/badge.svg)](http://search.maven.org/#search|gav|1|g:"org.apache.iotdb")
-
-# 简介
-IoTDB (Internet of Things Database) 是一个时序数据的数据管理系统,可以为用户提供数据收集、存储和分析等特定的服务。IoTDB由于其轻量级的结构、高性能和可用的特性,以及与Hadoop和Spark生态的无缝集成,满足了工业IoTDB领域中海量数据存储、高吞吐量数据写入和复杂数据分析的需求。
-
-# 主要特点
-
-IoTDB的主要特点如下:
-
-1. 灵活的部署策略。IoTDB为用户提供了一个在云平台或终端设备上的一键安装工具,以及一个连接云平台和终端上的数据的数据同步工具。
-2. 硬件成本低。IoTDB可以达到很高的磁盘存储压缩比。
-3. 高效的目录结构。IoTDB支持智能网络设备对复杂时间序列数据结构的高效组织,同类设备对时间序列数据的组织,海量复杂时间序列数据目录的模糊搜索策略。
-4. 高吞吐量读写。IoTDB支持数以百万计的低功耗设备的强连接数据访问、高速数据读写,适用于上述智能网络设备和混合设备。
-5. 丰富的查询语义。IoTDB支持跨设备和测量的时间序列数据的时间对齐、时间序列字段的计算(频域转换)和时间维度的丰富聚合函数支持。
-6. 学习成本非常低。IoTDB支持类似sql的语言、JDBC标准API和易于使用的导入/导出工具。
-7. 与先进的开放源码生态系统的无缝集成。IoTDB支持分析生态系统,如Hadoop、Spark和可视化工具(如Grafana)。
-
-有关IoTDB的最新信息,请访问[IoTDB官方网站](https://iotdb.apache.org/)。如果您在使用IoTDB时遇到任何问题或发现任何bug,请在[jira]中提交(https://issues.apache.org/jira/projects/IOTDB/issues)。
-
-<!-- TOC -->
-
-## 目录
-
-- [IoTDB](#iotdb)
-- [简介](#简介)
-- [主要特点](#主要特点)
-  - [目录](#目录)
-- [快速开始](#快速开始)
-  - [环境准备](#环境准备)
-  - [安装](#安装)
-    - [从源码构建](#从源码构建)
-      - [配置](#配置)
-  - [开始](#开始)
-    - [启动 IoTDB](#启动-iotdb)
-    - [使用 IoTDB](#使用-iotdb)
-      - [使用 Cli 命令行](#使用-cli-命令行)
-      - [基本的 IoTDB 命令](#基本的-iotdb-命令)
-    - [停止 IoTDB](#停止-iotdb)
-  - [只编译 server](#只编译-server)
-  - [只编译 cli](#只编译-cli)
-  - [导入导出CSV工具](#导入导出CSV工具)
-
-<!-- /TOC -->
-
-# 快速开始
-
-这篇简短的指南将带您了解使用IoTDB的基本过程。如需更详细的介绍,请访问我们的网站[用户指南](http://iotdb.apache.org/zh/UserGuide/Master/Get%20Started/QuickStart.html)。
-
-## 环境准备
-
-要使用IoTDB,您需要:
-1. Java >= 1.8 (目前 1.8、11和13 已经被验证可用。请确保环变量境路径已正确设置)。
-2. Maven >= 3.6 (如果希望从源代码编译和安装IoTDB)。
-3. 设置 max open files 为 65535,以避免"too many open files"错误。
-
-## 安装
-
-IoTDB提供了三种安装方法,您可以参考以下建议,选择最适合您的一种:
-
-* 从源代码安装。如果需要自己修改代码,可以使用此方法。
-
-* 从二进制文件安装。推荐的方法是从官方网站下载二进制文件,您将获得一个开箱即用的二进制发布包。
-
-* 使用Docker: dockerfile的路径是https://github.com/apache/iotdb/tree/master/docker/src/main
-
-在这篇《快速入门》中,我们简要介绍如何使用源代码安装IoTDB。如需进一步资料,请参阅《用户指南》第3章。
-
-## 从源码构建
-
-### 关于准备Thrift编译器
-
-如果您使用Windows,请跳过此段。
-
-我们使用Thrift作为RPC模块来提供客户端-服务器间的通信和协议支持,因此在编译阶段我们需要使用Thrift 0.13.0
-(或更高)编译器生成对应的Java代码。 Thrift只提供了Windows下的二进制编译器,Unix下需要通过源码自行编译。
-
-如果你有安装权限,可以通过`apt install`, `yum install`, `brew install`来安装thrift编译器,然后在下面的编译命令中
-都添加如下参数即可:`-Dthrift.download-url=http://apache.org/licenses/LICENSE-2.0.txt -Dthrift.exec.absolute.path=<你的thrift可执行文件路径>`。
-
-
-同时我们预先编译了一个Thrift编译器,并将其上传到了GitHub ,借助一个Maven插件,在编译时可以自动将其下载。
-该预编译的Thrift编译器在gcc8,Ubuntu, CentOS, MacOS下可以工作,但是在更低的gcc
-版本以及其他操作系统上尚未确认。
-如果您发现因为网络问题总是提示下载不到thrift文件,那么您需要手动下载,并并将编译器放置到目录`{project_root}\thrift\target\tools\thrift_0.12.0_0.13.0_linux.exe`。
-如果您放到其他地方,就需要在运行maven的命令中添加:`-Dthrift.download-url=http://apache.org/licenses/LICENSE-2.0.txt -Dthrift.exec.absolute.path=<你的thrift可执行文件路径>`。
-
-如果您对Maven足够熟悉,您也可以直接修改我们的根pom文件来避免每次编译都使用上述参数。
-Thrift官方网址为:https://thrift.apache.org/
-
-从 git 克隆源代码:
-
-```
-git clone https://github.com/apache/iotdb.git
-```
-
-默认的主分支是dev分支,如果你想使用某个发布版本x.x.x,请切换分支:
-
-```
-git checkout release/x.x.x
-```
-
-从0.11.3开始,版本的标签风格改为vx.x.x:
-```
-git checkout vx.x.x
-```
-
-在 iotdb 根目录下执行 maven 编译:
-
-```
-> mvn clean package -DskipTests
-```
-
-通过添加 `-P compile-cpp` 可以进行c++客户端API的编译。
-
-执行完成之后,可以在**distribution/target/apache-iotdb-{project.version}-all-bin.zip**找到编译完成的二进制版本(包括服务器和客户端)
-
-> 注意:"thrift/target/generated-sources/thrift" 和 "antlr/target/generated-sources/antlr4" 目录需要添加到源代码根中,以免在 IDE 中产生编译错误。
-> IDEA的操作方法:在上述maven命令编译好后,右键项目名称,选择"Maven->Reload project",即可。
-
-### 配置
-
-配置文件在"conf"文件夹下
-* 环境配置模块(`iotdb-env.bat`, `iotdb-env.sh`),
-* 系统配置模块(`iotdb-engine.properties`)
-* 日志配置模块(`logback.xml`)。
-
-有关详细信息,请参见[Chapter3: Server](http://iotdb.apache.org/zh/UserGuide/Master/Server/Config%20Manual.html)。
-
-## 开始
-
-您可以通过以下步骤来测试安装,如果执行后没有返回错误,安装就完成了。
-
-### 启动 IoTDB
-
-可以通过运行 sbin 文件夹下的 start-server 脚本启动 IoTDB。
-
-```
-# Unix/OS X
-> nohup sbin/start-server.sh >/dev/null 2>&1 &
-or
-> nohup sbin/start-server.sh -c <conf_path> -rpc_port <rpc_port> >/dev/null 2>&1 &
-
-# Windows
-> sbin\start-server.bat -c <conf_path> -rpc_port <rpc_port>
-```
-- "-c" and "-rpc_port" 都是可选的。
-- 选项 "-c" 指定了配置文件所在的文件夹。
-- 选项 "-rpc_port" 指定了启动的 rpc port。
-- 如果两个选项同时指定,那么*rpc_port*将会覆盖*conf_path*下面的配置。
-
-### 使用 IoTDB
-
-#### 使用 Cli 命令行
-
-IoTDB提供了与服务器交互的不同方式,这里我们将介绍使用 Cli 工具插入和查询数据的基本步骤。
-
-安装 IoTDB 后,有一个默认的用户`root`,它的默认密码也是`root`。用户可以使用这个
-默认用户登录 Cli 并使用 IoTDB。Cli 的启动脚本是 sbin 文件夹中的 start-cli 脚本。
-在执行脚本时,用户应该指定 IP,端口,USER_NAME 和 密码。默认参数为`-h 127.0.0.1 -p 6667 -u root -pw root`。
-
-
-下面是启动 Cli 的命令:
-
-```
-# Unix/OS X
-> sbin/start-cli.sh -h 127.0.0.1 -p 6667 -u root -pw root
-
-# Windows
-> sbin\start-cli.bat -h 127.0.0.1 -p 6667 -u root -pw root
-```
-
-命令行客户端是交互式的,所以如果一切就绪,您应该看到欢迎标志和声明:
-
-```
- _____       _________  ______   ______
-|_   _|     |  _   _  ||_   _ `.|_   _ \
-  | |   .--.|_/ | | \_|  | | `. \ | |_) |
-  | | / .'`\ \  | |      | |  | | |  __'.
- _| |_| \__. | _| |_    _| |_.' /_| |__) |
-|_____|'.__.' |_____|  |______.'|_______/  version x.x.x
-
-
-IoTDB> login successfully
-IoTDB>
-```
-
-#### 基本的 IoTDB 命令
-
-现在,让我们介绍创建 timeseries、插入数据和查询数据的方法。
-
-
-IoTDB中的数据组织为 timeseries。每个 timeseries 包含多个`数据-时间`对,由一个存储组拥有。
-在定义 timeseries 之前,我们应该先使用SET storage group来定义一个存储组,下面是一个例子:
-
-```
-IoTDB> SET STORAGE GROUP TO root.ln
-```
-
-我们也可以使用`SHOW STORAGE GROUP`来检查正在创建的存储组:
-
-```
-IoTDB> SHOW STORAGE GROUP
-+-----------------------------------+
-|                      Storage Group|
-+-----------------------------------+
-|                            root.ln|
-+-----------------------------------+
-storage group number = 1
-```
-
-在设置存储组之后,我们可以使用CREATE TIMESERIES来创建一个新的TIMESERIES。
-在创建 timeseries 时,我们应该定义它的数据类型和编码方案。这里我们创建两个 timeseries:
-
-
-```
-IoTDB> CREATE TIMESERIES root.ln.wf01.wt01.status WITH DATATYPE=BOOLEAN, ENCODING=PLAIN
-IoTDB> CREATE TIMESERIES root.ln.wf01.wt01.temperature WITH DATATYPE=FLOAT, ENCODING=RLE
-```
-
-为了查询特定的timeseries,我们可以使用 `SHOW TIMESERIES <Path>`. <Path> 表示被查询的 timeseries 的路径. 默认值是`null`, 表示查询系统中所有的 timeseries (同`SHOW TIMESERIES root`). 
-以下是一些示例:
-
-1. 查询系统中所有 timeseries:
-
-```
-IoTDB> SHOW TIMESERIES
-+-------------------------------+------+-------------+--------+--------+-----------+----+----------+
-|                   timeseries  | alias|storage group|dataType|encoding|compression|tags|attributes|
-+-------------------------------+------+-------------+--------+--------+-----------+----+----------+
-|       root.ln.wf01.wt01.status|  null|      root.ln| BOOLEAN|   PLAIN|     SNAPPY|null|      null|
-|  root.ln.wf01.wt01.temperature|  null|      root.ln|   FLOAT|     RLE|     SNAPPY|null|      null|
-+-------------------------------+------+-------------+--------+--------+-----------+----+----------+
-Total timeseries number = 2
-```
-
-2. 查询指定的 timeseries(root.ln.wf01.wt01.status):
-
-```
-IoTDB> SHOW TIMESERIES root.ln.wf01.wt01.status
-+-------------------------------+------+-------------+--------+--------+-----------+----+----------+
-|                   timeseries  | alias|storage group|dataType|encoding|compression|tags|attributes|
-+-------------------------------+------+-------------+--------+--------+-----------+----+----------+
-|       root.ln.wf01.wt01.status|  null|      root.ln| BOOLEAN|   PLAIN|     SNAPPY|null|      null|
-+-------------------------------+------+-------------+--------+--------+-----------+----+----------+
-Total timeseries number = 1
-```
-
-插入 timeseries 数据是IoTDB的一个基本操作,你可以使用`INSERT` 命令来完成这个操作。
-在插入之前,您应该指定时间戳和后缀路径名:
-
-```
-IoTDB> INSERT INTO root.ln.wf01.wt01(timestamp,status) values(100,true);
-IoTDB> INSERT INTO root.ln.wf01.wt01(timestamp,status,temperature) values(200,false,20.71)
-```
-
-你刚才插入的数据会显示如下:
-
-```
-IoTDB> SELECT status FROM root.ln.wf01.wt01
-+-----------------------+------------------------+
-|                   Time|root.ln.wf01.wt01.status|
-+-----------------------+------------------------+
-|1970-01-01T08:00:00.100|                    true|
-|1970-01-01T08:00:00.200|                   false|
-+-----------------------+------------------------+
-Total line number = 2
-```
-
-您还可以使用一条SQL语句查询多个 timeseries 数据:
-
-```
-IoTDB> SELECT * FROM root.ln.wf01.wt01
-+-----------------------+--------------------------+-----------------------------+
-|                   Time|  root.ln.wf01.wt01.status|root.ln.wf01.wt01.temperature|
-+-----------------------+--------------------------+-----------------------------+
-|1970-01-01T08:00:00.100|                      true|                         null|
-|1970-01-01T08:00:00.200|                     false|                        20.71|
-+-----------------------+--------------------------+-----------------------------+
-Total line number = 2
-```
-
-你可以使用如下命令退出:
-
-```
-IoTDB> quit
-or
-IoTDB> exit
-```
-
-有关IoTDB SQL支持的命令的更多信息,请参见[SQL 参考文档](http://iotdb.apache.org/zh/UserGuide/Master/Operation%20Manual/SQL%20Reference.html)。
-
-### 停止 IoTDB
-
-server 可以使用 "ctrl-C" 或者执行下面的脚本:
-
-```
-# Unix/OS X
-> sbin/stop-server.sh
-
-# Windows
-> sbin\stop-server.bat
-```
-
-## 只编译 server
-
-在 iotdb 根目录下执行:
-
-```
-> mvn clean package -pl server -am -DskipTests
-```
-
-编译完成后, IoTDB server 将生成在: "server/target/iotdb-server-{project.version}".
-
-
-## 只编译 cli
-
-在 iotdb 根目录下执行:
-
-```
-> mvn clean package -pl cli -am -DskipTests
-```
-
-编译完成后, IoTDB cli 将生成在 "cli/target/iotdb-cli-{project.version}".
-
-# 导入导出CSV工具
-
-查看 [导入导出CSV工具](https://iotdb.apache.org/zh/UserGuide/Master/System%20Tools/CSV%20Tool.html)
-
-# 常见编译错误
-查看 [常见编译错误](https://iotdb.apache.org/zh/Development/ContributeGuide.html#%E5%B8%B8%E8%A7%81%E7%BC%96%E8%AF%91%E9%94%99%E8%AF%AF)
-
-# 联系我们
-### QQ群
-
-* Apache IoTDB 交流群:659990460
-
-### Wechat Group
-
-* 添加好友 tietouqiao,我们会邀请您进群
-
-获取更多内容,请查看 [加入社区](https://github.com/apache/iotdb/issues/1995) 
diff --git a/RELEASE_NOTES.md b/RELEASE_NOTES.md
deleted file mode 100644
index df16fb9..0000000
--- a/RELEASE_NOTES.md
+++ /dev/null
@@ -1,721 +0,0 @@
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-
-# Apache IoTDB 0.12.0
-
-## New Features
-* [IOTDB-68] New shared-nothing cluster
-* [IOTDB-507] Add zeppelin-interpreter module
-* [IOTDB-825] Aggregation by natural month
-* [IOTDB-890] support SDT lossy compression 
-* [IOTDB-944] Support UDTF (User-defined Timeseries Generating Function)
-* [IOTDB-965] Add timeout parameter for query
-* [IOTDB-1077] Add insertOneDeviceRecords API in java session
-* [IOTDB-1055] Support data compression type GZIP
-* [IOTDB-1024] Support multiple aggregated measurements for group by level statement
-* [IOTDB-1276] Add explain sql support and remove debug_state parameter
-* [IOTDB-1197] Add iotdb-client-go as a git submodule of IoTDB repo
-* [IOTDB-1230] Support spans multi time partitions when loading one TsFile
-* [IOTDB-1273] Feature/restrucutre python module as well as supporting pandas dataframe
-* [IOTDB-1277] support IoTDB as Flink's data source
-* [PR-2605] Add level merge to "merge" command
-
-## Incompatible changes
-* [IOTDB-1081] New TsFile Format
-* [ISSUE-2730] Add the number of unseq merge times in TsFile name.
-
-
-## Miscellaneous changes
-* [IOTDB-868] Change mlog from txt to bin
-* [IOTDB-1069] Restrict the flushing memtable number to avoid OOM when mem_control is disabled
-* [IOTDB-1104] Refactor the error handling process of query exceptions
-* [IOTDB-1108] Add error log to print file name while error happened
-* [IOTDB-1152] Optimize regular data size in traversing
-* [IOTDB-1180] Reset the system log file names and maximal disk-space size
-* [ISSUE-2515] Set fetchsize through JDBC and Session
-* [ISSUE-2598] Throw explicit exception when time series is unknown in where clause
-* [PR-2944] Throw exception when device to be queried is not in TsFileMetaData
-* [PR-2967] Log memory usage information in SystemInfo for better diagnosis
-
-## Bug Fixes
-* [IOTDB-1049] Fix NullpointerException and a delete bug in Last query
-* [IOTDB-1050] Fix Count timeserise column name is wrong
-* [IOTDB-1068] Fix Time series metadata cache bug
-* [IOTDB-1084] Fix temporary memory of flushing may cause OOM
-* [IOTDB-1106] Fix delete timeseries bug
-* [IOTDB-1126] Fix the unseq tsfile delete due to merge
-* [IOTDB-1135] Fix the count timeseries prefix path bug
-* [IOTDB-1137] Fix MNode.getLeafCount error when existing sub-device
-* [ISSUE-2484] Fix creating timeseries error by using "create" or "insert" statement
-* [ISSUE-2545, 2549] Fix unseq merge end time bug
-* [ISSUE-2611] An unsequence file that covers too many sequence file causes OOM query
-* [ISSUE-2688] LRULinkedHashMap does not work as an LRU Cache
-* [ISSUE-2709, 1178] Fix cache not cleared after unseq compaction bug, Fix windows 70,10 ci bug in unseq compaction ci
-* [ISSUE-2741] getObject method in JDBC should return an Object
-* [ISSUE-2746] Fix data overlapped bug after unseq compaction
-* [ISSUE-2758] NullPointerException in QueryTimeManager.checkQueryAlive()
-* [ISSUE-2905] Fix Files.deleteIfExists() doesn't work for HDFS file
-* [ISSUE-2919] Fix C++ client memory leak bug
-* [PR-2613] Fix importCSVTool import directory bug & encode bug
-* [PR-2409] Fix import csv which can't import time format str
-* [PR-2582] Fix sync bug for tsfiles's directory changed by vitural storage group
-* [ISSUE-2911] Fix The write stream is not closed when executing the command 'tracing off'
-
-
-# Apache IoTDB 0.11.3
-
-## Bug Fixes
-* ISSUE-2505 ignore PathNotExistException in recover and change recover error to warn
-* IOTDB-1119 Fix C++ SessionDataSet bug when reading value buffer
-* Fix SessionPool does not recycle session and can not offer new Session due to RunTimeException
-* ISSUE-2588 Fix dead lock between deleting data and querying in parallel
-* ISSUE-2546 Fix first chunkmetadata should be consumed first
-* IOTDB-1126 Fix unseq tsfile is deleted due to compaction
-* IOTDB-1137 MNode.getLeafCount error when existing sub-device
-* ISSUE-2624 ISSUE-2625 Avoid OOM if user don't close Statement and Session manually
-* ISSUE-2639 Fix possible NPE during end query process
-* Alter IT for An error is reported and the system is suspended occasionally
-* IOTDB-1149 print error for -e param when set maxPRC<=0
-* IOTDB-1247 Fix the insert blocked caused the bugs in mem control module
-* ISSUE-2648 Last query not right when having multiple devices
-* Delete mods files after compaction
-* ISSUE-2687 fix insert NaN bug
-* ISSUE-2598 Throw explicit exception when time series is unknown in where clause
-* Fix timeseriesMetadata cache is not cleared after the TsFile is deleted by a compaction
-* ISSUE-2611 An unsequence file that covers too many sequence file causes OOM query
-* IOTDB-1135 Fix count timeseries bug when the paths are nested
-* ISSUE-2709 IOTDB-1178 Fix cache is not cleared after compaction
-* ISSUE-2746 Fix data overlapped bug after the elimination unseq compaction process
-* Fix getObject method in JDBC should return an Object
-* IOTDB-1188 Fix IoTDB 0.11 unable to delete data bug
-* Fix when covering a tsfile resource with HistoricalVersion = null, it’ll throw a NPE
-* fix the elimination unseq compaction may loss data bug after a delete operation is executed
-* Fix a bug of checking time partition in DeviceTimeIndex
-* Throw exeception when device to be queried is not in tsFileMetaData
-* Fix unseq compaction file selector conflicts with time partition bug
-* Fix high CPU usage during the compaction process
-
-## Improvements
-* IOTDB-1140 optimize regular data encoding
-* Add more log for better tracing
-* Add backgroup exec for cli -e function
-* Add max direct memory size parameter to env.sh
-* Change last cache log to debug level
-
-## New Features
-* Add explain sql support
-
-
-# Apache IoTDB 0.11.2
-
-## Bug Fixes
-* IOTDB-1049 Fix Nullpointer exception and a delete bug in Last query
-* IOTDB-1060 Support full deletion for delete statement without where clause
-* IOTDB-1068 Fix Time series metadata cache bug
-* IOTDB-1069 restrict the flushing memtable number to avoid OOM when mem_control is disabled
-* IOTDB-1077 add insertOneDeviceRecords API in java session
-* IOTDB-1087 fix compaction block flush: flush do not return until compaction finished
-* IOTDB-1106 Delete timeseries statement will incorrectly delete other timeseries
-* Github issue-2137 fix grafana value-time position bug
-* Github issue-2169 GetObject returns String for all data types
-* Github issue-2240 fix Sync failed: Socket is closed by peer
-* Github issue-2387 The deleteData method exists in Session but not in SessionPool.
-* add thrift_max_frame_size in iotdb-engine.properties
-* Fix incorrect last result after deleting all data
-* Fix compaction recover block restart: IoTDB cannot restart until last compaction recover task finished
-* Fix compaction ignore modification file: delete does not work after compaction
-* print more insert error message in client
-* expose enablePartition parameter into iotdb-engines.properpties
-
-# Apache IoTDB 0.11.1
-
-## Bug Fixes
-* IOTDB-990 cli parameter maxPRC shouldn't to be set zero
-* IOTDB-993 Fix tlog bug
-* IOTDB-994 Fix can not get last_value while doing the aggregation query along with first_value
-* IOTDB-1000 Fix read redundant data while select with value filter with unseq data
-* IOTDB-1007 Fix session pool concurrency and leakage issue when pool.close is called
-* IOTDB-1016 overlapped data should be consumed first
-* IOTDB-1021 Fix NullPointerException when showing child paths of non-existent path
-* IOTDB-1028 add MAX\_POINT\_NUMBER format check
-* IOTDB-1034 Fix Show timeseries error in Chinese on Windows
-* IOTDB-1035 Fix bug in getDeviceTimeseriesMetadata when querying non-exist device
-* IOTDB-1038 Fix flink set storage group bug
-* ISSUE-2179 fix insert partial tablet with binary NullPointer bug
-* add reject status code
-* Update compaction level list delete
-* Fix query result is not correct
-* Fix import errors in Session.py and SessionExample.py
-* Fix modules can not be found when using pypi to pack client-py
-* Fix Count timeseries group by level bug
-* Fix desc batchdata count bug
-
-# Apache IoTDB 0.11.0
-
-## New Features
-
-* IOTDB-627 Support range deletion for timeseries
-* IOTDB-670 Add raw data query interface in Session
-* IOTDB-716 add lz4 compression
-* IOTDB-736 Add query performance tracing
-* IOTDB-776 New memory control strategy
-* IOTDB-813 Show storage group under given path prefix
-* IOTDB-848 Support order by time asc/desc
-* IOTDB-863 add a switch to drop ouf-of-order data
-* IOTDB-873 Add count devices DDL
-* IOTDB-876 Add count storage group DDL
-* IOTDB-926 Support reconnection of Session
-* IOTDB-941 Support 'delete storage group <prefixPath>'
-* IOTDB-968 Support time predicate in select last, e.g., select last * from root where time >= T
-* Show alias if it is used in query
-* Add level compaction strategy
-* Add partialInsert
-
-## Incompatible changes
-
-* IOTDB-778 Support double/single quotation in Path
-* IOTDB-870 change tags and attributes output to two columns with json values
-
-## Miscellaneous changes
-
-* IOTDB-784 Update rpc protocol to V3
-* IOTDB-790 change base_dir to system_dir
-* IOTDB-829 Accelerate delete multiple timeseries
-* IOTDB-839 Make Tablet api more friendly
-* IOTDB-902 Optimize max_time aggregation
-* IOTDB-916 Add a config entry to make Last cache configurable
-* IOTDB-928 Make ENCODING optional in create time series sentence
-* IOTDB-938 Re-implement Gorilla encoding algorithm
-* IOTDB-942 Optimization of query with long time unsequence page
-* IOTDB-943 Fix cpu usage too high
-* Add query load log
-* Add merge rate limiting
-
-## Bug Fixes
-
-* IOTDB-749 Avoid select * from root OOM
-* IOTDB-774 Fix "show timeseries" OOM problem
-* IOTDB-832 Fix sessionPool logic when reconnection failed
-* IOTDB-833 Fix JMX cannot connect IoTDB in docker
-* IOTDB-835 Delete timeseries and change data type then write failed
-* IOTDB-836 Statistics classes mismatched when endFile (delete timeseries then recreate)
-* IOTDB-837 ArrayIndexOutOfBoundsException if the measurementId size is not consistent with the value size
-* IOTDB-847 Fix bug that 'List user privileges' cannot apply to 'root'
-* IOTDB-850 a user could list others privilege bug
-* IOTDB-851 Enhance failure tolerance when recover WAL (enable partial insertion)
-* IOTDB-855 Can not release Session in SessionPool if RuntimeException occurs
-* IOTDB-868 Can not redo mlogs with special characters like comma
-* IOTDB-872 Enable setting timezone at client
-* IOTDB-877 fix prefix bug on show storage group and show devices
-* IOTDB-904 fix update last cache NullPointerException
-* IOTDB-920 Disable insert row that only contains time/timestamp column
-* IOTDB-921 When execute two query simultaneously in one statement, got error
-* IOTDB-922 Int and Long can convert to each other in ResultSet
-* IOTDB-947 Fix error when counting node with wildcard
-* IOTDB-949 Align by device doesn't support 'T*' in path.
-* IOTDB-956 Filter will be missed in group by time align by device
-* IOTDB-963 Redo deleteStorageGroupPlan failed when recovering
-* IOTDB-967 Fix xxx does not have the child node xxx Bug in count timeseries
-* IOTDB-970 Restrict log file number and size
-* IOTDB-971 More precise error messages of slimit and soffset 
-* IOTDB-975 when series does not exist in TsFile, reading wrong ChunkMetadataList
-
-# Apache IoTDB (incubating) 0.10.1
-
-* [IOTDB-797] InsertTablet deserialization from WAL error
-* [IOTDB-788] Can not upgrade all storage groups
-* [IOTDB-792] deadlock when insert while show latest timeseries
-* [IOTDB-794] Rename file or delete file Error in start check in Windows
-* [IOTDB-795] BufferUnderflowException in Hive-connector
-* [IOTDB-766] Do not release unclosed file reader, a small memory leak
-* [IOTDB-796] Concurrent Query throughput is low
-* Query result is not correct when some unsequence data exists
-* Change the default fetch size to 10000 in session
-* [IOTDB-798] fix a set rowLimit and rowOffset bug
-* [IOTDB-800] Add a new config type for those parameters which could not be modified any more after the first start 
-* [IOTDB-802] Improve "group by" query performance
-* [IOTDB-799] remove log visualizer tool from v0.10 
-* fix license-binary  
-* [IOTDB-805] Fix BufferUnderflowException when querying TsFile stored in HDFS 
-* python session client ver-0.10.0
-* [IOTDB-808] fix bug in selfCheck() truncate 
-* fix doc of MeasurementSchema in Tablet 
-* [IOTDB-811] fix upgrading mlog many times when upgrading system.properties crashed
-* Improve IoTDB restart process
-* remove jol-core dependency which is introduced by hive-serde 2.8.4
-* remove org.json dependency because of license compatibility
-* [ISSUE-1551] fix set historical version when loading additional tsfile
-
-
-# Apache IoTDB (incubating) 0.10.0
-
-## New Features
-
-* IOTDB-217 A new GROUPBY syntax, e.g., select avg(s1) from root.sg.d1.s1 GROUP BY ([1, 50), 5ms)
-* IOTDB-220 Add hot-load configuration function
-* IOTDB-275 allow using user defined JAVA_HOME and allow blank space in the JAVA_HOME
-* IOTDB-287 Allow domain in JDBC URL
-* IOTDB-292 Add load external tsfile feature
-* IOTDB-297 Support "show flush task info"
-* IOTDB-298 Support new Last point query. e.g, select last * from root
-* IOTDB-305 Add value filter function while executing align by device
-* IOTDB-309 add Dockerfiles for 0.8.1, 0.9.0, and 0.9.1
-* IOTDB-313 Add RandomOnDiskUsableSpaceStrategy
-* IOTDB-323 Support insertRecords in session
-* IOTDB-337 Add timestamp precision properties for grafana
-* IOTDB-343 Add test method in session
-* IOTDB-396 Support new query clause: disable align, e.g., select * from root disable align
-* IOTDB-447 Support querying non-existing measurement and constant measurement
-* IOTDB-448 Add IN operation, e.g., where time in (1,2,3)
-* IOTDB-456 Support GroupByFill Query, e.g., select last_value(s1) from root.sg.d1 GROUP BY ([1, 10), 2ms) FILL(int32[previousUntilLast])
-* IOTDB-467 The CLI displays query results in a batch manner
-* IOTDB-497 Support Apache Flink Connector with IoTDB
-* IOTDB-558 add text support for grafana
-* IOTDB-560 Support Apache Flink connecter with TsFile
-* IOTDB-565 MQTT Protocol Support, disabled by default, open in iotdb-engine.properties
-* IOTDB-574 Specify configuration when start iotdb
-* IOTDB-588 Add tags and attributes management
-* IOTDB-607 add batch create timeseries in native interface
-* IOTDB-612 add limit&offset to show timeseries
-* IOTDB-615 Use TsDataType + Binary to replace String in insert plan
-* IOTDB-617 Support alter one time series's tag/attribute
-* IOTDB-630 Add a jdbc-like way to fetch data in session
-* IOTDB-640 Enable system admin sql (flush/merge) in JDBC or Other API
-* IOTDB-671 Add clear cache command
-* Support open and close time range in group by, e.g, [), (]
-* Online upgrade from 0.9.x
-* Support special characters in path: -/+&%$#@
-* IOTDB-446 Support path start with a digit, e.g., root.sg.12a
-* enable rpc compression in session pool
-* Make JDBC OSGi usable and added a feature file
-* add printing one resource file tool
-* Allow count timeseries group by level=x using default path
-* IOTDB-700 Add OpenID Connect based JWT Access as alternative to Username / Password
-* IOTDB-701 Set heap size by percentage of system total memory when starts
-* IOTDB-708 add config for inferring data type from string value
-* IOTDB-715 Support previous time range in previousuntillast
-* IOTDB-719 add avg_series_point_number_threshold in config
-* IOTDB-731 Continue write inside InsertPlan 
-* IOTDB-734 Add Support for NaN in Double / Floats in SQL Syntax.
-* IOTDB-744 Support upsert alias 
-
-
-## Incompatible changes
-
-* IOTDB-138 Move All metadata query to usual query
-* IOTDB-322 upgrade to thrift 0.12.0-0.13.0
-* IOTDB-325 Refactor Statistics in TsFile
-* IOTDB-419 Refactor the 'last' and 'first' aggregators to 'last_value' and 'first_value'
-* IOTDB-506 upgrade the rpc protocol to v2 to reject clients or servers that version < 0.10
-* IOTDB-587 TsFile is upgraded to version 2
-* IOTDB-593 add metaOffset in TsFileMetadata
-* IOTDB-597 Rename methods in Session: insertBatch to insertTablet, insertInBatch to insertRecords, insert to insertRecord
-* RPC is incompatible, you can not use client-v0.9 to connect with server-v0.10
-* TsFile format is incompatible, will be upgraded when starting 0.10
-* Refine exception code in native api
-
-## Miscellaneous changes
-
-* IOTDB-190 upgrade from antlr3 to antlr4
-* IOTDB-418 new query engine
-* IOTDB-429 return empty dataset instead of throw exception, e.g., show child paths root.*
-* IOTDB-445 Unify the keyword of "timestamp" and "time"
-* IOTDB-450 Add design documents
-* IOTDB-498 Support date format "2020-02-10"
-* IOTDB-503 Add checkTimeseriesExists in java native api
-* IOTDB-605 Add more levels of index in TsFileMetadata for handling too many series in one device
-* IOTDB-625 Change default level number: root is level 0
-* IOTDB-628 rename client to cli
-* IOTDB-621 Add Check isNull in Field for querying using session
-* IOTDB-632 Performance improve for PreviousFill/LinearFill
-* IOTDB-695 Accelerate the count timeseries query 
-* IOTDB-707 Optimize TsFileResource memory usage  
-* IOTDB-730 continue write in MQTT when some events are failed
-* IOTDB-729 shutdown uncessary threadpool 
-* IOTDB-733 Enable setting for mqtt max length 
-* IOTDB-732 Upgrade fastjson version to 1.2.70
-* Allow "count timeseries" without a prefix path
-* Add max backup log file number
-* add rpc compression api in client and session module
-* Continue writing the last unclosed file
-* Move the vulnera-checks section into the apache-release profile to accelerate compile
-* Add metaquery in python example
-* Set inferType of MQTT InsertPlan to true
-
-
-
-## Bug Fixes
-
-* IOTDB-125 Potential Concurrency bug while deleting and inserting happen together
-* IOTDB-185 fix start-client failed on WinOS if there is blank space in the file path; let start-server.bat suport jdk12,13 etc
-* IOTDB-304 Fix bug of incomplete HDFS URI
-* IOTDB-341 Fix data type bug in grafana
-* IOTDB-346 Fix a bug of renaming tsfile in loading function
-* IOTDB-370 fix a concurrent problem in parsing sql
-* IOTDB-376 fix metric to show executeQuery
-* IOTDB-392 fix export CSV
-* IOTDB-393 Fix unclear error message for no privilege users
-* IOTDB-401 Correct the calculation of a chunk if there is no data in the chunk, do not flush empty chunk
-* IOTDB-412 Paths are not correctly deduplicated
-* IOTDB-420 Avoid encoding task dying silently
-* IOTDB-425 fix can't change the root password.
-* IOTDB-459 Fix calmem tool bug
-* IOTDB-470fix IllegalArgumentException when there exists 0 byte TsFile
-* IOTDB-529 Relative times and NOW() operator cannot be used in Group By
-* IOTDB-531 fix issue when grafana visualize boolean data
-* IOTDB-546 Fix show child paths statement doesn't show quotation marks
-* IOTDB-643 Concurrent queries cause BufferUnderflowException when storage in HDFS
-* IOTDB-663 Fix query cache OOM while executing query
-* IOTDB-664 Win -e option
-* IOTDB-669 fix getting two columns bug while ”show devices“ in session
-* IOTDB-692 merge behaves incorrectly
-* IOTDB-712 Meet BufferUnderflowException and can not recover
-* IOTDB-718 Fix wrong time precision of NOW()
-* IOTDB-735 Fix Concurrent error for MNode when creating time series automatically 
-* IOTDB-738 Fix measurements has blank 
-
-* fix concurrent auto create schema conflict bug
-* fix meet incompatible file error in restart
-* Fix bugs of set core-site.xml and hdfs-site.xml paths in HDFS storage
-* fix execute flush command while inserting bug
-* Fix sync schema pos bug
-* Fix batch execution bug, the following sqls will all fail after one error sql
-* Fix recover endTime set bug
-
-
-# Apache IoTDB (incubating) 0.9.3
-
-## Bug Fixes
-- IOTDB-531 Fix that JDBC URL does not support domain issue
-- IOTDB-563 Fix pentaho cannot be downloaded because of spring.io address
-- IOTDB-608 Skip error Mlog
-- IOTDB-634 Fix merge caused errors for TsFile storage in HDFS
-- IOTDB-636 Fix Grafana connector does not use correct time unit
-
-## Miscellaneous changes
-- IOTDB-528 Modify grafana group by
-- IOTDB-635 Add workaround when doing Aggregation over boolean Series
-- Remove docs of Load External Tsfile
-- Add Grafana IoTDB Bridge Artifact to distribution in tools/grafana folder
-
-
-# Apache IoTDB (incubating) 0.9.2
-
-## Bug Fixes
-- IOTDB-553 Fix Return Empty ResultSet when queried series doesn't exist
-- IOTDB-575 add default jmx user and password; fix issues that jmx can't be accessed remotely
-- IOTDB-584 Fix InitializerError when recovering files on HDFS
-- Fix batch insert once an illegal sql occurs all the sqls after that will not succeed
-- Fix concurrent modification exception when iterator TsFileResourceList 
-- Fix some HDFS config issues 
-- Fix runtime exception not be catched and sync schema pos was nullpointer bug in DataTransferManager
-- Fix python rpc grammar mistakes
-- Fix upgrade ConcurrentModificationException
-
-## Miscellaneous changes
-- IOTDB-332 support Chinese characters in path
-- IOTDB-316 add AVG function to 4-SQL Reference.md and modify style 
-- improve start-server.bat by using quotes to protect against empty entries
-- Add Chinese documents for chapter 4.2
-- change download-maven-plugin to 1.3.0
-- add session pool 
-- add insertInBatch in Session
-- add insertInBatch to SessionPool
-- modify 0.9 docs to fit website
-- remove tsfile-format.properties
-- add bloom filter in iotdb-engien.properties
-- update server download doc
-- typos fix in Rel/0.9 docs
-- support 0.12.0 and 0.13.0 thrift
-
-# Apache IoTDB (incubating) 0.9.1
-
-## Bug Fixes
-
-- IOTDB-159 Fix NullPointerException in SeqTsFileRecoverTest and UnseqTsFileRecoverTest
-- IOTDB-317 Fix a bug that "flush + wrong aggregation query" causes the following queries to fail
-- IOTDB-324 Fix inaccurate statistics when writing in batch
-- IOTDB-327 Fix a groupBy-without-value-filter query bug caused by the wrong page skipping logic
-- IOTDB-331 Fix a groupBy query bug when axisOrigin-startTimeOfWindow is an integral multiple of interval
-- IOTDB-357 Fix NullPointerException in ActiveTimeSeriesCounter
-- IOTDB-359 Fix a wrong-data-type bug in TsFileSketchTool
-- IOTDB-360 Fix bug of a deadlock in CompressionRatio
-- IOTDB-363 Fix link errors in Development-Contributing.md and add Development-Document.md
-- IOTDB-392 Fix a bug in CSV export tool
-- Fix apache rat header format error in some files
-
-## Miscellaneous changes
-
-- IOTDB-321 Add definitions of time expression and LEVEL in related documents
-- Support pypi distribution for Python client
-
-# Apache IoTDB (incubating) 0.9.0
-
-## New Features
-
-* IOTDB-143 Compaction of data file
-* IOTDB-151 Support number format in timeseries path
-* IOTDB-158 Add metrics web service
-* IOTDB-173 Add batch write interface in session
-* IoTDB-174 Add interfaces for querying device or timeseries number
-* IOTDB-187 Enable to choose storage in local file system or HDFS
-* IOTDB-188 Delete storage group
-* IOTDB-193 Create schema automatically when inserting
-* IOTDB-198 Add sync module (Sync TsFiles between IoTDB instances)
-* IOTDB-199 Add a log visualization tool 
-* IOTDB-203 Add "group by device" function for narrow table display
-* IOTDB-205 Support storage-group-level Time To Live (TTL)
-* IOTDB-208 Add Bloom filter in TsFile
-* IOTDB-223 Add a TsFile sketch tool
-* IoTDB-226 Hive-TsFile connector
-* IOTDB-239 Add interface for showing devices
-* IOTDB-241 Add query and non query interface in session
-* IOTDB-249 Enable lowercase in create_timeseries sql
-* IOTDB-253 Support time expression 
-* IOTDB-259 Level query of path
-* IOTDB-282 Add "show version"
-* IOTDB-294 Online upgrade from 0.8.0 to 0.9.0
-* Spark-iotdb-connector
-* Support quoted measurement name
-* Generate cpp, go, and python thrift files under service-rpc
-* Display cache hit rate through jconsole
-* Support inserting data that time < 0
-* Add interface (Delete timeseries) in session 
-* Add a tool to print tsfileResources (each device's start and end time)
-* Support watermark feature
-* Add micro and nano timestamp precision
-
-## Incompatible changes
-
-* RPC is incompatible, you can not use client-0.8.0 to connect with server-0.9.0 or use client-0.9.0 to connect with server-0.8.0.
-* Server is backward compatible, server-0.9.0 could run on data folder of 0.8.0. The data file will be upgraded background.
-* Change map key in TsDigest from String to enum data type
-
-## Miscellaneous changes
-
-* IOTDB-144 Meta data cache for query
-* IOTDB-153 Further limit fetchSize to speed up LIMIT&OFFSET query
-* IOTDB-160 External sort
-* IOTDB-161 Add ErrorCode of different response errors
-* IOTDB-180 Get rid of JSON format in "show timeseries"
-* IOTDB-192 Improvement for LRUCache
-* IOTDB-210 One else if branch will never be reached in the method optimize of ExpressionOptimizer
-* IOTDB-215 Update TsFile sketch tool and TsFile docs for v0.9.0
-* IOTDB-221 Add a python client example
-* IOTDB-233 keep metadata plan clear
-* IOTDB-251 Improve TSQueryDataSet structure in RPC
-* IOTDB-257 Makes the client stop fetch when dataSize equals maxPrintRowCount and change client fetchSize less than maxPrintRowCount
-* IOTDB-258 Add documents for Query History Visualization Tool and Shared Storage Architecture
-* IOTDB-265 Re-adjust the threshold size of memtable
-* IOTDB-267 Reduce IO operations in deserializing chunk header
-* IOTDB-273 Parallel recovery
-* IOTDB-276 Fix inconsistent ways of judging whether a Field is null
-* IOTDB-285 Duplicate fields in EngineDataSetWithoutValueFilter.java
-* IOTDB-287 Restrict users to only use domain names and IP addresses.
-* IOTDB-293 Variable naming convention
-* IOTDB-295 Refactor db.exception
-* Reconstruct Antlr3 grammar to improve performance
-* Tooling for release
-* Modified Decoder and SequenceReader to support old version of TsFile 
-* Remove jdk constrain of jdk8 and 11
-* Modify print function in AbstractClient
-* Avoid second execution of parseSQLToPhysicalPlan in executeStatement
-
-## Known Issues
-
-* IOTDB-20 Need to support UPDATE
-
-## Bug Fixes
-
-* IOTDB-168&169 Fix a bug in export-csv tool and fix compatibility of timestamp formats in exportCsv, client display and sql
-* IOTDB-174 Fix querying timeseries interface cannot make a query by the specified path prefix
-* IOTDB-195 Using String.getBytes(utf-9).length to replace string.length() in ChunkGroupMetadata for supporting Chinese
-* IOTDB-211 Use "%IOTDB_HOME%\lib\*" to refers to all .jar files in the directory in start-server.bat
-* IOTDB-240 Fix unknown time series in where clause
-* IOTDB-244 Fix bug when querying with duplicated columns
-* IOTDB-252 Add/fix shell and bat for TsFileSketchTool/TsFileResourcePrinter
-* IOTDB-266 NullPoint exception when reading not existed devices using ReadOnlyTsFile
-* IOTDB-264 Restart failure due to WAL replay error
-* IOTDB-290 Bug about threadlocal field in TSServiceImpl.java
-* IOTDB-291 Statement close operation may cause the whole connection's resource to be released
-* IOTDB-296 Fix error when skip page data in sequence reader
-* IOTDB-301 Bug Fix: executing "count nodes root" in client gets "Msg:3"
-* Fix Dynamic Config when Creating Existing SG or Time-series
-* Fix start-walchecker scripts for letting user define the wal folder
-* Fix start script to set JAVA_HOME
-
-# Apache IoTDB (incubating) 0.8.2
-
- This is a bug-fix version of 0.8.1 
-
--  IOTDB-264 lack checking datatype before writing WAL 
--  IOTDB-317 Fix "flush + wrong aggregation" causes failed query in v0.8.x 
--  NOTICE and LICENSE file update 
-
-# Apache IoTDB (incubating) 0.8.1
-
-This is a bug-fix version of 0.8.0
-
-* IOTDB-172 Bug in updating startTime and endTime in TsFileResource
-* IOTDB-195 Bug about 'serializedSize' in ChunkGroupMetaData.java (for Chinese string)
-* IOTDB-202 fix tsfile example data type
-* IOTDB-242 fix mvn integration-test failed because the files in the target folder changes
-* Abnormal publishing of sequence and unsequence data folders in DirectoryManager
-* Fix a bug in TimeRange's intersects function
-
-
-# Apache IoTDB (incubating) 0.8.0
-
-This is the first official release of Apache IoTDB after joining the Incubator.
-
-## New Features
-
-* IOTDB-1 Add Aggregation query
-* IOTDB-4 Asynchronously force sync WAL periodically
-* IOTDB-5 Support data deletion
-* IOTDB-11 Support start script for jdk 11 on Windows OS
-* IOTDB-18 Improve startup script compatible for jdk11
-* IOTDB-36 [TsFile] Enable recover data from a incomplete TsFile and continue to write
-* IOTDB-37 Add WAL check tool script
-* IOTDB-51 Update post-back module to synchronization module
-* IOTDB-59 Support GroupBy query
-* IOTDB-60 Support Fill function when query
-* IOTDB-73 Add REGULAR encoding method for data with fixed frequency
-* IOTDB-80 Support custom export file name
-* IOTDB-81 Update travis for supporting JDK11 on Windows
-* IOTDB-83 Add process bar for import script and show how many rows have been exported
-* IOTDB-91 Improve tsfile-spark-connector to support spark-2.4.3
-* IOTDB-93 IoTDB Calcite integration
-* IOTDB-109 Support appending data at the end of a completed TsFile
-* IOTDB-122 Add prepared statement in JDBC
-* IOTDB-123 Add documents in Chinese
-* IOTDB-130 Dynamic parameters adapter
-* IOTDB-134 Add default parameter for client starting script
-* Add read-only mode of IoTDB
-* New storage engine with asynchronously flush and close data file
-* Adding english documents
-* Supporting travis + window + jdk8
-* Add skipping all UTs: maven integration-test -DskipUTS=true
-* Enable users define the location of their thrift compiler
-* Add example module
-* Add a log appender: put info, warn, error log into one file and disable log_info by default
-* Recover when resource file does not exist while tsfile is complete
-
-## Incompatible changes
-
-If you use the previous unofficial version 0.7.0. It is incompatible with 0.8.0.
-
-## Miscellaneous changes
-
-* IOTDB-21 Add ChunkGroup offset information in ChunkGroupMetaData
-* IOTDB-25 Add some introduction for JMX MBean Monitor in user guide
-* IOTDB-29 Multiple Exceptions when reading empty measurements from TsFileSequenceReader
-* IOTDB-39 Add auto repair functionality for RestorableTsFileIOWriter
-* IOTDB-45 Update the license in IoTDB
-* IOTDB-56 Faster getSortedTimeValuePairList() of Memtable
-* IOTDB-62 Change log level from error to debug in SQL parser
-* IoTDB-63 Use TsFileInput instead of FileChannel as the input parameter of some functions
-* IOTDB-76 Reformat MManager.getMetadataInString() in JSON format
-* IOTDB-78 Make unsequence file format more similar with TsFile
-* IOTDB-95 Keep stack trace when logging or throwing an exception
-* IOTDB-117 Add sync documents
-* Modify ASF header for each file and add related maven plugin
-* Add IoTDB env script test
-* Add sync function for jdbc server to close
-* Add cache directories for download jars and sonar plugin of maven in travis
-* Add partition start and end offset constraints when loading ChunkGroupMetaData
-* Check when creating Storage group
-* Try to release memory asap in ReadOnlyMemChunk
-* Add more physical plan serializer
-* Move all generated tsfiles for test into the target folder
-* Make TsFileWriter as AutoClosable
-* Print apache-rat violation result on console
-* Update multi dir avoid disk is full
-* Simplify Path construction
-* Separate documents into different chapter folders
-* Suppress mvn log in travis
-* Add mvn -B in travis
-
-## Known Issues
-
-* IOTDB-20 Need to support UPDATE
-* IOTDB-124 Lost timeseries info after restart IoTDB
-* IOTDB-125 [potential] a concurrency conflict may occur when a delete command and insertion command appears concurrently
-* IOTDB-126 IoTDB will not be closed immediately after run 'stop-server.sh' script
-* IOTDB-127 Chinese version documents problems
-
-## Bug Fixes
-
-* IOTDB-2 Maven Test failed before run mvn package -Dmaven.test.skip=true
-* IOTDB-7 OpenFileNumUtilTest failed
-* IOTDB-15 Fail to install IoTDB on Ubuntu 14.04
-* IOTDB-16 Invalid link on https://iotdb.apache.org/#/Documents/Quick Start
-* IOTDB-17 Need to update chapter Start of https://iotdb.apache.org/#/Documents/Quick Start
-* IOTDB-18 IoTDB startup script does not work on openjdk11
-* IOTDB-19 Fail to start start-server.sh script on Ubuntu 14.04/Ubuntu 16.04
-* IOTDB-22 BUG in TsFileSequenceReader when reading tsfile
-* IOTDB-24 DELETION error after restart a server
-* IOTDB-26 Return error when quit client
-* IOTDB-27 Delete error message
-* IOTDB-30 Flush timeseries cause select to returns "Msg:null"
-* IOTDB-31 Cannot set float number precision
-* IOTDB-34 Invalid message for show storage group
-* IOTDB-44 Error message in server log when select timeseries
-* IOTDB-49 Authorizer module outputs too many debug log info
-* IOTDB-50 DataSetWithoutTimeGenerator's initHeap behaves wrongly
-* IOTDB-52 Cli doesn't support aggregate
-* IOTDB-54 Predicates doesn't take effect
-* IOTDB-67 ValueDecoder reading new page bug
-* IOTDB-70 Disconnect from server when logging in fails
-* IOTDB-71 Improve readPositionInfo
-* IOTDB-74 THe damaged log will be skipped if it is the only log
-* IOTDB-79 Long term test failed because of the version control of deletion function
-* IOTDB-81 Fix Windows OS environment for Travis-CI
-* IOTDB-82 File not closed in PageHeaderTest and cause UT on Windows fails
-* IOTDB-84 Out-of-memory bug
-* IOTDB-94 IoTDB failed to start client since the required jars are not in the right folder
-* IOTDB-96 The JDBC interface throws an exception when executing the SQL statement "list user"
-* IOTDB-99 List privileges User <username> on <path> cannot be used properly
-* IOTDB-100 Return error message while executing sum aggregation query
-* IOTDB-103 Does not give a hint when encountering unsupported data types
-* IOTDB-104 MManager is incorrectly recovered when system reboots
-* IOTDB-108 Mistakes in documents
-* IOTDB-110 Cli inserts data normally even if there is no space left on the disk
-* IOTDB-118 When the disk space is full, the storage group is created successfully
-* IOTDB-121 A bug of query on value columns
-* IOTDB-128 Probably a bug in iotdb official website
-* IOTDB-129 A bug in restoring incomplete tsfile when system restart
-* IOTDB-131 IoTDB-Grafana module error when getting the timeseries list from Grafana
-* IOTDB-133 Some content is mistaken for links
-* System memory check failure in iotdb-env.sh
-* Time zone bug in different region
-* DateTimeUtilsTest UT bug
-* Problem discovered by Sonar
-* Openjdk11 + linux11 does not work on travis
-* Start JDBC service too slowly
-* JDBC cannot be closed
-* Close bug in sync thread
-* Bug in MManager to get all file names of a path
-* Version files of different storage groups are placed into the same place
-* Import/export csv script bug
-* Log level and stack print in test
-* Bug in TsFile-Spark-Connector
-* A doc bug of QuickStart.md
\ No newline at end of file
diff --git a/antlr/pom.xml b/antlr/pom.xml
deleted file mode 100644
index f6b9f2d..0000000
--- a/antlr/pom.xml
+++ /dev/null
@@ -1,78 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <parent>
-        <groupId>org.apache.iotdb</groupId>
-        <artifactId>iotdb-parent</artifactId>
-        <version>0.12.1-SNAPSHOT</version>
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-    <artifactId>iotdb-antlr</artifactId>
-    <name>sql-antlr</name>
-    <description>Antlr parser for IoTDB.</description>
-    <dependencies>
-        <dependency>
-            <groupId>org.antlr</groupId>
-            <artifactId>antlr4-runtime</artifactId>
-        </dependency>
-    </dependencies>
-    <build>
-        <plugins>
-            <plugin>
-                <groupId>org.antlr</groupId>
-                <artifactId>antlr4-maven-plugin</artifactId>
-                <version>${antlr4.version}</version>
-                <executions>
-                    <execution>
-                        <configuration>
-                            <listener>false</listener>
-                            <visitor>true</visitor>
-                        </configuration>
-                        <goals>
-                            <goal>antlr4</goal>
-                        </goals>
-                    </execution>
-                </executions>
-            </plugin>
-            <plugin>
-                <groupId>org.codehaus.mojo</groupId>
-                <artifactId>build-helper-maven-plugin</artifactId>
-                <version>3.2.0</version>
-                <executions>
-                    <execution>
-                        <id>add-source</id>
-                        <phase>generate-sources</phase>
-                        <goals>
-                            <goal>add-source</goal>
-                        </goals>
-                        <configuration>
-                            <sources>
-                                <source>${project.build.directory}/generated-sources/antlr4</source>
-                            </sources>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
-</project>
diff --git a/antlr/src/main/antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4 b/antlr/src/main/antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4
deleted file mode 100644
index 6a027cd..0000000
--- a/antlr/src/main/antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4
+++ /dev/null
@@ -1,1537 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-grammar SqlBase;
-
-singleStatement
-    : DEBUG? statement (';')? EOF
-    ;
-
-/*
- * According to The Definitive ANTLR 4 Reference, 11. Altering the Parse with Semantic Predicates, Altering the Parse with Semantic Predicates.
- * "It s a good idea to avoid embedding predicates in the parser when possible for efficiency and clarity reasons."
- * So if unnecessary, don't use embedding predicates.
- */
-
-statement
-    : CREATE TIMESERIES fullPath alias? WITH attributeClauses #createTimeseries
-    | DELETE TIMESERIES prefixPath (COMMA prefixPath)* #deleteTimeseries
-    | ALTER TIMESERIES fullPath alterClause #alterTimeseries
-    | INSERT INTO prefixPath insertColumnsSpec VALUES insertValuesSpec #insertStatement
-    | UPDATE prefixPath setClause whereClause? #updateStatement
-    | DELETE FROM prefixPath (COMMA prefixPath)* (whereClause)? #deleteStatement
-    | SET STORAGE GROUP TO prefixPath #setStorageGroup
-    | DELETE STORAGE GROUP prefixPath (COMMA prefixPath)* #deleteStorageGroup
-    | SHOW METADATA #showMetadata // not support yet
-    | DESCRIBE prefixPath #describePath // not support yet
-    | CREATE INDEX ON prefixPath whereClause? indexWithClause #createIndex //not support yet
-    | DROP INDEX indexName=ID ON prefixPath #dropIndex //not support yet
-    | MERGE #merge
-    | FLUSH prefixPath? (COMMA prefixPath)* (booleanClause)?#flush
-    | FULL MERGE #fullMerge
-    | CLEAR CACHE #clearcache
-    | CREATE USER userName=ID password= stringLiteral#createUser
-    | ALTER USER userName=(ROOT|ID) SET PASSWORD password=stringLiteral #alterUser
-    | DROP USER userName=ID #dropUser
-    | CREATE ROLE roleName=ID #createRole
-    | DROP ROLE roleName=ID #dropRole
-    | GRANT USER userName=ID PRIVILEGES privileges ON prefixPath #grantUser
-    | GRANT ROLE roleName=ID PRIVILEGES privileges ON prefixPath #grantRole
-    | REVOKE USER userName=ID PRIVILEGES privileges ON prefixPath #revokeUser
-    | REVOKE ROLE roleName=ID PRIVILEGES privileges ON prefixPath #revokeRole
-    | GRANT roleName=ID TO userName=ID #grantRoleToUser
-    | REVOKE roleName = ID FROM userName = ID #revokeRoleFromUser
-    | LOAD TIMESERIES (fileName=stringLiteral) prefixPath#loadStatement
-    | GRANT WATERMARK_EMBEDDING TO rootOrId (COMMA rootOrId)* #grantWatermarkEmbedding
-    | REVOKE WATERMARK_EMBEDDING FROM rootOrId (COMMA rootOrId)* #revokeWatermarkEmbedding
-    | LIST USER #listUser
-    | LIST ROLE #listRole
-    | LIST PRIVILEGES USER username=rootOrId ON prefixPath #listPrivilegesUser
-    | LIST PRIVILEGES ROLE roleName=ID ON prefixPath #listPrivilegesRole
-    | LIST USER PRIVILEGES username =rootOrId #listUserPrivileges
-    | LIST ROLE PRIVILEGES roleName = ID #listRolePrivileges
-    | LIST ALL ROLE OF USER username = rootOrId #listAllRoleOfUser
-    | LIST ALL USER OF ROLE roleName = ID #listAllUserOfRole
-    | SET TTL TO path=prefixPath time=INT #setTTLStatement
-    | UNSET TTL TO path=prefixPath #unsetTTLStatement
-    | SHOW TTL ON prefixPath (COMMA prefixPath)* #showTTLStatement
-    | SHOW ALL TTL #showAllTTLStatement
-    | SHOW FLUSH TASK INFO #showFlushTaskInfo
-    | SHOW VERSION #showVersion
-    | SHOW LATEST? TIMESERIES prefixPath? showWhereClause? limitClause? #showTimeseries
-    | SHOW STORAGE GROUP prefixPath? #showStorageGroup
-    | SHOW CHILD PATHS prefixPath? #showChildPaths
-    | SHOW CHILD NODES prefixPath? #showChildNodes
-    | SHOW DEVICES prefixPath? (WITH STORAGE GROUP)? limitClause? #showDevices
-    | SHOW MERGE #showMergeStatus
-    | SHOW QUERY PROCESSLIST #showQueryProcesslist
-    | KILL QUERY INT? #killQuery
-    | TRACING ON #tracingOn
-    | TRACING OFF #tracingOff
-    | COUNT TIMESERIES prefixPath? (GROUP BY LEVEL OPERATOR_EQ INT)? #countTimeseries
-    | COUNT DEVICES prefixPath? #countDevices
-    | COUNT STORAGE GROUP prefixPath? #countStorageGroup
-    | COUNT NODES prefixPath LEVEL OPERATOR_EQ INT #countNodes
-    | LOAD CONFIGURATION (MINUS GLOBAL)? #loadConfigurationStatement
-    | LOAD stringLiteral autoCreateSchema?#loadFiles
-    | REMOVE stringLiteral #removeFile
-    | MOVE stringLiteral stringLiteral #moveFile
-    | DELETE PARTITION prefixPath INT(COMMA INT)* #deletePartition
-    | CREATE SNAPSHOT FOR SCHEMA #createSnapshot
-    | CREATE TEMPORARY? FUNCTION udfName=ID AS className=stringLiteral #createFunction
-    | DROP FUNCTION udfName=ID #dropFunction
-    | SHOW TEMPORARY? FUNCTIONS #showFunctions
-    | CREATE TRIGGER triggerName=ID triggerEventClause ON fullPath
-      AS className=stringLiteral triggerAttributeClause? #createTrigger
-    | DROP TRIGGER triggerName=ID #dropTrigger
-    | START TRIGGER triggerName=ID #startTrigger
-    | STOP TRIGGER triggerName=ID #stopTrigger
-    | SHOW TRIGGERS (ON fullPath)? #showTriggers
-    | SELECT topClause? selectElements
-    fromClause
-    whereClause?
-    specialClause? #selectStatement
-    ;
-
-selectElements
-    : aggregationCall (COMMA aggregationCall)* #aggregationElement
-    | tableCall (COMMA tableCall)* #tableElement
-    | lastClause #lastElement
-    | asClause (COMMA asClause)* #asElement
-    | functionAsClause (COMMA functionAsClause)* #functionAsElement
-    ;
-
-aggregationCall
-    : builtInFunctionCall
-    | udfCall
-    ;
-
-tableCall
-    : suffixPath
-    | udfCall
-    | SINGLE_QUOTE_STRING_LITERAL
-    ;
-
-udfCall
-    : udfName=ID LR_BRACKET udfSuffixPaths udfAttribute* RR_BRACKET
-    ;
-
-udfSuffixPaths
-    : suffixPath (COMMA suffixPath)*
-    ;
-
-udfAttribute
-    : COMMA udfAttributeKey=stringLiteral OPERATOR_EQ udfAttributeValue=stringLiteral
-    ;
-
-builtInFunctionCall
-    : functionName LR_BRACKET suffixPath RR_BRACKET
-    ;
-
-functionName
-    : MIN_TIME
-    | MAX_TIME
-    | MIN_VALUE
-    | MAX_VALUE
-    | COUNT
-    | AVG
-    | FIRST_VALUE
-    | SUM
-    | LAST_VALUE
-    ;
-
-functionAsClause
-    : builtInFunctionCall (AS ID)?
-    ;
-
-lastClause
-    : LAST suffixPath (COMMA suffixPath)*
-    | LAST asClause (COMMA asClause)*
-    ;
-
-asClause
-    : suffixPath (AS ID)?
-    ;
-
-alias
-    : LR_BRACKET ID RR_BRACKET
-    ;
-
-alterClause
-    : RENAME beforeName=ID TO currentName=ID
-    | SET property (COMMA property)*
-    | DROP ID (COMMA ID)*
-    | ADD TAGS property (COMMA property)*
-    | ADD ATTRIBUTES property (COMMA property)*
-    | UPSERT aliasClause? tagClause? attributeClause?
-    ;
-
-aliasClause
-    : ALIAS OPERATOR_EQ ID
-    ;
-
-attributeClauses
-    : DATATYPE OPERATOR_EQ dataType (COMMA ENCODING OPERATOR_EQ encoding)?
-    (COMMA (COMPRESSOR | COMPRESSION) OPERATOR_EQ compressor)?
-    (COMMA property)*
-    tagClause?
-    attributeClause?
-    ;
-
-compressor
-    : UNCOMPRESSED
-    | SNAPPY
-    | LZ4
-    | GZIP
-    ;
-
-attributeClause
-    : ATTRIBUTES LR_BRACKET property (COMMA property)* RR_BRACKET
-    ;
-
-tagClause
-    : TAGS LR_BRACKET property (COMMA property)* RR_BRACKET
-    ;
-
-setClause
-    : SET setCol (COMMA setCol)*
-    ;
-
-whereClause
-    : WHERE (orExpression | indexPredicateClause)
-    ;
-
-showWhereClause
-    : WHERE (property | containsExpression)
-    ;
-containsExpression
-    : name=ID OPERATOR_CONTAINS value=propertyValue
-    ;
-
-orExpression
-    : andExpression (OPERATOR_OR andExpression)*
-    ;
-
-andExpression
-    : predicate (OPERATOR_AND predicate)*
-    ;
-
-predicate
-    : (TIME | TIMESTAMP | suffixPath | fullPath) comparisonOperator constant
-    | (TIME | TIMESTAMP | suffixPath | fullPath) inClause
-    | OPERATOR_NOT? LR_BRACKET orExpression RR_BRACKET
-    ;
-
-inClause
-    : OPERATOR_NOT? OPERATOR_IN LR_BRACKET constant (COMMA constant)* RR_BRACKET
-    ;
-
-fromClause
-    : FROM prefixPath (COMMA prefixPath)*
-    ;
-
-specialClause
-    : specialLimit #specialLimitStatement
-    | orderByTimeClause specialLimit? #orderByTimeStatement
-    | groupByTimeClause orderByTimeClause? specialLimit? #groupByTimeStatement
-    | groupByFillClause orderByTimeClause? specialLimit? #groupByFillStatement
-    | fillClause slimitClause? alignByDeviceClauseOrDisableAlign? #fillStatement
-    | alignByDeviceClauseOrDisableAlign #alignByDeviceStatementOrDisableAlignInSpecialClause
-    | groupByLevelClause orderByTimeClause? specialLimit? #groupByLevelStatement
-    ;
-
-specialLimit
-    : limitClause slimitClause? alignByDeviceClauseOrDisableAlign? #limitStatement
-    | slimitClause limitClause? alignByDeviceClauseOrDisableAlign? #slimitStatement
-    | alignByDeviceClauseOrDisableAlign #alignByDeviceClauseOrDisableAlignInSpecialLimit
-    ;
-
-orderByTimeClause
-    : ORDER BY TIME (DESC | ASC)?
-    ;
-
-limitClause
-    : LIMIT INT offsetClause?
-    | offsetClause? LIMIT INT
-    ;
-
-offsetClause
-    : OFFSET INT
-    ;
-
-slimitClause
-    : SLIMIT INT soffsetClause?
-    | soffsetClause? SLIMIT INT
-    ;
-
-soffsetClause
-    : SOFFSET INT
-    ;
-
-alignByDeviceClause
-    : ALIGN BY DEVICE
-    | GROUP BY DEVICE
-    ;
-
-disableAlign
-    : DISABLE ALIGN
-    ;
-
-alignByDeviceClauseOrDisableAlign
-    : alignByDeviceClause
-    | disableAlign
-    ;
-
-fillClause
-    : FILL LR_BRACKET typeClause (COMMA typeClause)* RR_BRACKET
-    ;
-
-groupByTimeClause
-    : GROUP BY LR_BRACKET
-      timeInterval
-      COMMA DURATION
-      (COMMA DURATION)?
-      RR_BRACKET
-    | GROUP BY LR_BRACKET
-            timeInterval
-            COMMA DURATION
-            (COMMA DURATION)?
-            RR_BRACKET
-            COMMA LEVEL OPERATOR_EQ INT
-    ;
-
-groupByFillClause
-    : GROUP BY LR_BRACKET
-      timeInterval
-      COMMA DURATION
-      RR_BRACKET
-      FILL LR_BRACKET typeClause (COMMA typeClause)* RR_BRACKET
-     ;
-
-groupByLevelClause
-    : GROUP BY LEVEL OPERATOR_EQ INT
-    ;
-
-typeClause
-    : (dataType | ALL) LS_BRACKET linearClause RS_BRACKET
-    | (dataType | ALL) LS_BRACKET previousClause RS_BRACKET
-    | (dataType | ALL) LS_BRACKET previousUntilLastClause RS_BRACKET
-    ;
-
-linearClause
-    : LINEAR (COMMA aheadDuration=DURATION COMMA behindDuration=DURATION)?
-    ;
-
-previousClause
-    : PREVIOUS (COMMA DURATION)?
-    ;
-
-previousUntilLastClause
-    : PREVIOUSUNTILLAST (COMMA DURATION)?
-    ;
-
-indexWithClause
-    : WITH INDEX OPERATOR_EQ indexName=ID (COMMA property)*
-    ;
-
-topClause
-    : TOP INT
-    ;
-
-indexPredicateClause
-    : (suffixPath | fullPath) LIKE sequenceClause
-    | (suffixPath | fullPath) CONTAIN sequenceClause WITH TOLERANCE constant (CONCAT sequenceClause WITH TOLERANCE constant)*
-    ;
-
-
-sequenceClause
-    : LR_BRACKET constant (COMMA constant)* RR_BRACKET
-    ;
-
-comparisonOperator
-    : type = OPERATOR_GT
-    | type = OPERATOR_GTE
-    | type = OPERATOR_LT
-    | type = OPERATOR_LTE
-    | type = OPERATOR_EQ
-    | type = OPERATOR_NEQ
-    ;
-
-insertColumnsSpec
-    : LR_BRACKET (TIMESTAMP|TIME) (COMMA nodeNameWithoutStar)+ RR_BRACKET
-    ;
-
-insertValuesSpec
-    : LR_BRACKET dateFormat (COMMA constant)+ RR_BRACKET
-    | LR_BRACKET INT (COMMA constant)+ RR_BRACKET
-    ;
-
-setCol
-    : suffixPath OPERATOR_EQ constant
-    ;
-
-privileges
-    : stringLiteral (COMMA stringLiteral)*
-    ;
-
-rootOrId
-    : ROOT
-    | ID
-    ;
-
-timeInterval
-    : LS_BRACKET startTime=timeValue COMMA endTime=timeValue RR_BRACKET
-    | LR_BRACKET startTime=timeValue COMMA endTime=timeValue RS_BRACKET
-    ;
-
-timeValue
-    : dateFormat
-    | dateExpression
-    | INT
-    ;
-
-propertyValue
-    : INT
-    | ID
-    | stringLiteral
-    | constant
-    ;
-
-fullPath
-    : ROOT (DOT nodeNameWithoutStar)*
-    ;
-
-prefixPath
-    : ROOT (DOT nodeName)*
-    ;
-
-suffixPath
-    : nodeName (DOT nodeName)*
-    ;
-
-nodeName
-    : ID STAR?
-    | STAR
-    | DOUBLE_QUOTE_STRING_LITERAL
-    | DURATION
-    | encoding
-    | dataType
-    | dateExpression
-    | MINUS? (EXPONENT | INT)
-    | booleanClause
-    | CREATE
-    | INSERT
-    | UPDATE
-    | DELETE
-    | SELECT
-    | SHOW
-    | GRANT
-    | INTO
-    | SET
-    | WHERE
-    | FROM
-    | TO
-    | BY
-    | DEVICE
-    | CONFIGURATION
-    | DESCRIBE
-    | SLIMIT
-    | LIMIT
-    | UNLINK
-    | OFFSET
-    | SOFFSET
-    | FILL
-    | LINEAR
-    | PREVIOUS
-    | PREVIOUSUNTILLAST
-    | METADATA
-    | TIMESERIES
-    | TIMESTAMP
-    | PROPERTY
-    | WITH
-    | DATATYPE
-    | COMPRESSOR
-    | STORAGE
-    | GROUP
-    | LABEL
-    | ADD
-    | UPSERT
-    | VALUES
-    | NOW
-    | LINK
-    | INDEX
-    | USING
-    | ON
-    | DROP
-    | MERGE
-    | LIST
-    | USER
-    | PRIVILEGES
-    | ROLE
-    | ALL
-    | OF
-    | ALTER
-    | PASSWORD
-    | REVOKE
-    | LOAD
-    | WATERMARK_EMBEDDING
-    | UNSET
-    | TTL
-    | FLUSH
-    | TASK
-    | INFO
-    | VERSION
-    | REMOVE
-    | MOVE
-    | CHILD
-    | PATHS
-    | DEVICES
-    | COUNT
-    | NODES
-    | LEVEL
-    | MIN_TIME
-    | MAX_TIME
-    | MIN_VALUE
-    | MAX_VALUE
-    | AVG
-    | FIRST_VALUE
-    | SUM
-    | LAST_VALUE
-    | LAST
-    | DISABLE
-    | ALIGN
-    | COMPRESSION
-    | TIME
-    | ATTRIBUTES
-    | TAGS
-    | RENAME
-    | FULL
-    | CLEAR
-    | CACHE
-    | SNAPSHOT
-    | FOR
-    | SCHEMA
-    | TRACING
-    | OFF
-    | (ID | OPERATOR_IN)? LS_BRACKET INT? ID? RS_BRACKET? ID?
-    | compressor
-    | GLOBAL
-    | PARTITION
-    | DESC
-    | ASC
-    ;
-
-nodeNameWithoutStar
-    : ID
-    | DOUBLE_QUOTE_STRING_LITERAL
-    | DURATION
-    | encoding
-    | dataType
-    | dateExpression
-    | MINUS? ( EXPONENT | INT)
-    | booleanClause
-    | CREATE
-    | INSERT
-    | UPDATE
-    | DELETE
-    | SELECT
-    | SHOW
-    | GRANT
-    | INTO
-    | SET
-    | WHERE
-    | FROM
-    | TO
-    | BY
-    | DEVICE
-    | CONFIGURATION
-    | DESCRIBE
-    | SLIMIT
-    | LIMIT
-    | UNLINK
-    | OFFSET
-    | SOFFSET
-    | FILL
-    | LINEAR
-    | PREVIOUS
-    | PREVIOUSUNTILLAST
-    | METADATA
-    | TIMESERIES
-    | TIMESTAMP
-    | PROPERTY
-    | WITH
-    | DATATYPE
-    | COMPRESSOR
-    | STORAGE
-    | GROUP
-    | LABEL
-    | ADD
-    | UPSERT
-    | VALUES
-    | NOW
-    | LINK
-    | INDEX
-    | USING
-    | ON
-    | DROP
-    | MERGE
-    | LIST
-    | USER
-    | PRIVILEGES
-    | ROLE
-    | ALL
-    | OF
-    | ALTER
-    | PASSWORD
-    | REVOKE
-    | LOAD
-    | WATERMARK_EMBEDDING
-    | UNSET
-    | TTL
-    | FLUSH
-    | TASK
-    | INFO
-    | VERSION
-    | REMOVE
-    | MOVE
-    | CHILD
-    | PATHS
-    | DEVICES
-    | COUNT
-    | NODES
-    | LEVEL
-    | MIN_TIME
-    | MAX_TIME
-    | MIN_VALUE
-    | MAX_VALUE
-    | AVG
-    | FIRST_VALUE
-    | SUM
-    | LAST_VALUE
-    | LAST
-    | DISABLE
-    | ALIGN
-    | COMPRESSION
-    | TIME
-    | ATTRIBUTES
-    | TAGS
-    | RENAME
-    | FULL
-    | CLEAR
-    | CACHE
-    | SNAPSHOT
-    | FOR
-    | SCHEMA
-    | TRACING
-    | OFF
-    | (ID | OPERATOR_IN)? LS_BRACKET INT? ID? RS_BRACKET? ID?
-    | compressor
-    | GLOBAL
-    | PARTITION
-    | DESC
-    | ASC
-    ;
-
-dataType
-    : INT32 | INT64 | FLOAT | DOUBLE | BOOLEAN | TEXT
-    ;
-
-dateFormat
-    : DATETIME
-    | NOW LR_BRACKET RR_BRACKET
-    ;
-
-constant
-    : dateExpression
-    | NaN
-    | MINUS? realLiteral
-    | MINUS? INT
-    | stringLiteral
-    | booleanClause
-    ;
-
-booleanClause
-    : TRUE
-    | FALSE
-    ;
-
-dateExpression
-    : dateFormat ((PLUS | MINUS) DURATION)*
-    ;
-
-encoding
-    : PLAIN | PLAIN_DICTIONARY | RLE | DIFF | TS_2DIFF | GORILLA | REGULAR
-    ;
-
-realLiteral
-    :   INT DOT (INT | EXPONENT)?
-    |   DOT  (INT|EXPONENT)
-    |   EXPONENT
-    ;
-
-property
-    : name=ID OPERATOR_EQ value=propertyValue
-    ;
-
-autoCreateSchema
-    : booleanClause
-    | booleanClause INT
-    ;
-
-triggerEventClause
-    : (BEFORE | AFTER) INSERT
-    ;
-
-triggerAttributeClause
-    : WITH LR_BRACKET triggerAttribute (COMMA triggerAttribute)* RR_BRACKET
-    ;
-
-triggerAttribute
-    : key=stringLiteral OPERATOR_EQ value=stringLiteral
-    ;
-
-//============================
-// Start of the keywords list
-//============================
-CREATE
-    : C R E A T E
-    ;
-
-INSERT
-    : I N S E R T
-    ;
-
-UPDATE
-    : U P D A T E
-    ;
-
-DELETE
-    : D E L E T E
-    ;
-
-SELECT
-    : S E L E C T
-    ;
-
-SHOW
-    : S H O W
-    ;
-
-QUERY
-    : Q U E R Y
-    ;
-
-KILL
-    : K I L L
-    ;
-
-PROCESSLIST
-    : P R O C E S S L I S T
-    ;
-
-
-GRANT
-    : G R A N T
-    ;
-
-INTO
-    : I N T O
-    ;
-
-SET
-    : S E T
-    ;
-
-WHERE
-    : W H E R E
-    ;
-
-FROM
-    : F R O M
-    ;
-
-TO
-    : T O
-    ;
-
-ORDER
-    : O R D E R
-    ;
-
-BY
-    : B Y
-    ;
-
-DEVICE
-    : D E V I C E
-    ;
-
-CONFIGURATION
-    : C O N F I G U R A T I O N
-    ;
-
-DESCRIBE
-    : D E S C R I B E
-    ;
-
-SLIMIT
-    : S L I M I T
-    ;
-
-LIMIT
-    : L I M I T
-    ;
-
-UNLINK
-    : U N L I N K
-    ;
-
-OFFSET
-    : O F F S E T
-    ;
-
-SOFFSET
-    : S O F F S E T
-    ;
-
-FILL
-    : F I L L
-    ;
-
-LINEAR
-    : L I N E A R
-    ;
-
-PREVIOUS
-    : P R E V I O U S
-    ;
-
-PREVIOUSUNTILLAST
-    : P R E V I O U S U N T I L L A S T
-    ;
-
-METADATA
-    : M E T A D A T A
-    ;
-
-TIMESERIES
-    : T I M E S E R I E S
-    ;
-
-TIMESTAMP
-    : T I M E S T A M P
-    ;
-
-PROPERTY
-    : P R O P E R T Y
-    ;
-
-WITH
-    : W I T H
-    ;
-
-ROOT
-    : R O O T
-    ;
-
-DATATYPE
-    : D A T A T Y P E
-    ;
-
-COMPRESSOR
-    : C O M P R E S S O R
-    ;
-
-STORAGE
-    : S T O R A G E
-    ;
-
-GROUP
-    : G R O U P
-    ;
-
-LABEL
-    : L A B E L
-    ;
-
-INT32
-    : I N T '3' '2'
-    ;
-
-INT64
-    : I N T '6' '4'
-    ;
-
-FLOAT
-    : F L O A T
-    ;
-
-DOUBLE
-    : D O U B L E
-    ;
-
-BOOLEAN
-    : B O O L E A N
-    ;
-
-TEXT
-    : T E X T
-    ;
-
-ENCODING
-    : E N C O D I N G
-    ;
-
-PLAIN
-    : P L A I N
-    ;
-
-PLAIN_DICTIONARY
-    : P L A I N '_' D I C T I O N A R Y
-    ;
-
-RLE
-    : R L E
-    ;
-
-DIFF
-    : D I F F
-    ;
-
-TS_2DIFF
-    : T S '_' '2' D I F F
-    ;
-
-GORILLA
-    : G O R I L L A
-    ;
-
-
-REGULAR
-    : R E G U L A R
-    ;
-
-BITMAP
-    : B I T M A P
-    ;
-
-ADD
-    : A D D
-    ;
-
-UPSERT
-    : U P S E R T
-    ;
-
-ALIAS
-    : A L I A S
-    ;
-
-VALUES
-    : V A L U E S
-    ;
-
-NOW
-    : N O W
-    ;
-
-LINK
-    : L I N K
-    ;
-
-INDEX
-    : I N D E X
-    ;
-
-USING
-    : U S I N G
-    ;
-
-TRACING
-    : T R A C I N G
-    ;
-
-ON
-    : O N
-    ;
-
-OFF
-    : O F F
-    ;
-
-DROP
-    : D R O P
-    ;
-
-MERGE
-    : M E R G E
-    ;
-
-LIST
-    : L I S T
-    ;
-
-USER
-    : U S E R
-    ;
-
-PRIVILEGES
-    : P R I V I L E G E S
-    ;
-
-ROLE
-    : R O L E
-    ;
-
-ALL
-    : A L L
-    ;
-
-OF
-    : O F
-    ;
-
-ALTER
-    : A L T E R
-    ;
-
-PASSWORD
-    : P A S S W O R D
-    ;
-
-REVOKE
-    : R E V O K E
-    ;
-
-LOAD
-    : L O A D
-    ;
-
-WATERMARK_EMBEDDING
-    : W A T E R M A R K '_' E M B E D D I N G
-    ;
-
-UNSET
-    : U N S E T
-    ;
-
-TTL
-    : T T L
-    ;
-
-FLUSH
-    : F L U S H
-    ;
-
-TASK
-    : T A S K
-    ;
-
-INFO
-    : I N F O
-    ;
-
-VERSION
-    : V E R S I O N
-    ;
-
-REMOVE
-    : R E M O V E
-    ;
-MOVE
-    : M O V E
-    ;
-
-CHILD
-    : C H I L D
-    ;
-
-PATHS
-    : P A T H S
-    ;
-
-DEVICES
-    : D E V I C E S
-    ;
-
-COUNT
-    : C O U N T
-    ;
-
-NODES
-    : N O D E S
-    ;
-
-LEVEL
-    : L E V E L
-    ;
-
-MIN_TIME
-    : M I N UNDERLINE T I M E
-    ;
-
-MAX_TIME
-    : M A X UNDERLINE T I M E
-    ;
-
-MIN_VALUE
-    : M I N UNDERLINE V A L U E
-    ;
-
-MAX_VALUE
-    : M A X UNDERLINE V A L U E
-    ;
-
-AVG
-    : A V G
-    ;
-
-FIRST_VALUE
-    : F I R S T UNDERLINE V A L U E
-    ;
-
-SUM
-    : S U M
-    ;
-
-LAST_VALUE
-    : L A S T UNDERLINE V A L U E
-    ;
-
-LAST
-    : L A S T
-    ;
-
-DISABLE
-    : D I S A B L E
-    ;
-
-ALIGN
-    : A L I G N
-    ;
-
-COMPRESSION
-    : C O M P R E S S I O N
-    ;
-
-TIME
-    : T I M E
-    ;
-
-ATTRIBUTES
-    : A T T R I B U T E S
-    ;
-
-TAGS
-    : T A G S
-    ;
-
-RENAME
-    : R E N A M E
-    ;
-
-GLOBAL
-  : G L O B A L
-  | G
-  ;
-
-FULL
-    : F U L L
-    ;
-
-CLEAR
-    : C L E A R
-    ;
-
-CACHE
-    : C A C H E
-    ;
-
-TRUE
-    : T R U E
-    ;
-
-FALSE
-    : F A L S E
-    ;
-
-UNCOMPRESSED
-    : U N C O M P R E S S E D
-    ;
-
-SNAPPY
-    : S N A P P Y
-    ;
-
-GZIP
-    : G Z I P
-    ;
-
-LZO
-    : L Z O
-    ;
-
-PAA
-    : P A A
-    ;
-
-PLA
-   : P L A
-   ;
-
-LZ4
-   : L Z '4' 
-   ;
-
-LATEST
-    : L A T E S T
-    ;
-
-PARTITION
-    : P A R T I T I O N
-    ;
-
-SNAPSHOT
-    : S N A P S H O T
-    ;
-
-FOR
-    : F O R
-    ;
-
-SCHEMA
-    : S C H E M A
-    ;
-
-TEMPORARY
-    : T E M P O R A R Y
-    ;
-
-FUNCTION
-    : F U N C T I O N
-    ;
-
-FUNCTIONS
-    : F U N C T I O N S
-    ;
-
-AS
-    : A S
-    ;
-
-TRIGGER
-    : T R I G G E R
-    ;
-
-TRIGGERS
-    : T R I G G E R S
-    ;
-
-BEFORE
-    : B E F O R E
-    ;
-
-AFTER
-    : A F T E R
-    ;
-
-START
-    : S T A R T
-    ;
-
-STOP
-    : S T O P
-    ;
-
-DESC
-    : D E S C
-    ;
-ASC
-    : A S C
-    ;
-
-TOP
-    : T O P
-    ;
-
-CONTAIN
-    : C O N T A I N
-    ;
-
-CONCAT
-    : C O N C A T
-    ;
-
-LIKE
-    : L I K E
-    ;
-
-TOLERANCE
-    : T O L E R A N C E
-    ;
-
-EXPLAIN
-    : E X P L A I N
-    ;
-
-DEBUG
-    : D E B U G
-    ;
-
-//============================
-// End of the keywords list
-//============================
-COMMA : ',';
-
-STAR : '*';
-
-OPERATOR_EQ : '=' | '==';
-
-OPERATOR_GT : '>';
-
-OPERATOR_GTE : '>=';
-
-OPERATOR_LT : '<';
-
-OPERATOR_LTE : '<=';
-
-OPERATOR_NEQ : '!=' | '<>';
-
-OPERATOR_IN : I N;
-
-OPERATOR_AND
-    : A N D
-    | '&'
-    | '&&'
-    ;
-
-OPERATOR_OR
-    : O R
-    | '|'
-    | '||'
-    ;
-
-OPERATOR_NOT
-    : N O T | '!'
-    ;
-
-OPERATOR_CONTAINS
-    : C O N T A I N S
-    ;
-
-MINUS : '-';
-
-PLUS : '+';
-
-DOT : '.';
-
-LR_BRACKET : '(';
-
-RR_BRACKET : ')';
-
-LS_BRACKET : '[';
-
-RS_BRACKET : ']';
-
-L_BRACKET : '{';
-
-R_BRACKET : '}';
-
-UNDERLINE : '_';
-
-NaN : 'NaN';
-
-stringLiteral
-   : SINGLE_QUOTE_STRING_LITERAL
-   | DOUBLE_QUOTE_STRING_LITERAL
-   ;
-
-INT : [0-9]+;
-
-EXPONENT : INT ('e'|'E') ('+'|'-')? INT ;
-
-DURATION
-    :
-    (INT+ (Y|M O|W|D|H|M|S|M S|U S|N S))+
-    ;
-
-DATETIME
-    : INT ('-'|'/') INT ('-'|'/') INT
-      ((T | WS)
-      INT ':' INT ':' INT (DOT INT)?
-      (('+' | '-') INT ':' INT)?)?
-    ;
-
-/** Allow unicode rule/token names */
-ID : FIRST_NAME_CHAR NAME_CHAR*;
-
-fragment
-NAME_CHAR
-    :   'A'..'Z'
-    |   'a'..'z'
-    |   '0'..'9'
-    |   '_'
-    |   '-'
-    |   ':'
-    |   '/'
-    |   '@'
-    |   '#'
-    |   '$'
-    |   '%'
-    |   '&'
-    |   '+'
-    |   CN_CHAR
-    ;
-
-fragment
-FIRST_NAME_CHAR
-    :   'A'..'Z'
-    |   'a'..'z'
-    |   '0'..'9'
-    |   '_'
-    |   '/'
-    |   '@'
-    |   '#'
-    |   '$'
-    |   '%'
-    |   '&'
-    |   '+'
-    |   CN_CHAR
-    ;
-
-fragment CN_CHAR
-  : '\u2E80'..'\u9FFF'
-  ;
-
-DOUBLE_QUOTE_STRING_LITERAL
-    : '"' ('\\' . | ~'"' )*? '"'
-    ;
-
-SINGLE_QUOTE_STRING_LITERAL
-    : '\'' ('\\' . | ~'\'' )*? '\''
-    ;
-
-//Characters and write it this way for case sensitivity
-fragment A
-    : 'a' | 'A'
-    ;
-
-fragment B
-    : 'b' | 'B'
-    ;
-
-fragment C
-    : 'c' | 'C'
-    ;
-
-fragment D
-    : 'd' | 'D'
-    ;
-
-fragment E
-    : 'e' | 'E'
-    ;
-
-fragment F
-    : 'f' | 'F'
-    ;
-
-fragment G
-    : 'g' | 'G'
-    ;
-
-fragment H
-    : 'h' | 'H'
-    ;
-
-fragment I
-    : 'i' | 'I'
-    ;
-
-fragment J
-    : 'j' | 'J'
-    ;
-
-fragment K
-    : 'k' | 'K'
-    ;
-
-fragment L
-    : 'l' | 'L'
-    ;
-
-fragment M
-    : 'm' | 'M'
-    ;
-
-fragment N
-    : 'n' | 'N'
-    ;
-
-fragment O
-    : 'o' | 'O'
-    ;
-
-fragment P
-    : 'p' | 'P'
-    ;
-
-fragment Q
-    : 'q' | 'Q'
-    ;
-
-fragment R
-    : 'r' | 'R'
-    ;
-
-fragment S
-    : 's' | 'S'
-    ;
-
-fragment T
-    : 't' | 'T'
-    ;
-
-fragment U
-    : 'u' | 'U'
-    ;
-
-fragment V
-    : 'v' | 'V'
-    ;
-
-fragment W
-    : 'w' | 'W'
-    ;
-
-fragment X
-    : 'x' | 'X'
-    ;
-
-fragment Y
-    : 'y' | 'Y'
-    ;
-
-fragment Z
-    : 'z' | 'Z'
-    ;
-
-WS
-    : [ \r\n\t]+ -> channel(HIDDEN)
-    ;
\ No newline at end of file
diff --git a/asf.header b/asf.header
deleted file mode 100644
index 7f7950e..0000000
--- a/asf.header
+++ /dev/null
@@ -1,16 +0,0 @@
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
diff --git a/checkstyle.xml b/checkstyle.xml
deleted file mode 100644
index 0a9d199..0000000
--- a/checkstyle.xml
+++ /dev/null
@@ -1,230 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?><!DOCTYPE module PUBLIC "-//Checkstyle//DTD Checkstyle Configuration 1.3//EN" "https://checkstyle.org/dtds/configuration_1_3.dtd">
-
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<!--
-    Checkstyle configuration that checks the Google coding conventions from Google Java Style
-    that can be found at https://google.github.io/styleguide/javaguide.html.
-    Checkstyle is very configurable. Be sure to read the documentation at
-    http://checkstyle.sf.net (or in your downloaded distribution).
-    To completely disable a check, just comment it out or delete it from the file.
-    Authors: Max Vetrenko, Ruslan Diachenko, Roman Ivanov.
- -->
-<module name="Checker">
-    <property name="charset" value="UTF-8"/>
-    <property name="severity" value="warning"/>
-    <property name="fileExtensions" value="java, properties, xml"/>
-    <!-- Checks for whitespace                               -->
-    <!-- See http://checkstyle.sf.net/config_whitespace.html -->
-    <module name="FileTabCharacter">
-        <property name="eachLine" value="true"/>
-    </module>
-    <module name="TreeWalker">
-        <module name="OuterTypeFilename"/>
-        <module name="IllegalTokenText">
-            <property name="tokens" value="STRING_LITERAL, CHAR_LITERAL"/>
-            <property name="format" value="\\u00(09|0(a|A)|0(c|C)|0(d|D)|22|27|5(C|c))|\\(0(10|11|12|14|15|42|47)|134)"/>
-            <property name="message" value="Consider using special escape sequence instead of octal value or Unicode escaped value."/>
-        </module>
-        <module name="AvoidEscapedUnicodeCharacters">
-            <property name="allowEscapesForControlCharacters" value="true"/>
-            <property name="allowByTailComment" value="true"/>
-            <property name="allowNonPrintableEscapes" value="true"/>
-        </module>
-        <module name="LineLength">
-            <property name="max" value="100"/>
-            <property name="ignorePattern" value="^package.*|^import.*|a href|href|http://|https://|ftp://"/>
-        </module>
-        <module name="AvoidStarImport"/>
-        <module name="OneTopLevelClass"/>
-        <module name="NoLineWrap"/>
-        <module name="EmptyBlock">
-            <property name="option" value="TEXT"/>
-            <property name="tokens" value="LITERAL_TRY, LITERAL_FINALLY, LITERAL_IF, LITERAL_ELSE, LITERAL_SWITCH"/>
-        </module>
-        <module name="NeedBraces"/>
-        <module name="LeftCurly"/>
-        <module name="RightCurly">
-            <property name="id" value="RightCurlySame"/>
-            <property name="tokens" value="LITERAL_TRY, LITERAL_CATCH, LITERAL_FINALLY, LITERAL_IF, LITERAL_ELSE,                     LITERAL_DO"/>
-        </module>
-        <module name="RightCurly">
-            <property name="id" value="RightCurlyAlone"/>
-            <property name="option" value="alone"/>
-            <property name="tokens" value="CLASS_DEF, METHOD_DEF, CTOR_DEF, LITERAL_FOR, LITERAL_WHILE, STATIC_INIT,                     INSTANCE_INIT"/>
-        </module>
-        <module name="WhitespaceAround">
-            <property name="allowEmptyConstructors" value="true"/>
-            <property name="allowEmptyMethods" value="true"/>
-            <property name="allowEmptyTypes" value="true"/>
-            <property name="allowEmptyLoops" value="true"/>
-            <message key="ws.notFollowed" value="WhitespaceAround: ''{0}'' is not followed by whitespace. Empty blocks may only be represented as '{}' when not part of a multi-block statement (4.1.3)"/>
-            <message key="ws.notPreceded" value="WhitespaceAround: ''{0}'' is not preceded with whitespace."/>
-        </module>
-        <module name="OneStatementPerLine"/>
-        <module name="MultipleVariableDeclarations"/>
-        <module name="ArrayTypeStyle"/>
-        <module name="MissingSwitchDefault"/>
-        <module name="FallThrough"/>
-        <module name="UpperEll"/>
-        <module name="ModifierOrder"/>
-        <module name="EmptyLineSeparator">
-            <property name="allowNoEmptyLineBetweenFields" value="true"/>
-        </module>
-        <module name="SeparatorWrap">
-            <property name="id" value="SeparatorWrapDot"/>
-            <property name="tokens" value="DOT"/>
-            <property name="option" value="nl"/>
-        </module>
-        <module name="SeparatorWrap">
-            <property name="id" value="SeparatorWrapComma"/>
-            <property name="tokens" value="COMMA"/>
-            <property name="option" value="EOL"/>
-        </module>
-        <module name="SeparatorWrap">
-            <!-- ELLIPSIS is EOL until https://github.com/google/styleguide/issues/258 -->
-            <property name="id" value="SeparatorWrapEllipsis"/>
-            <property name="tokens" value="ELLIPSIS"/>
-            <property name="option" value="EOL"/>
-        </module>
-        <module name="SeparatorWrap">
-            <!-- ARRAY_DECLARATOR is EOL until https://github.com/google/styleguide/issues/259 -->
-            <property name="id" value="SeparatorWrapArrayDeclarator"/>
-            <property name="tokens" value="ARRAY_DECLARATOR"/>
-            <property name="option" value="EOL"/>
-        </module>
-        <module name="SeparatorWrap">
-            <property name="id" value="SeparatorWrapMethodRef"/>
-            <property name="tokens" value="METHOD_REF"/>
-            <property name="option" value="nl"/>
-        </module>
-        <module name="PackageName">
-            <property name="format" value="^[a-z]+(\.[a-z][a-z0-9]*)*$"/>
-            <message key="name.invalidPattern" value="Package name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="TypeName">
-            <message key="name.invalidPattern" value="Type name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="MemberName">
-            <property name="format" value="^[a-z][a-z0-9][a-zA-Z0-9]*$"/>
-            <message key="name.invalidPattern" value="Member name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="ParameterName">
-            <property name="format" value="^[a-z]([a-z0-9][a-zA-Z0-9]*)?$"/>
-            <message key="name.invalidPattern" value="Parameter name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="LambdaParameterName">
-            <property name="format" value="^[a-z]([a-z0-9][a-zA-Z0-9]*)?$"/>
-            <message key="name.invalidPattern" value="Lambda parameter name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="CatchParameterName">
-            <property name="format" value="^[a-z]([a-z0-9][a-zA-Z0-9]*)?$"/>
-            <message key="name.invalidPattern" value="Catch parameter name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="LocalVariableName">
-            <property name="tokens" value="VARIABLE_DEF"/>
-            <property name="format" value="^[a-z]([a-z0-9][a-zA-Z0-9]*)?$"/>
-            <message key="name.invalidPattern" value="Local variable name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="ClassTypeParameterName">
-            <property name="format" value="(^[A-Z][0-9]?)$|([A-Z][a-zA-Z0-9]*[T]$)"/>
-            <message key="name.invalidPattern" value="Class type name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="MethodTypeParameterName">
-            <property name="format" value="(^[A-Z][0-9]?)$|([A-Z][a-zA-Z0-9]*[T]$)"/>
-            <message key="name.invalidPattern" value="Method type name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="InterfaceTypeParameterName">
-            <property name="format" value="(^[A-Z][0-9]?)$|([A-Z][a-zA-Z0-9]*[T]$)"/>
-            <message key="name.invalidPattern" value="Interface type name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="NoFinalizer"/>
-        <module name="GenericWhitespace">
-            <message key="ws.followed" value="GenericWhitespace ''{0}'' is followed by whitespace."/>
-            <message key="ws.preceded" value="GenericWhitespace ''{0}'' is preceded with whitespace."/>
-            <message key="ws.illegalFollow" value="GenericWhitespace ''{0}'' should followed by whitespace."/>
-            <message key="ws.notPreceded" value="GenericWhitespace ''{0}'' is not preceded with whitespace."/>
-        </module>
-        <module name="Indentation">
-            <property name="basicOffset" value="2"/>
-            <property name="braceAdjustment" value="0"/>
-            <property name="caseIndent" value="2"/>
-            <property name="throwsIndent" value="4"/>
-            <property name="lineWrappingIndentation" value="4"/>
-            <property name="arrayInitIndent" value="2"/>
-        </module>
-        <module name="AbbreviationAsWordInName">
-            <property name="ignoreFinal" value="false"/>
-            <property name="allowedAbbreviationLength" value="1"/>
-        </module>
-        <module name="OverloadMethodsDeclarationOrder"/>
-        <module name="VariableDeclarationUsageDistance"/>
-        <module name="MethodParamPad"/>
-        <module name="NoWhitespaceBefore">
-            <property name="tokens" value="COMMA, SEMI, POST_INC, POST_DEC, DOT, ELLIPSIS, METHOD_REF"/>
-            <property name="allowLineBreaks" value="true"/>
-        </module>
-        <module name="ParenPad"/>
-        <module name="OperatorWrap">
-            <property name="option" value="NL"/>
-            <property name="tokens" value="BAND, BOR, BSR, BXOR, DIV, EQUAL, GE, GT, LAND, LE, LITERAL_INSTANCEOF, LOR,                     LT, MINUS, MOD, NOT_EQUAL, PLUS, QUESTION, SL, SR, STAR, METHOD_REF "/>
-        </module>
-        <module name="AnnotationLocation">
-            <property name="id" value="AnnotationLocationMostCases"/>
-            <property name="tokens" value="CLASS_DEF, INTERFACE_DEF, ENUM_DEF, METHOD_DEF, CTOR_DEF"/>
-        </module>
-        <module name="AnnotationLocation">
-            <property name="id" value="AnnotationLocationVariables"/>
-            <property name="tokens" value="VARIABLE_DEF"/>
-            <property name="allowSamelineMultipleAnnotations" value="true"/>
-        </module>
-        <module name="NonEmptyAtclauseDescription"/>
-        <module name="JavadocTagContinuationIndentation"/>
-        <module name="SummaryJavadoc">
-            <property name="forbiddenSummaryFragments" value="^@return the *|^This method returns |^A [{]@code [a-zA-Z0-9]+[}]( is a )"/>
-        </module>
-        <module name="JavadocParagraph"/>
-        <module name="AtclauseOrder">
-            <property name="tagOrder" value="@param, @return, @throws, @deprecated"/>
-            <property name="target" value="CLASS_DEF, INTERFACE_DEF, ENUM_DEF, METHOD_DEF, CTOR_DEF, VARIABLE_DEF"/>
-        </module>
-        <module name="JavadocMethod">
-            <property name="scope" value="public"/>
-            <property name="allowMissingParamTags" value="true"/>
-            <property name="allowMissingThrowsTags" value="true"/>
-            <property name="allowMissingReturnTag" value="true"/>
-            <property name="minLineCount" value="2"/>
-            <property name="allowedAnnotations" value="Override, Test"/>
-            <property name="allowThrowsTagsForSubclasses" value="true"/>
-        </module>
-        <module name="MethodName">
-            <property name="format" value="^[a-z][a-z0-9][a-zA-Z0-9_]*$"/>
-            <message key="name.invalidPattern" value="Method name ''{0}'' must match pattern ''{1}''."/>
-        </module>
-        <module name="SingleLineJavadoc">
-            <property name="ignoreInlineTags" value="false"/>
-        </module>
-        <module name="EmptyCatchBlock">
-            <property name="exceptionVariableName" value="expected"/>
-        </module>
-        <module name="CommentsIndentation"/>
-    </module>
-</module>
diff --git a/cli/pom.xml b/cli/pom.xml
deleted file mode 100644
index 18413b9..0000000
--- a/cli/pom.xml
+++ /dev/null
@@ -1,165 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <parent>
-        <groupId>org.apache.iotdb</groupId>
-        <artifactId>iotdb-parent</artifactId>
-        <version>0.12.1-SNAPSHOT</version>
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-    <artifactId>iotdb-cli</artifactId>
-    <name>IoTDB Cli</name>
-    <properties>
-        <cli.test.skip>false</cli.test.skip>
-        <cli.it.skip>${cli.test.skip}</cli.it.skip>
-        <cli.ut.skip>${cli.test.skip}</cli.ut.skip>
-    </properties>
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.iotdb</groupId>
-            <artifactId>iotdb-session</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.iotdb</groupId>
-            <artifactId>iotdb-server</artifactId>
-            <version>${project.version}</version>
-            <type>test-jar</type>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.iotdb</groupId>
-            <artifactId>iotdb-jdbc</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>commons-cli</groupId>
-            <artifactId>commons-cli</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.commons</groupId>
-            <artifactId>commons-lang3</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>me.tongfei</groupId>
-            <artifactId>progressbar</artifactId>
-            <version>0.9.0</version>
-        </dependency>
-        <dependency>
-            <groupId>jline</groupId>
-            <artifactId>jline</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.iotdb</groupId>
-            <artifactId>iotdb-server</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency>
-    </dependencies>
-    <build>
-        <plugins>
-            <!--using `mvn test` to run UT, `mvn verify` to run ITs
-            Reference: https://antoniogoncalves.org/2012/12/13/lets-turn-integration-tests-with-maven-to-a-first-class-citizen/-->
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-surefire-plugin</artifactId>
-                <configuration>
-                    <skipTests>${cli.ut.skip}</skipTests>
-                </configuration>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-failsafe-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>run-integration-tests</id>
-                        <phase>integration-test</phase>
-                        <goals>
-                            <goal>integration-test</goal>
-                            <goal>verify</goal>
-                        </goals>
-                    </execution>
-                </executions>
-                <configuration>
-                    <skipTests>${cli.test.skip}</skipTests>
-                    <skipITs>${cli.it.skip}</skipITs>
-                </configuration>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-assembly-plugin</artifactId>
-                <version>${maven.assembly.version}</version>
-                <executions>
-                    <!-- Package binaries-->
-                    <execution>
-                        <id>client-assembly</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>single</goal>
-                        </goals>
-                        <configuration>
-                            <descriptors>
-                                <descriptor>src/assembly/cli.xml</descriptor>
-                            </descriptors>
-                            <appendAssemblyId>false</appendAssemblyId>
-                            <archive>
-                                <manifest>
-                                    <addDefaultImplementationEntries>true</addDefaultImplementationEntries>
-                                    <addDefaultSpecificationEntries>true</addDefaultSpecificationEntries>
-                                </manifest>
-                            </archive>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
-    <profiles>
-        <profile>
-            <id>skipCliTests</id>
-            <activation>
-                <property>
-                    <name>skipTests</name>
-                    <value>true</value>
-                </property>
-            </activation>
-            <properties>
-                <cli.test.skip>true</cli.test.skip>
-                <cli.ut.skip>true</cli.ut.skip>
-                <cli.it.skip>true</cli.it.skip>
-            </properties>
-        </profile>
-        <profile>
-            <id>skipUT_CliTests</id>
-            <activation>
-                <property>
-                    <name>skipUTs</name>
-                    <value>true</value>
-                </property>
-            </activation>
-            <properties>
-                <cli.ut.skip>true</cli.ut.skip>
-            </properties>
-        </profile>
-    </profiles>
-</project>
diff --git a/cli/src/assembly/cli.xml b/cli/src/assembly/cli.xml
deleted file mode 100644
index ca537d7..0000000
--- a/cli/src/assembly/cli.xml
+++ /dev/null
@@ -1,40 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<assembly>
-    <id>cli</id>
-    <formats>
-        <format>dir</format>
-        <format>zip</format>
-    </formats>
-    <includeBaseDirectory>false</includeBaseDirectory>
-    <dependencySets>
-        <dependencySet>
-            <outputDirectory>lib</outputDirectory>
-        </dependencySet>
-    </dependencySets>
-    <fileSets>
-        <fileSet>
-            <directory>src/assembly/resources</directory>
-            <outputDirectory>${file.separator}</outputDirectory>
-        </fileSet>
-    </fileSets>
-</assembly>
diff --git a/cli/src/assembly/resources/sbin/start-cli.bat b/cli/src/assembly/resources/sbin/start-cli.bat
deleted file mode 100644
index 99da3fd..0000000
--- a/cli/src/assembly/resources/sbin/start-cli.bat
+++ /dev/null
@@ -1,74 +0,0 @@
-@REM
-@REM Licensed to the Apache Software Foundation (ASF) under one
-@REM or more contributor license agreements.  See the NOTICE file
-@REM distributed with this work for additional information
-@REM regarding copyright ownership.  The ASF licenses this file
-@REM to you under the Apache License, Version 2.0 (the
-@REM "License"); you may not use this file except in compliance
-@REM with the License.  You may obtain a copy of the License at
-@REM
-@REM     http://www.apache.org/licenses/LICENSE-2.0
-@REM
-@REM Unless required by applicable law or agreed to in writing,
-@REM software distributed under the License is distributed on an
-@REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-@REM KIND, either express or implied.  See the License for the
-@REM specific language governing permissions and limitations
-@REM under the License.
-@REM
-
-@echo off
-
-@REM You can put your env variable here
-@REM set JAVA_HOME=%JAVA_HOME%
-
-if "%OS%" == "Windows_NT" setlocal
-
-pushd %~dp0..
-if NOT DEFINED IOTDB_CLI_HOME set IOTDB_CLI_HOME=%CD%
-popd
-
-if NOT DEFINED MAIN_CLASS set MAIN_CLASS=org.apache.iotdb.cli.WinCli
-if NOT DEFINED JAVA_HOME goto :err
-
-@REM -----------------------------------------------------------------------------
-@REM JVM Opts we'll use in legacy run or installation
-set JAVA_OPTS=-ea^
- -DIOTDB_CLI_HOME="%IOTDB_CLI_HOME%"
-
-REM For each jar in the IOTDB_CLI_HOME lib directory call append to build the CLASSPATH variable.
-set CLASSPATH="%IOTDB_CLI_HOME%\lib\*"
-
-REM -----------------------------------------------------------------------------
-set PARAMETERS=%*
-
-@REM if "%PARAMETERS%" == "" set PARAMETERS=-h 127.0.0.1 -p 6667 -u root -pw root
-
-@REM set default parameters
-set pw_parameter=-pw root
-set u_parameter=-u root
-set p_parameter=-p 6667
-set h_parameter=-h 127.0.0.1
-
-@REM Added parameters when default parameters are missing
-echo %PARAMETERS% | findstr /c:"-pw ">nul && (set PARAMETERS=%PARAMETERS%) || (set PARAMETERS=%pw_parameter% %PARAMETERS%)
-echo %PARAMETERS% | findstr /c:"-u ">nul && (set PARAMETERS=%PARAMETERS%) || (set PARAMETERS=%u_parameter% %PARAMETERS%)
-echo %PARAMETERS% | findstr /c:"-p ">nul && (set PARAMETERS=%PARAMETERS%) || (set PARAMETERS=%p_parameter% %PARAMETERS%)
-echo %PARAMETERS% | findstr /c:"-h ">nul && (set PARAMETERS=%PARAMETERS%) || (set PARAMETERS=%h_parameter% %PARAMETERS%)
-
-echo %PARAMETERS%
-
-"%JAVA_HOME%\bin\java" %JAVA_OPTS% -cp %CLASSPATH% %MAIN_CLASS% %PARAMETERS%
-
-goto finally
-
-
-:err
-echo JAVA_HOME environment variable must be set!
-pause
-
-
-@REM -----------------------------------------------------------------------------
-:finally
-
-ENDLOCAL
\ No newline at end of file
diff --git a/cli/src/assembly/resources/sbin/start-cli.sh b/cli/src/assembly/resources/sbin/start-cli.sh
deleted file mode 100644
index ac96496..0000000
--- a/cli/src/assembly/resources/sbin/start-cli.sh
+++ /dev/null
@@ -1,81 +0,0 @@
-#!/bin/sh
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-# You can put your env variable here
-# export JAVA_HOME=$JAVA_HOME
-
-if [ -z "${IOTDB_CLI_HOME}" ]; then
-  export IOTDB_CLI_HOME="$(cd "`dirname "$0"`"/..; pwd)"
-fi
-
-
-MAIN_CLASS=org.apache.iotdb.cli.Cli
-
-
-CLASSPATH=""
-for f in ${IOTDB_CLI_HOME}/lib/*.jar; do
-  CLASSPATH=${CLASSPATH}":"$f
-done
-
-
-if [ -n "$JAVA_HOME" ]; then
-    for java in "$JAVA_HOME"/bin/amd64/java "$JAVA_HOME"/bin/java; do
-        if [ -x "$java" ]; then
-            JAVA="$java"
-            break
-        fi
-    done
-else
-    JAVA=java
-fi
-
-PARAMETERS="$@"
-
-# if [ $# -eq 0 ]
-# then
-# 	PARAMETERS="-h 127.0.0.1 -p 6667 -u root -pw root"
-# fi
-
-# Added parameters when default parameters are missing
-
-# sh version
-case "$PARAMETERS" in
-*"-pw "*) PARAMETERS=$PARAMETERS ;;
-*            ) PARAMETERS="-pw root $PARAMETERS" ;;
-esac
-case "$PARAMETERS" in
-*"-u "*) PARAMETERS=$PARAMETERS ;;
-*            ) PARAMETERS="-u root $PARAMETERS" ;;
-esac
-case "$PARAMETERS" in
-*"-p "*) PARAMETERS=$PARAMETERS ;;
-*            ) PARAMETERS="-p 6667 $PARAMETERS" ;;
-esac
-case "$PARAMETERS" in
-*"-h "*) PARAMETERS=$PARAMETERS ;;
-*            ) PARAMETERS="-h 127.0.0.1 $PARAMETERS" ;;
-esac
-
-# echo $PARAMETERS
-
-exec "$JAVA" -cp "$CLASSPATH" "$MAIN_CLASS" $PARAMETERS
-
-
-exit $?
diff --git a/cli/src/assembly/resources/tools/export-csv.bat b/cli/src/assembly/resources/tools/export-csv.bat
deleted file mode 100644
index 2514bf6..0000000
--- a/cli/src/assembly/resources/tools/export-csv.bat
+++ /dev/null
@@ -1,56 +0,0 @@
-@REM
-@REM Licensed to the Apache Software Foundation (ASF) under one
-@REM or more contributor license agreements.  See the NOTICE file
-@REM distributed with this work for additional information
-@REM regarding copyright ownership.  The ASF licenses this file
-@REM to you under the Apache License, Version 2.0 (the
-@REM "License"); you may not use this file except in compliance
-@REM with the License.  You may obtain a copy of the License at
-@REM
-@REM     http://www.apache.org/licenses/LICENSE-2.0
-@REM
-@REM Unless required by applicable law or agreed to in writing,
-@REM software distributed under the License is distributed on an
-@REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-@REM KIND, either express or implied.  See the License for the
-@REM specific language governing permissions and limitations
-@REM under the License.
-@REM
-
-@echo off
-echo ````````````````````````````````````````````````
-echo Starting IoTDB Client Export Script
-echo ````````````````````````````````````````````````
-
-if "%OS%" == "Windows_NT" setlocal
-
-pushd %~dp0..
-if NOT DEFINED IOTDB_CLI_HOME set IOTDB_CLI_HOME=%CD%
-popd
-
-if NOT DEFINED MAIN_CLASS set MAIN_CLASS=org.apache.iotdb.tool.ExportCsv
-if NOT DEFINED JAVA_HOME goto :err
-
-@REM -----------------------------------------------------------------------------
-@REM JVM Opts we'll use in legacy run or installation
-set JAVA_OPTS=-ea^
- -DIOTDB_CLI_HOME=%IOTDB_CLI_HOME%
-
-@REM ***** CLASSPATH library setting *****
-set CLASSPATH=%IOTDB_CLI_HOME%\lib\*
-
-REM -----------------------------------------------------------------------------
-
-"%JAVA_HOME%\bin\java" -DIOTDB_CLI_HOME=%IOTDB_CLI_HOME% %JAVA_OPTS% -cp %CLASSPATH% %MAIN_CLASS% %*
-
-goto finally
-
-
-:err
-echo JAVA_HOME environment variable must be set!
-pause
-
-@REM -----------------------------------------------------------------------------
-:finally
-
-ENDLOCAL
\ No newline at end of file
diff --git a/cli/src/assembly/resources/tools/export-csv.sh b/cli/src/assembly/resources/tools/export-csv.sh
deleted file mode 100644
index 375e461..0000000
--- a/cli/src/assembly/resources/tools/export-csv.sh
+++ /dev/null
@@ -1,53 +0,0 @@
-#!/bin/sh
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-echo ------------------------------------------
-echo Starting IoTDB Client Export Script
-echo ------------------------------------------
-
-if [ -z "${IOTDB_CLI_HOME}" ]; then
-    export IOTDB_CLI_HOME="$(cd "`dirname "$0"`"/..; pwd)"
-fi
-
-if [ -n "$JAVA_HOME" ]; then
-    for java in "$JAVA_HOME"/bin/amd64/java "$JAVA_HOME"/bin/java; do
-        if [ -x "$java" ]; then
-            JAVA="$java"
-            break
-        fi
-    done
-else
-    JAVA=java
-fi
-
-if [ -z $JAVA ] ; then
-    echo Unable to find java executable. Check JAVA_HOME and PATH environment variables.  > /dev/stderr
-    exit 1;
-fi
-
-CLASSPATH=""
-for f in ${IOTDB_CLI_HOME}/lib/*.jar; do
-    CLASSPATH=${CLASSPATH}":"$f
-done
-
-MAIN_CLASS=org.apache.iotdb.tool.ExportCsv
-
-"$JAVA" -DIOTDB_CLI_HOME=${IOTDB_CLI_HOME} -cp "$CLASSPATH" "$MAIN_CLASS" "$@"
-exit $?
\ No newline at end of file
diff --git a/cli/src/assembly/resources/tools/import-csv.bat b/cli/src/assembly/resources/tools/import-csv.bat
deleted file mode 100644
index c264bbf..0000000
--- a/cli/src/assembly/resources/tools/import-csv.bat
+++ /dev/null
@@ -1,57 +0,0 @@
-@REM
-@REM Licensed to the Apache Software Foundation (ASF) under one
-@REM or more contributor license agreements.  See the NOTICE file
-@REM distributed with this work for additional information
-@REM regarding copyright ownership.  The ASF licenses this file
-@REM to you under the Apache License, Version 2.0 (the
-@REM "License"); you may not use this file except in compliance
-@REM with the License.  You may obtain a copy of the License at
-@REM
-@REM     http://www.apache.org/licenses/LICENSE-2.0
-@REM
-@REM Unless required by applicable law or agreed to in writing,
-@REM software distributed under the License is distributed on an
-@REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-@REM KIND, either express or implied.  See the License for the
-@REM specific language governing permissions and limitations
-@REM under the License.
-@REM
-
-@echo off
-echo ````````````````````````````````````````````````
-echo Starting IoTDB Client Import Script
-echo ````````````````````````````````````````````````
-
-if "%OS%" == "Windows_NT" setlocal
-
-pushd %~dp0..
-if NOT DEFINED IOTDB_CLI_HOME set IOTDB_CLI_HOME=%CD%
-popd
-
-if NOT DEFINED MAIN_CLASS set MAIN_CLASS=org.apache.iotdb.tool.ImportCsv
-if NOT DEFINED JAVA_HOME goto :err
-
-@REM -----------------------------------------------------------------------------
-@REM JVM Opts we'll use in legacy run or installation
-set JAVA_OPTS=-ea^
- -DIOTDB_CLI_HOME=%IOTDB_CLI_HOME%
-
-@REM ***** CLASSPATH library setting *****
-set CLASSPATH=%IOTDB_CLI_HOME%\lib\*
-
-REM -----------------------------------------------------------------------------
-
-"%JAVA_HOME%\bin\java" -DIOTDB_CLI_HOME=%IOTDB_CLI_HOME% %JAVA_OPTS% -cp %CLASSPATH% %MAIN_CLASS% %*
-
-goto finally
-
-
-:err
-echo JAVA_HOME environment variable must be set!
-pause
-
-
-@REM -----------------------------------------------------------------------------
-:finally
-
-ENDLOCAL
\ No newline at end of file
diff --git a/cli/src/assembly/resources/tools/import-csv.sh b/cli/src/assembly/resources/tools/import-csv.sh
deleted file mode 100644
index 413dc42..0000000
--- a/cli/src/assembly/resources/tools/import-csv.sh
+++ /dev/null
@@ -1,53 +0,0 @@
-#!/bin/sh
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-echo ------------------------------------------
-echo Starting IoTDB Client Import Script
-echo ------------------------------------------
-
-if [ -z "${IOTDB_CLI_HOME}" ]; then
-    export IOTDB_CLI_HOME="$(cd "`dirname "$0"`"/..; pwd)"
-fi
-
-if [ -n "$JAVA_HOME" ]; then
-    for java in "$JAVA_HOME"/bin/amd64/java "$JAVA_HOME"/bin/java; do
-        if [ -x "$java" ]; then
-            JAVA="$java"
-            break
-        fi
-    done
-else
-    JAVA=java
-fi
-
-if [ -z $JAVA ] ; then
-    echo Unable to find java executable. Check JAVA_HOME and PATH environment variables.  > /dev/stderr
-    exit 1;
-fi
-
-CLASSPATH=""
-for f in ${IOTDB_CLI_HOME}/lib/*.jar; do
-    CLASSPATH=${CLASSPATH}":"$f
-done
-
-MAIN_CLASS=org.apache.iotdb.tool.ImportCsv
-
-"$JAVA" -DIOTDB_CLI_HOME=${IOTDB_CLI_HOME} -cp "$CLASSPATH" "$MAIN_CLASS" "$@"
-exit $?
\ No newline at end of file
diff --git a/cli/src/main/java/org/apache/iotdb/cli/AbstractCli.java b/cli/src/main/java/org/apache/iotdb/cli/AbstractCli.java
deleted file mode 100644
index 55216b9..0000000
--- a/cli/src/main/java/org/apache/iotdb/cli/AbstractCli.java
+++ /dev/null
@@ -1,679 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli;
-
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.jdbc.IoTDBConnection;
-import org.apache.iotdb.jdbc.IoTDBJDBCResultSet;
-import org.apache.iotdb.rpc.RpcUtils;
-import org.apache.iotdb.service.rpc.thrift.ServerProperties;
-import org.apache.iotdb.tool.ImportCsv;
-
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.Option;
-import org.apache.commons.cli.Options;
-import org.apache.commons.lang3.ArrayUtils;
-
-import java.io.BufferedReader;
-import java.io.IOException;
-import java.io.InputStreamReader;
-import java.sql.ResultSet;
-import java.sql.ResultSetMetaData;
-import java.sql.SQLException;
-import java.sql.Statement;
-import java.time.ZoneId;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.HashSet;
-import java.util.List;
-import java.util.Set;
-
-import static org.apache.iotdb.cli.utils.IoTPrinter.computeHANCount;
-import static org.apache.iotdb.cli.utils.IoTPrinter.printBlockLine;
-import static org.apache.iotdb.cli.utils.IoTPrinter.printCount;
-import static org.apache.iotdb.cli.utils.IoTPrinter.printRow;
-import static org.apache.iotdb.cli.utils.IoTPrinter.println;
-
-public abstract class AbstractCli {
-
-  static final String HOST_ARGS = "h";
-  static final String HOST_NAME = "host";
-
-  static final String HELP_ARGS = "help";
-
-  static final String PORT_ARGS = "p";
-  static final String PORT_NAME = "port";
-
-  static final String PASSWORD_ARGS = "pw";
-  private static final String PASSWORD_NAME = "password";
-
-  static final String USERNAME_ARGS = "u";
-  static final String USERNAME_NAME = "username";
-
-  private static final String EXECUTE_ARGS = "e";
-  private static final String EXECUTE_NAME = "execute";
-  private static final String NULL = "null";
-
-  static final String ISO8601_ARGS = "disableISO8601";
-  static final List<String> AGGREGRATE_TIME_LIST = new ArrayList<>();
-  static final String MAX_PRINT_ROW_COUNT_ARGS = "maxPRC";
-  private static final String MAX_PRINT_ROW_COUNT_NAME = "maxPrintRowCount";
-  static final String RPC_COMPRESS_ARGS = "c";
-  private static final String RPC_COMPRESS_NAME = "rpcCompressed";
-  static final String SET_MAX_DISPLAY_NUM = "set max_display_num";
-  static final String SET_TIMESTAMP_DISPLAY = "set time_display_type";
-  static final String SHOW_TIMESTAMP_DISPLAY = "show time_display_type";
-  static final String SET_TIME_ZONE = "set time_zone";
-  static final String SHOW_TIMEZONE = "show time_zone";
-  static final String SET_FETCH_SIZE = "set fetch_size";
-  static final String SHOW_FETCH_SIZE = "show fetch_size";
-  private static final String HELP = "help";
-  static final String IOTDB_CLI_PREFIX = "IoTDB";
-  static final String SCRIPT_HINT = "./start-cli.sh(start-cli.bat if Windows)";
-  static final String QUIT_COMMAND = "quit";
-  static final String EXIT_COMMAND = "exit";
-  private static final String SHOW_METADATA_COMMAND = "show timeseries";
-  static final int MAX_HELP_CONSOLE_WIDTH = 88;
-  static final String TIMESTAMP_STR = "Time";
-  private static final String IMPORT_CMD = "import";
-  static int maxPrintRowCount = 1000;
-  private static int fetchSize = 1000;
-  static String timestampPrecision = "ms";
-  static String timeFormat = RpcUtils.DEFAULT_TIME_FORMAT;
-  private static boolean continuePrint = false;
-
-  private static int lineCount = 0;
-  private static final String SUCCESS_MESSAGE = "The statement is executed successfully.";
-
-  private static boolean isReachEnd = false;
-
-  static String host = "127.0.0.1";
-  static String port = "6667";
-  static String username;
-  static String password;
-  static String execute;
-  static boolean hasExecuteSQL = false;
-
-  static Set<String> keywordSet = new HashSet<>();
-
-  static ServerProperties properties = null;
-
-  private static boolean cursorBeforeFirst = true;
-
-  static void init() {
-    keywordSet.add("-" + HOST_ARGS);
-    keywordSet.add("-" + HELP_ARGS);
-    keywordSet.add("-" + PORT_ARGS);
-    keywordSet.add("-" + PASSWORD_ARGS);
-    keywordSet.add("-" + USERNAME_ARGS);
-    keywordSet.add("-" + EXECUTE_ARGS);
-    keywordSet.add("-" + ISO8601_ARGS);
-    keywordSet.add("-" + MAX_PRINT_ROW_COUNT_ARGS);
-    keywordSet.add("-" + RPC_COMPRESS_ARGS);
-  }
-
-  static Options createOptions() {
-    Options options = new Options();
-    Option help = new Option(HELP_ARGS, false, "Display help information(optional)");
-    help.setRequired(false);
-    options.addOption(help);
-
-    Option timeFormat = new Option(ISO8601_ARGS, false, "Display timestamp in number(optional)");
-    timeFormat.setRequired(false);
-    options.addOption(timeFormat);
-
-    Option host =
-        Option.builder(HOST_ARGS)
-            .argName(HOST_NAME)
-            .hasArg()
-            .desc("Host Name (optional, default 127.0.0.1)")
-            .build();
-    options.addOption(host);
-
-    Option port =
-        Option.builder(PORT_ARGS)
-            .argName(PORT_NAME)
-            .hasArg()
-            .desc("Port (optional, default 6667)")
-            .build();
-    options.addOption(port);
-
-    Option username =
-        Option.builder(USERNAME_ARGS)
-            .argName(USERNAME_NAME)
-            .hasArg()
-            .desc("User name (required)")
-            .required()
-            .build();
-    options.addOption(username);
-
-    Option password =
-        Option.builder(PASSWORD_ARGS)
-            .argName(PASSWORD_NAME)
-            .hasArg()
-            .desc("password (optional)")
-            .build();
-    options.addOption(password);
-
-    Option execute =
-        Option.builder(EXECUTE_ARGS)
-            .argName(EXECUTE_NAME)
-            .hasArg()
-            .desc("execute statement (optional)")
-            .build();
-    options.addOption(execute);
-
-    Option maxPrintCount =
-        Option.builder(MAX_PRINT_ROW_COUNT_ARGS)
-            .argName(MAX_PRINT_ROW_COUNT_NAME)
-            .hasArg()
-            .desc("Maximum number of rows displayed (optional)")
-            .build();
-    options.addOption(maxPrintCount);
-
-    Option isRpcCompressed =
-        Option.builder(RPC_COMPRESS_ARGS)
-            .argName(RPC_COMPRESS_NAME)
-            .desc("Rpc Compression enabled or not")
-            .build();
-    options.addOption(isRpcCompressed);
-    return options;
-  }
-
-  static String checkRequiredArg(
-      String arg, String name, CommandLine commandLine, boolean isRequired, String defaultValue)
-      throws ArgsErrorException {
-    String str = commandLine.getOptionValue(arg);
-    if (str == null) {
-      if (isRequired) {
-        String msg =
-            String.format(
-                "%s: Required values for option '%s' not provided", IOTDB_CLI_PREFIX, name);
-        println(msg);
-        println("Use -help for more information");
-        throw new ArgsErrorException(msg);
-      } else if (defaultValue == null) {
-        String msg =
-            String.format("%s: Required values for option '%s' is null.", IOTDB_CLI_PREFIX, name);
-        throw new ArgsErrorException(msg);
-      } else {
-        return defaultValue;
-      }
-    }
-    return str;
-  }
-
-  private static void setFetchSize(String fetchSizeString) {
-    long tmp = Long.parseLong(fetchSizeString.trim());
-    if (tmp > Integer.MAX_VALUE || tmp < 0) {
-      fetchSize = Integer.MAX_VALUE;
-    } else {
-      fetchSize = Integer.parseInt(fetchSizeString.trim());
-    }
-  }
-
-  static void setMaxDisplayNumber(String maxDisplayNum) {
-    long tmp = Long.parseLong(maxDisplayNum.trim());
-    if (tmp > Integer.MAX_VALUE) {
-      throw new NumberFormatException();
-    } else if (tmp <= 0) {
-      continuePrint = true;
-    } else {
-      maxPrintRowCount = Integer.parseInt(maxDisplayNum.trim());
-    }
-  }
-
-  static String[] removePasswordArgs(String[] args) {
-    int index = -1;
-    for (int i = 0; i < args.length; i++) {
-      if (args[i].equals("-" + PASSWORD_ARGS)) {
-        index = i;
-        break;
-      }
-    }
-    if (index >= 0
-        && ((index + 1 >= args.length)
-            || (index + 1 < args.length && keywordSet.contains(args[index + 1])))) {
-      return ArrayUtils.remove(args, index);
-    }
-    return args;
-  }
-
-  @SuppressWarnings("squid:S3776") // Suppress high Cognitive Complexity warning
-  static String[] processExecuteArgs(String[] args) {
-    int index = -1;
-    for (int i = 0; i < args.length; i++) {
-      if (args[i].equals("-" + EXECUTE_ARGS)) {
-        index = i;
-        break;
-      }
-    }
-    if (index >= 0
-        && ((index + 1 >= args.length)
-            || (index + 1 < args.length && keywordSet.contains(args[index + 1])))) {
-      return ArrayUtils.remove(args, index);
-    } else if (index == -1) {
-      return args;
-    } else {
-      StringBuilder executeCommand = new StringBuilder();
-      for (int j = index + 1; j < args.length; j++) {
-        executeCommand.append(args[j]).append(" ");
-      }
-      // remove last space
-      executeCommand.deleteCharAt(executeCommand.length() - 1);
-      // some bashes may not remove quotes of parameters automatically, remove them in that case
-      if (executeCommand.charAt(0) == '\'' || executeCommand.charAt(0) == '\"') {
-        executeCommand.deleteCharAt(0);
-        if (executeCommand.charAt(executeCommand.length() - 1) == '\''
-            || executeCommand.charAt(executeCommand.length() - 1) == '\"') {
-          executeCommand.deleteCharAt(executeCommand.length() - 1);
-        }
-      }
-
-      execute = executeCommand.toString();
-      hasExecuteSQL = true;
-      args = Arrays.copyOfRange(args, 0, index);
-      return args;
-    }
-  }
-
-  static void displayLogo(String version) {
-    println(
-        " _____       _________  ______   ______    \n"
-            + "|_   _|     |  _   _  ||_   _ `.|_   _ \\   \n"
-            + "  | |   .--.|_/ | | \\_|  | | `. \\ | |_) |  \n"
-            + "  | | / .'`\\ \\  | |      | |  | | |  __'.  \n"
-            + " _| |_| \\__. | _| |_    _| |_.' /_| |__) | \n"
-            + "|_____|'.__.' |_____|  |______.'|_______/  version "
-            + version
-            + "\n"
-            + "                                           \n");
-  }
-
-  static void echoStarting() {
-    println("---------------------");
-    println("Starting IoTDB Cli");
-    println("---------------------");
-  }
-
-  static OperationResult handleInputCmd(String cmd, IoTDBConnection connection) {
-    String specialCmd = cmd.toLowerCase().trim();
-
-    if (QUIT_COMMAND.equals(specialCmd) || EXIT_COMMAND.equals(specialCmd)) {
-      return OperationResult.STOP_OPER;
-    }
-    if (HELP.equals(specialCmd)) {
-      showHelp();
-      return OperationResult.CONTINUE_OPER;
-    }
-    if (specialCmd.startsWith(SET_TIMESTAMP_DISPLAY)) {
-      setTimestampDisplay(specialCmd, cmd);
-      return OperationResult.CONTINUE_OPER;
-    }
-
-    if (specialCmd.startsWith(SET_TIME_ZONE)) {
-      setTimeZone(specialCmd, cmd, connection);
-      return OperationResult.CONTINUE_OPER;
-    }
-
-    if (specialCmd.startsWith(SET_FETCH_SIZE)) {
-      setFetchSize(specialCmd, cmd);
-      return OperationResult.CONTINUE_OPER;
-    }
-
-    if (specialCmd.startsWith(SET_MAX_DISPLAY_NUM)) {
-      setMaxDisplayNum(specialCmd, cmd);
-      return OperationResult.CONTINUE_OPER;
-    }
-
-    if (specialCmd.startsWith(SHOW_TIMEZONE)) {
-      showTimeZone(connection);
-      return OperationResult.CONTINUE_OPER;
-    }
-    if (specialCmd.startsWith(SHOW_TIMESTAMP_DISPLAY)) {
-      println("Current time format: " + timeFormat);
-      return OperationResult.CONTINUE_OPER;
-    }
-    if (specialCmd.startsWith(SHOW_FETCH_SIZE)) {
-      println("Current fetch size: " + fetchSize);
-      return OperationResult.CONTINUE_OPER;
-    }
-
-    if (specialCmd.startsWith(IMPORT_CMD)) {
-      importCmd(specialCmd, cmd, connection);
-      return OperationResult.CONTINUE_OPER;
-    }
-
-    executeQuery(connection, cmd);
-    return OperationResult.NO_OPER;
-  }
-
-  private static void showHelp() {
-    println("    <your-sql>\t\t\t execute your sql statment");
-    println(
-        String.format("    %s\t\t show how many timeseries are in iotdb", SHOW_METADATA_COMMAND));
-    println(
-        String.format(
-            "    %s=xxx\t eg. long, default, ISO8601, yyyy-MM-dd HH:mm:ss.",
-            SET_TIMESTAMP_DISPLAY));
-    println(String.format("    %s\t show time display type", SHOW_TIMESTAMP_DISPLAY));
-    println(String.format("    %s=xxx\t\t eg. +08:00, Asia/Shanghai.", SET_TIME_ZONE));
-    println(String.format("    %s\t\t show cli time zone", SHOW_TIMEZONE));
-    println(
-        String.format(
-            "    %s=xxx\t\t set fetch size when querying data from server.", SET_FETCH_SIZE));
-    println(String.format("    %s\t\t show fetch size", SHOW_FETCH_SIZE));
-    println(
-        String.format(
-            "    %s=xxx\t eg. set max lines for cli to ouput, -1 equals to unlimited.",
-            SET_MAX_DISPLAY_NUM));
-  }
-
-  private static void setTimestampDisplay(String specialCmd, String cmd) {
-    String[] values = specialCmd.split("=");
-    if (values.length != 2) {
-      println(
-          String.format(
-              "Time display format error, please input like %s=ISO8601", SET_TIMESTAMP_DISPLAY));
-      return;
-    }
-    try {
-      timeFormat = RpcUtils.setTimeFormat(cmd.split("=")[1]);
-    } catch (Exception e) {
-      println(String.format("time display format error, %s", e.getMessage()));
-      return;
-    }
-    println("Time display type has set to " + cmd.split("=")[1].trim());
-  }
-
-  /**
-   * if cli has not specified a zondId, it will be set to cli's system timezone by default otherwise
-   * for insert and query accuracy cli should set timezone the same for all sessions
-   *
-   * @param specialCmd
-   * @param cmd
-   * @param connection
-   */
-  private static void setTimeZone(String specialCmd, String cmd, IoTDBConnection connection) {
-    String[] values = specialCmd.split("=");
-    if (values.length != 2) {
-      println(String.format("Time zone format error, please input like %s=+08:00", SET_TIME_ZONE));
-      return;
-    }
-    try {
-      connection.setTimeZone(cmd.split("=")[1].trim());
-    } catch (Exception e) {
-      println(String.format("Time zone format error: %s", e.getMessage()));
-      return;
-    }
-    println("Time zone has set to " + values[1].trim());
-  }
-
-  private static void setFetchSize(String specialCmd, String cmd) {
-    String[] values = specialCmd.split("=");
-    if (values.length != 2) {
-      println(String.format("Fetch size format error, please input like %s=10000", SET_FETCH_SIZE));
-      return;
-    }
-    try {
-      setFetchSize(cmd.split("=")[1]);
-    } catch (Exception e) {
-      println(String.format("Fetch size format error, %s", e.getMessage()));
-      return;
-    }
-    println("Fetch size has set to " + values[1].trim());
-  }
-
-  private static void setMaxDisplayNum(String specialCmd, String cmd) {
-    String[] values = specialCmd.split("=");
-    if (values.length != 2) {
-      println(
-          String.format(
-              "Max display number format error, please input like %s = 10000",
-              SET_MAX_DISPLAY_NUM));
-      return;
-    }
-    try {
-      setMaxDisplayNumber(cmd.split("=")[1]);
-    } catch (Exception e) {
-      println(String.format("Max display number format error, %s", e.getMessage()));
-      return;
-    }
-    println("Max display number has set to " + values[1].trim());
-  }
-
-  private static void showTimeZone(IoTDBConnection connection) {
-    try {
-      println("Current time zone: " + connection.getTimeZone());
-    } catch (Exception e) {
-      println("Cannot get time zone from server side because: " + e.getMessage());
-    }
-  }
-
-  private static void importCmd(String specialCmd, String cmd, IoTDBConnection connection) {
-    String[] values = specialCmd.split(" ");
-    if (values.length != 2) {
-      println(
-          "Please input like: import /User/myfile. "
-              + "Noted that your file path cannot contain any space character)");
-      return;
-    }
-    println(cmd.split(" ")[1]);
-    ImportCsv.importCsvFromFile(
-        host, port, username, password, cmd.split(" ")[1], connection.getTimeZone());
-  }
-
-  private static void executeQuery(IoTDBConnection connection, String cmd) {
-    long startTime = System.currentTimeMillis();
-    try (Statement statement = connection.createStatement()) {
-      ZoneId zoneId = ZoneId.of(connection.getTimeZone());
-      statement.setFetchSize(fetchSize);
-      boolean hasResultSet = statement.execute(cmd.trim());
-      if (hasResultSet) {
-        // print the result
-        try (ResultSet resultSet = statement.getResultSet()) {
-          ResultSetMetaData resultSetMetaData = resultSet.getMetaData();
-          int columnLength = resultSetMetaData.getColumnCount();
-          List<Integer> maxSizeList = new ArrayList<>(columnLength);
-          List<List<String>> lists =
-              cacheResult(resultSet, maxSizeList, columnLength, resultSetMetaData, zoneId);
-          output(lists, maxSizeList);
-          long costTime = System.currentTimeMillis() - startTime;
-          println(String.format("It costs %.3fs", costTime / 1000.0));
-          while (!isReachEnd) {
-            if (continuePrint) {
-              maxSizeList = new ArrayList<>(columnLength);
-              lists = cacheResult(resultSet, maxSizeList, columnLength, resultSetMetaData, zoneId);
-              output(lists, maxSizeList);
-              continue;
-            }
-            println(
-                String.format(
-                    "Reach the max_display_num = %s. Press ENTER to show more, input 'q' to quit.",
-                    maxPrintRowCount));
-            BufferedReader br = new BufferedReader(new InputStreamReader(System.in));
-            try {
-              if (br.readLine().equals("")) {
-                maxSizeList = new ArrayList<>(columnLength);
-                lists =
-                    cacheResult(resultSet, maxSizeList, columnLength, resultSetMetaData, zoneId);
-                output(lists, maxSizeList);
-              } else {
-                break;
-              }
-            } catch (IOException e) {
-              e.printStackTrace();
-            }
-          }
-        }
-      } else {
-        println("Msg: " + SUCCESS_MESSAGE);
-      }
-    } catch (Exception e) {
-      println("Msg: " + e.getMessage());
-    } finally {
-      resetArgs();
-    }
-  }
-
-  /**
-   * cache all results
-   *
-   * @param resultSet jdbc resultSet
-   * @param maxSizeList the longest result of every column
-   * @param columnCount the number of column
-   * @param resultSetMetaData jdbc resultSetMetaData
-   * @param zoneId your time zone
-   * @return List<List<String>> result
-   * @throws SQLException throw exception
-   */
-  @SuppressWarnings("squid:S3776") // Suppress high Cognitive Complexity warning
-  private static List<List<String>> cacheResult(
-      ResultSet resultSet,
-      List<Integer> maxSizeList,
-      int columnCount,
-      ResultSetMetaData resultSetMetaData,
-      ZoneId zoneId)
-      throws SQLException {
-
-    int j = 0;
-    if (cursorBeforeFirst) {
-      isReachEnd = !resultSet.next();
-      cursorBeforeFirst = false;
-    }
-
-    List<List<String>> lists = new ArrayList<>(columnCount);
-    if (resultSet instanceof IoTDBJDBCResultSet) {
-      for (int i = 1; i <= columnCount; i++) {
-        List<String> list = new ArrayList<>(maxPrintRowCount + 1);
-        String columnLabel = resultSetMetaData.getColumnLabel(i);
-        list.add(columnLabel);
-        lists.add(list);
-        int count = computeHANCount(columnLabel);
-        maxSizeList.add(columnLabel.length() + count);
-      }
-
-      boolean printTimestamp = !((IoTDBJDBCResultSet) resultSet).isIgnoreTimeStamp();
-      while (j < maxPrintRowCount && !isReachEnd) {
-        for (int i = 1; i <= columnCount; i++) {
-          String tmp;
-          if (printTimestamp && i == 1) {
-            tmp =
-                RpcUtils.formatDatetime(
-                    timeFormat, timestampPrecision, resultSet.getLong(TIMESTAMP_STR), zoneId);
-          } else {
-            tmp = resultSet.getString(i);
-          }
-          if (tmp == null) {
-            tmp = NULL;
-          }
-          lists.get(i - 1).add(tmp);
-          int count = computeHANCount(tmp);
-          int realLength = tmp.length() + count;
-          if (maxSizeList.get(i - 1) < realLength) {
-            maxSizeList.set(i - 1, realLength);
-          }
-        }
-        j++;
-        isReachEnd = !resultSet.next();
-      }
-      return lists;
-    }
-
-    for (int i = 1; i <= columnCount; i += 2) {
-      List<String> timeList = new ArrayList<>(maxPrintRowCount + 1);
-      timeList.add(resultSetMetaData.getColumnLabel(i).substring(0, TIMESTAMP_STR.length()));
-      lists.add(timeList);
-      List<String> valueList = new ArrayList<>(maxPrintRowCount + 1);
-      valueList.add(resultSetMetaData.getColumnLabel(i + 1));
-      lists.add(valueList);
-      maxSizeList.add(TIMESTAMP_STR.length());
-      maxSizeList.add(resultSetMetaData.getColumnLabel(i + 1).length());
-    }
-
-    while (j < maxPrintRowCount && !isReachEnd) {
-      for (int i = 1; i <= columnCount; i++) {
-        String tmp = resultSet.getString(i);
-        if (tmp == null) {
-          tmp = NULL;
-        }
-        if (i % 2 != 0 && !tmp.equals(NULL)) {
-          tmp =
-              RpcUtils.formatDatetime(timeFormat, timestampPrecision, Long.parseLong(tmp), zoneId);
-        }
-        lists.get(i - 1).add(tmp);
-        if (maxSizeList.get(i - 1) < tmp.length()) {
-          maxSizeList.set(i - 1, tmp.length());
-        }
-      }
-      j++;
-      isReachEnd = !resultSet.next();
-    }
-    return lists;
-  }
-
-  private static void output(List<List<String>> lists, List<Integer> maxSizeList) {
-    printBlockLine(maxSizeList);
-    printRow(lists, 0, maxSizeList);
-    printBlockLine(maxSizeList);
-    for (int i = 1; i < lists.get(0).size(); i++) {
-      printRow(lists, i, maxSizeList);
-    }
-    printBlockLine(maxSizeList);
-    if (isReachEnd) {
-      lineCount += lists.get(0).size() - 1;
-      printCount(lineCount);
-    } else {
-      lineCount += maxPrintRowCount;
-    }
-  }
-
-  private static void resetArgs() {
-    lineCount = 0;
-    cursorBeforeFirst = true;
-    isReachEnd = false;
-  }
-
-  enum OperationResult {
-    STOP_OPER,
-    CONTINUE_OPER,
-    NO_OPER
-  }
-
-  static boolean processCommand(String s, IoTDBConnection connection) {
-    if (s == null) {
-      return true;
-    }
-    String[] cmds = s.trim().split(";");
-    for (String cmd : cmds) {
-      if (cmd != null && !"".equals(cmd.trim())) {
-        OperationResult result = handleInputCmd(cmd, connection);
-        switch (result) {
-          case STOP_OPER:
-            return false;
-          case CONTINUE_OPER:
-            continue;
-          default:
-            break;
-        }
-      }
-    }
-    return true;
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/cli/Cli.java b/cli/src/main/java/org/apache/iotdb/cli/Cli.java
deleted file mode 100644
index d1b0735..0000000
--- a/cli/src/main/java/org/apache/iotdb/cli/Cli.java
+++ /dev/null
@@ -1,171 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli;
-
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.jdbc.Config;
-import org.apache.iotdb.jdbc.IoTDBConnection;
-import org.apache.iotdb.rpc.RpcUtils;
-
-import jline.console.ConsoleReader;
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.CommandLineParser;
-import org.apache.commons.cli.DefaultParser;
-import org.apache.commons.cli.HelpFormatter;
-import org.apache.commons.cli.Options;
-import org.apache.commons.cli.ParseException;
-import org.apache.thrift.TException;
-
-import java.io.IOException;
-import java.sql.DriverManager;
-import java.sql.SQLException;
-
-import static org.apache.iotdb.cli.utils.IoTPrinter.println;
-
-/** args[]: -h 127.0.0.1 -p 6667 -u root -pw root */
-public class Cli extends AbstractCli {
-
-  private static CommandLine commandLine;
-
-  /**
-   * IoTDB Client main function.
-   *
-   * @param args launch arguments
-   * @throws ClassNotFoundException ClassNotFoundException
-   */
-  public static void main(String[] args) throws ClassNotFoundException {
-    Class.forName(Config.JDBC_DRIVER_NAME);
-    Options options = createOptions();
-    HelpFormatter hf = new HelpFormatter();
-    hf.setWidth(MAX_HELP_CONSOLE_WIDTH);
-    commandLine = null;
-
-    if (args == null || args.length == 0) {
-      println(
-          "Require more params input, eg. ./start-cli.sh(start-cli.bat if Windows) "
-              + "-h xxx.xxx.xxx.xxx -p xxxx -u xxx.");
-      println("For more information, please check the following hint.");
-      hf.printHelp(SCRIPT_HINT, options, true);
-      return;
-    }
-    init();
-    String[] newArgs = removePasswordArgs(args);
-    String[] newArgs2 = processExecuteArgs(newArgs);
-    boolean continues = parseCommandLine(options, newArgs2, hf);
-    if (!continues) {
-      return;
-    }
-
-    serve();
-  }
-
-  private static boolean parseCommandLine(Options options, String[] newArgs, HelpFormatter hf) {
-    try {
-      CommandLineParser parser = new DefaultParser();
-      commandLine = parser.parse(options, newArgs);
-      if (commandLine.hasOption(HELP_ARGS)) {
-        hf.printHelp(SCRIPT_HINT, options, true);
-        return false;
-      }
-      if (commandLine.hasOption(RPC_COMPRESS_ARGS)) {
-        Config.rpcThriftCompressionEnable = true;
-      }
-      if (commandLine.hasOption(ISO8601_ARGS)) {
-        timeFormat = RpcUtils.setTimeFormat("long");
-      }
-      if (commandLine.hasOption(MAX_PRINT_ROW_COUNT_ARGS)) {
-        setMaxDisplayNumber(commandLine.getOptionValue(MAX_PRINT_ROW_COUNT_ARGS));
-      }
-    } catch (ParseException e) {
-      println(
-          "Require more params input, eg. ./start-cli.sh(start-cli.bat if Windows) "
-              + "-h xxx.xxx.xxx.xxx -p xxxx -u xxx.");
-      println("For more information, please check the following hint.");
-      hf.printHelp(IOTDB_CLI_PREFIX, options, true);
-      return false;
-    } catch (NumberFormatException e) {
-      println(
-          IOTDB_CLI_PREFIX
-              + "> error format of max print row count, it should be a number and greater than 0");
-      return false;
-    }
-    return true;
-  }
-
-  private static void serve() {
-    try {
-      host = checkRequiredArg(HOST_ARGS, HOST_NAME, commandLine, false, host);
-      port = checkRequiredArg(PORT_ARGS, PORT_NAME, commandLine, false, port);
-      username = checkRequiredArg(USERNAME_ARGS, USERNAME_NAME, commandLine, true, null);
-
-      password = commandLine.getOptionValue(PASSWORD_ARGS);
-      if (hasExecuteSQL && password != null) {
-        try (IoTDBConnection connection =
-            (IoTDBConnection)
-                DriverManager.getConnection(
-                    Config.IOTDB_URL_PREFIX + host + ":" + port + "/", username, password)) {
-          properties = connection.getServerProperties();
-          AGGREGRATE_TIME_LIST.addAll(properties.getSupportedTimeAggregationOperations());
-          processCommand(execute, connection);
-          return;
-        } catch (SQLException e) {
-          println(IOTDB_CLI_PREFIX + "> can't execute sql because" + e.getMessage());
-        }
-      }
-      try (ConsoleReader reader = new ConsoleReader()) {
-        reader.setExpandEvents(false);
-        if (password == null) {
-          password = reader.readLine("please input your password:", '\0');
-        }
-        receiveCommands(reader);
-      }
-    } catch (ArgsErrorException e) {
-      println(IOTDB_CLI_PREFIX + "> input params error because" + e.getMessage());
-    } catch (Exception e) {
-      println(IOTDB_CLI_PREFIX + "> exit cli with error " + e.getMessage());
-    }
-  }
-
-  private static void receiveCommands(ConsoleReader reader) throws TException, IOException {
-    try (IoTDBConnection connection =
-        (IoTDBConnection)
-            DriverManager.getConnection(
-                Config.IOTDB_URL_PREFIX + host + ":" + port + "/", username, password)) {
-      String s;
-      properties = connection.getServerProperties();
-      AGGREGRATE_TIME_LIST.addAll(properties.getSupportedTimeAggregationOperations());
-      timestampPrecision = properties.getTimestampPrecision();
-
-      echoStarting();
-      displayLogo(properties.getVersion());
-      println(IOTDB_CLI_PREFIX + "> login successfully");
-      while (true) {
-        s = reader.readLine(IOTDB_CLI_PREFIX + "> ", null);
-        boolean continues = processCommand(s, connection);
-        if (!continues) {
-          break;
-        }
-      }
-    } catch (SQLException e) {
-      println(
-          String.format(
-              "%s> %s Host is %s, port is %s.", IOTDB_CLI_PREFIX, e.getMessage(), host, port));
-    }
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/cli/WinCli.java b/cli/src/main/java/org/apache/iotdb/cli/WinCli.java
deleted file mode 100644
index 1ef3cd9..0000000
--- a/cli/src/main/java/org/apache/iotdb/cli/WinCli.java
+++ /dev/null
@@ -1,178 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli;
-
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.jdbc.Config;
-import org.apache.iotdb.jdbc.IoTDBConnection;
-import org.apache.iotdb.rpc.RpcUtils;
-
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.CommandLineParser;
-import org.apache.commons.cli.DefaultParser;
-import org.apache.commons.cli.HelpFormatter;
-import org.apache.commons.cli.Options;
-import org.apache.commons.cli.ParseException;
-import org.apache.thrift.TException;
-
-import java.io.Console;
-import java.sql.DriverManager;
-import java.sql.SQLException;
-import java.util.Scanner;
-
-import static org.apache.iotdb.cli.utils.IoTPrinter.print;
-import static org.apache.iotdb.cli.utils.IoTPrinter.println;
-
-/** args[]: -h 127.0.0.1 -p 6667 -u root -pw root */
-public class WinCli extends AbstractCli {
-
-  private static CommandLine commandLine;
-
-  /**
-   * main function.
-   *
-   * @param args -console args
-   */
-  public static void main(String[] args) throws ClassNotFoundException {
-    Class.forName(Config.JDBC_DRIVER_NAME);
-    Options options = createOptions();
-    HelpFormatter hf = new HelpFormatter();
-    hf.setWidth(MAX_HELP_CONSOLE_WIDTH);
-    commandLine = null;
-
-    if (args == null || args.length == 0) {
-      println("Require more params input, please check the following hint.");
-      hf.printHelp(IOTDB_CLI_PREFIX, options, true);
-      return;
-    }
-
-    init();
-    String[] newArgs = removePasswordArgs(args);
-    String[] newArgs2 = processExecuteArgs(newArgs);
-    boolean continues = parseCommandLine(options, newArgs2, hf);
-    if (!continues) {
-      return;
-    }
-
-    serve();
-  }
-
-  private static String readPassword() {
-    Console c = System.console();
-    if (c == null) { // IN ECLIENTPSE IDE
-      print(IOTDB_CLI_PREFIX + "> please input password: ");
-      Scanner scanner = new Scanner(System.in);
-      return scanner.nextLine();
-    } else { // Outside Eclipse IDE
-      return new String(c.readPassword(IOTDB_CLI_PREFIX + "> please input password: "));
-    }
-  }
-
-  private static boolean parseCommandLine(Options options, String[] newArgs, HelpFormatter hf) {
-    try {
-      CommandLineParser parser = new DefaultParser();
-      commandLine = parser.parse(options, newArgs);
-      if (commandLine.hasOption(HELP_ARGS)) {
-        hf.printHelp(IOTDB_CLI_PREFIX, options, true);
-        return false;
-      }
-      if (commandLine.hasOption(RPC_COMPRESS_ARGS)) {
-        Config.rpcThriftCompressionEnable = true;
-      }
-      if (commandLine.hasOption(ISO8601_ARGS)) {
-        timeFormat = RpcUtils.setTimeFormat("long");
-      }
-      if (commandLine.hasOption(MAX_PRINT_ROW_COUNT_ARGS)) {
-        maxPrintRowCount = Integer.parseInt(commandLine.getOptionValue(MAX_PRINT_ROW_COUNT_ARGS));
-        if (maxPrintRowCount <= 0) {
-          println(
-              IOTDB_CLI_PREFIX
-                  + "> error format of max print row count, it should be a number greater than 0");
-          return false;
-        }
-      }
-    } catch (ParseException e) {
-      println("Require more params input, please check the following hint.");
-      hf.printHelp(IOTDB_CLI_PREFIX, options, true);
-      return false;
-    } catch (NumberFormatException e) {
-      println(IOTDB_CLI_PREFIX + "> error format of max print row count, it should be a number");
-      return false;
-    }
-    return true;
-  }
-
-  private static void serve() {
-    try (Scanner scanner = new Scanner(System.in)) {
-      host = checkRequiredArg(HOST_ARGS, HOST_NAME, commandLine, false, host);
-      port = checkRequiredArg(PORT_ARGS, PORT_NAME, commandLine, false, port);
-      username = checkRequiredArg(USERNAME_ARGS, USERNAME_NAME, commandLine, true, null);
-      password = commandLine.getOptionValue(PASSWORD_ARGS);
-      if (password == null) {
-        password = readPassword();
-      }
-      if (hasExecuteSQL) {
-        try (IoTDBConnection connection =
-            (IoTDBConnection)
-                DriverManager.getConnection(
-                    Config.IOTDB_URL_PREFIX + host + ":" + port + "/", username, password)) {
-          properties = connection.getServerProperties();
-          AGGREGRATE_TIME_LIST.addAll(properties.getSupportedTimeAggregationOperations());
-          processCommand(execute, connection);
-          return;
-        } catch (SQLException e) {
-          println(IOTDB_CLI_PREFIX + "> can't execute sql because" + e.getMessage());
-        }
-      }
-
-      receiveCommands(scanner);
-    } catch (ArgsErrorException e) {
-      println(IOTDB_CLI_PREFIX + "> input params error because" + e.getMessage());
-    } catch (Exception e) {
-      println(IOTDB_CLI_PREFIX + "> exit cli with error " + e.getMessage());
-    }
-  }
-
-  private static void receiveCommands(Scanner scanner) throws TException {
-    try (IoTDBConnection connection =
-        (IoTDBConnection)
-            DriverManager.getConnection(
-                Config.IOTDB_URL_PREFIX + host + ":" + port + "/", username, password)) {
-      properties = connection.getServerProperties();
-      AGGREGRATE_TIME_LIST.addAll(properties.getSupportedTimeAggregationOperations());
-      timestampPrecision = properties.getTimestampPrecision();
-
-      echoStarting();
-      displayLogo(properties.getVersion());
-      println(IOTDB_CLI_PREFIX + "> login successfully");
-      while (true) {
-        print(IOTDB_CLI_PREFIX + "> ");
-        String s = scanner.nextLine();
-        boolean continues = processCommand(s, connection);
-        if (!continues) {
-          break;
-        }
-      }
-    } catch (SQLException e) {
-      println(
-          String.format(
-              "%s> %s Host is %s, port is %s.", IOTDB_CLI_PREFIX, e.getMessage(), host, port));
-    }
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/cli/utils/IoTPrinter.java b/cli/src/main/java/org/apache/iotdb/cli/utils/IoTPrinter.java
deleted file mode 100644
index 407e6f6..0000000
--- a/cli/src/main/java/org/apache/iotdb/cli/utils/IoTPrinter.java
+++ /dev/null
@@ -1,106 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli.utils;
-
-import org.apache.commons.lang3.StringUtils;
-
-import java.io.PrintStream;
-import java.lang.Character.UnicodeScript;
-import java.util.List;
-
-public class IoTPrinter {
-  private static final PrintStream SCREEN_PRINTER = new PrintStream(System.out);
-
-  public static void printf(String format, Object... args) {
-    SCREEN_PRINTER.printf(format, args);
-  }
-
-  public static void print(String msg) {
-    SCREEN_PRINTER.print(msg);
-  }
-
-  public static void println() {
-    SCREEN_PRINTER.println();
-  }
-
-  public static void println(String msg) {
-    SCREEN_PRINTER.println(msg);
-  }
-
-  public static void printBlockLine(List<Integer> maxSizeList) {
-    StringBuilder blockLine = new StringBuilder();
-    for (Integer integer : maxSizeList) {
-      blockLine.append("+").append(StringUtils.repeat("-", integer));
-    }
-    blockLine.append("+");
-    println(blockLine.toString());
-  }
-
-  public static void printRow(List<List<String>> lists, int i, List<Integer> maxSizeList) {
-    printf("|");
-    int count;
-    int maxSize;
-    String element;
-    StringBuilder paddingStr;
-    for (int j = 0; j < maxSizeList.size(); j++) {
-      maxSize = maxSizeList.get(j);
-      element = lists.get(j).get(i);
-      count = computeHANCount(element);
-
-      if (count > 0) {
-        int remain = maxSize - (element.length() + count);
-        if (remain > 0) {
-          paddingStr = padding(remain);
-          maxSize = maxSize - count;
-          element = paddingStr.append(element).toString();
-        } else if (remain == 0) {
-          maxSize = maxSize - count;
-        }
-      }
-
-      printf("%" + maxSize + "s|", element);
-    }
-    println();
-  }
-
-  public static void printCount(int cnt) {
-    if (cnt == 0) {
-      println("Empty set.");
-    } else {
-      println("Total line number = " + cnt);
-    }
-  }
-
-  public static StringBuilder padding(int count) {
-    StringBuilder sb = new StringBuilder();
-    for (int k = 0; k < count; k++) {
-      sb.append(' ');
-    }
-
-    return sb;
-  }
-
-  /** compute the number of Chinese characters included in the String */
-  public static int computeHANCount(String s) {
-    return (int)
-        s.codePoints()
-            .filter(codePoint -> UnicodeScript.of(codePoint) == UnicodeScript.HAN)
-            .count();
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/exception/ArgsErrorException.java b/cli/src/main/java/org/apache/iotdb/exception/ArgsErrorException.java
deleted file mode 100644
index eabba3b..0000000
--- a/cli/src/main/java/org/apache/iotdb/exception/ArgsErrorException.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.exception;
-
-public class ArgsErrorException extends Exception {
-
-  private static final long serialVersionUID = -3614543017182165265L;
-
-  public ArgsErrorException(String msg) {
-    super(msg);
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/tool/AbstractCsvTool.java b/cli/src/main/java/org/apache/iotdb/tool/AbstractCsvTool.java
deleted file mode 100644
index 90764b5..0000000
--- a/cli/src/main/java/org/apache/iotdb/tool/AbstractCsvTool.java
+++ /dev/null
@@ -1,191 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.tool;
-
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.session.Session;
-
-import jline.console.ConsoleReader;
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.Option;
-import org.apache.commons.cli.Options;
-
-import java.io.IOException;
-import java.time.ZoneId;
-
-public abstract class AbstractCsvTool {
-
-  protected static final String HOST_ARGS = "h";
-  protected static final String HOST_NAME = "host";
-
-  protected static final String HELP_ARGS = "help";
-
-  protected static final String PORT_ARGS = "p";
-  protected static final String PORT_NAME = "port";
-
-  protected static final String PASSWORD_ARGS = "pw";
-  protected static final String PASSWORD_NAME = "password";
-
-  protected static final String USERNAME_ARGS = "u";
-  protected static final String USERNAME_NAME = "username";
-
-  protected static final String TIME_FORMAT_ARGS = "tf";
-  protected static final String TIME_FORMAT_NAME = "timeformat";
-
-  protected static final String TIME_ZONE_ARGS = "tz";
-  protected static final String TIME_ZONE_NAME = "timeZone";
-  protected static final int MAX_HELP_CONSOLE_WIDTH = 92;
-  protected static final String[] TIME_FORMAT =
-      new String[] {"default", "long", "number", "timestamp"};
-  protected static final String[] STRING_TIME_FORMAT =
-      new String[] {
-        "yyyy-MM-dd'T'HH:mm:ss.SSSZ",
-        "yyyy/MM/dd HH:mm:ss.SSS",
-        "yyyy-MM-dd HH:mm:ss.SSS",
-        "yyyy.MM.dd HH:mm:ss.SSS",
-        "yyyy/MM/dd'T'HH:mm:ss.SSS",
-        "yyyy-MM-dd'T'HH:mm:ss.SSS",
-        "yyyy-MM-dd'T'HH:mm:ss.SSS",
-        "yyyy.MM.dd'T'HH:mm:ss.SSS",
-        "yyyy-MM-dd HH:mm:ss.SSSZZ",
-        "yyyy/MM/dd HH:mm:ss.SSSZZ",
-        "yyyy.MM.dd HH:mm:ss.SSSZZ",
-        "yyyy-MM-dd'T'HH:mm:ss.SSSZZ",
-        "yyyy/MM/dd'T'HH:mm:ss.SSSZZ",
-        "yyyy-MM-dd HH:mm:ss",
-        "yyyy/MM/dd HH:mm:ss",
-        "yyyy.MM.dd HH:mm:ss",
-        "yyyy-MM-dd'T'HH:mm:ss",
-        "yyyy/MM/dd'T'HH:mm:ss",
-        "yyyy.MM.dd'T'HH:mm:ss",
-        "yyyy-MM-dd HH:mm:ssZZ",
-        "yyyy/MM/dd HH:mm:ssZZ",
-        "yyyy.MM.dd HH:mm:ssZZ",
-        "yyyy-MM-dd'T'HH:mm:ssZZ",
-        "yyyy/MM/dd'T'HH:mm:ssZZ",
-        "yyyy.MM.dd'T'HH:mm:ssZZ",
-      };
-  protected static String host;
-  protected static String port;
-  protected static String username;
-  protected static String password;
-  protected static ZoneId zoneId;
-
-  protected static String timeZoneID;
-  protected static String timeFormat;
-  protected static Session session;
-
-  AbstractCsvTool() {}
-
-  protected static String checkRequiredArg(String arg, String name, CommandLine commandLine)
-      throws ArgsErrorException {
-    String str = commandLine.getOptionValue(arg);
-    if (str == null) {
-      String msg = String.format("Required values for option '%s' not provided", name);
-      System.out.println(msg);
-      System.out.println("Use -help for more information");
-      throw new ArgsErrorException(msg);
-    }
-    return str;
-  }
-
-  protected static void setTimeZone() throws IoTDBConnectionException, StatementExecutionException {
-    if (timeZoneID != null) {
-      session.setTimeZone(timeZoneID);
-    }
-    zoneId = ZoneId.of(session.getTimeZone());
-  }
-
-  protected static void parseBasicParams(CommandLine commandLine, ConsoleReader reader)
-      throws ArgsErrorException, IOException {
-    host = checkRequiredArg(HOST_ARGS, HOST_NAME, commandLine);
-    port = checkRequiredArg(PORT_ARGS, PORT_NAME, commandLine);
-    username = checkRequiredArg(USERNAME_ARGS, USERNAME_NAME, commandLine);
-
-    password = commandLine.getOptionValue(PASSWORD_ARGS);
-    if (password == null) {
-      password = reader.readLine("please input your password:", '\0');
-    }
-  }
-
-  protected static boolean checkTimeFormat() {
-    for (String format : TIME_FORMAT) {
-      if (timeFormat.equals(format)) {
-        return true;
-      }
-    }
-    for (String format : STRING_TIME_FORMAT) {
-      if (timeFormat.equals(format)) {
-        return true;
-      }
-    }
-    System.out.printf(
-        "Input time format %s is not supported, "
-            + "please input like yyyy-MM-dd\\ HH:mm:ss.SSS or yyyy-MM-dd'T'HH:mm:ss.SSS%n",
-        timeFormat);
-    return false;
-  }
-
-  protected static Options createNewOptions() {
-    Options options = new Options();
-
-    Option opHost =
-        Option.builder(HOST_ARGS)
-            .longOpt(HOST_NAME)
-            .required()
-            .argName(HOST_NAME)
-            .hasArg()
-            .desc("Host Name (required)")
-            .build();
-    options.addOption(opHost);
-
-    Option opPort =
-        Option.builder(PORT_ARGS)
-            .longOpt(PORT_NAME)
-            .required()
-            .argName(PORT_NAME)
-            .hasArg()
-            .desc("Port (required)")
-            .build();
-    options.addOption(opPort);
-
-    Option opUsername =
-        Option.builder(USERNAME_ARGS)
-            .longOpt(USERNAME_NAME)
-            .required()
-            .argName(USERNAME_NAME)
-            .hasArg()
-            .desc("Username (required)")
-            .build();
-    options.addOption(opUsername);
-
-    Option opPassword =
-        Option.builder(PASSWORD_ARGS)
-            .longOpt(PASSWORD_NAME)
-            .optionalArg(true)
-            .argName(PASSWORD_NAME)
-            .hasArg()
-            .desc("Password (optional)")
-            .build();
-    options.addOption(opPassword);
-    return options;
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/tool/ExportCsv.java b/cli/src/main/java/org/apache/iotdb/tool/ExportCsv.java
deleted file mode 100644
index 5b1d9ca..0000000
--- a/cli/src/main/java/org/apache/iotdb/tool/ExportCsv.java
+++ /dev/null
@@ -1,372 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.iotdb.tool;
-
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.RpcUtils;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.session.Session;
-import org.apache.iotdb.session.SessionDataSet;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSDataType;
-import org.apache.iotdb.tsfile.read.common.Field;
-import org.apache.iotdb.tsfile.read.common.RowRecord;
-
-import jline.console.ConsoleReader;
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.CommandLineParser;
-import org.apache.commons.cli.DefaultParser;
-import org.apache.commons.cli.HelpFormatter;
-import org.apache.commons.cli.Option;
-import org.apache.commons.cli.Options;
-import org.apache.commons.cli.ParseException;
-
-import java.io.BufferedReader;
-import java.io.BufferedWriter;
-import java.io.File;
-import java.io.FileReader;
-import java.io.FileWriter;
-import java.io.IOException;
-import java.time.Instant;
-import java.time.ZonedDateTime;
-import java.time.format.DateTimeFormatter;
-import java.util.List;
-
-/**
- * Export CSV file.
- *
- * @version 1.0.0 20170719
- */
-public class ExportCsv extends AbstractCsvTool {
-
-  private static final String TARGET_DIR_ARGS = "td";
-  private static final String TARGET_DIR_NAME = "targetDirectory";
-
-  private static final String TARGET_FILE_ARGS = "f";
-  private static final String TARGET_FILE_NAME = "targetFile";
-
-  private static final String SQL_FILE_ARGS = "s";
-  private static final String SQL_FILE_NAME = "sqlfile";
-
-  private static final String TSFILEDB_CLI_PREFIX = "ExportCsv";
-
-  private static final String DUMP_FILE_NAME_DEFAULT = "dump";
-  private static String targetFile = DUMP_FILE_NAME_DEFAULT;
-
-  private static String targetDirectory;
-
-  private static final int EXPORT_PER_LINE_COUNT = 10000;
-
-  /** main function of export csv tool. */
-  public static void main(String[] args) throws IOException {
-    Options options = createOptions();
-    HelpFormatter hf = new HelpFormatter();
-    CommandLine commandLine;
-    CommandLineParser parser = new DefaultParser();
-    hf.setOptionComparator(null); // avoid reordering
-    hf.setWidth(MAX_HELP_CONSOLE_WIDTH);
-
-    if (args == null || args.length == 0) {
-      System.out.println("Too few params input, please check the following hint.");
-      hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-      return;
-    }
-    try {
-      commandLine = parser.parse(options, args);
-    } catch (ParseException e) {
-      System.out.println(e.getMessage());
-      hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-      return;
-    }
-    if (commandLine.hasOption(HELP_ARGS)) {
-      hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-      return;
-    }
-
-    ConsoleReader reader = new ConsoleReader();
-    reader.setExpandEvents(false);
-
-    try {
-      parseBasicParams(commandLine, reader);
-      parseSpecialParams(commandLine);
-      if (!checkTimeFormat()) {
-        return;
-      }
-
-      String sqlFile = commandLine.getOptionValue(SQL_FILE_ARGS);
-      String sql;
-      session = new Session(host, Integer.parseInt(port), username, password);
-      session.open(false);
-      setTimeZone();
-
-      if (sqlFile == null) {
-        sql = reader.readLine(TSFILEDB_CLI_PREFIX + "> please input query: ");
-        String[] values = sql.trim().split(";");
-        for (int i = 0; i < values.length; i++) {
-          dumpResult(values[i], i);
-        }
-      } else {
-        dumpFromSqlFile(sqlFile);
-      }
-    } catch (IOException e) {
-      System.out.println("Failed to operate on file, because " + e.getMessage());
-    } catch (ArgsErrorException e) {
-      System.out.println("Invalid args: " + e.getMessage());
-    } catch (IoTDBConnectionException | StatementExecutionException e) {
-      System.out.println("Connect failed because " + e.getMessage());
-    } finally {
-      reader.close();
-      if (session != null) {
-        try {
-          session.close();
-        } catch (IoTDBConnectionException e) {
-          System.out.println(
-              "Encounter an error when closing session, error is: " + e.getMessage());
-        }
-      }
-    }
-  }
-
-  private static void parseSpecialParams(CommandLine commandLine) throws ArgsErrorException {
-    targetDirectory = checkRequiredArg(TARGET_DIR_ARGS, TARGET_DIR_NAME, commandLine);
-    targetFile = commandLine.getOptionValue(TARGET_FILE_ARGS);
-    if (targetFile == null) {
-      targetFile = DUMP_FILE_NAME_DEFAULT;
-    }
-    timeFormat = commandLine.getOptionValue(TIME_FORMAT_ARGS);
-    if (timeFormat == null) {
-      timeFormat = "default";
-    }
-    timeZoneID = commandLine.getOptionValue(TIME_ZONE_ARGS);
-    if (!targetDirectory.endsWith(File.separator)) {
-      targetDirectory += File.separator;
-    }
-  }
-
-  /**
-   * commandline option create.
-   *
-   * @return object Options
-   */
-  private static Options createOptions() {
-    Options options = createNewOptions();
-
-    Option opTargetFile =
-        Option.builder(TARGET_DIR_ARGS)
-            .required()
-            .argName(TARGET_DIR_NAME)
-            .hasArg()
-            .desc("Target File Directory (required)")
-            .build();
-    options.addOption(opTargetFile);
-
-    Option targetFileName =
-        Option.builder(TARGET_FILE_ARGS)
-            .argName(TARGET_FILE_NAME)
-            .hasArg()
-            .desc("Export file name (optional)")
-            .build();
-    options.addOption(targetFileName);
-
-    Option opSqlFile =
-        Option.builder(SQL_FILE_ARGS)
-            .argName(SQL_FILE_NAME)
-            .hasArg()
-            .desc("SQL File Path (optional)")
-            .build();
-    options.addOption(opSqlFile);
-
-    Option opTimeFormat =
-        Option.builder(TIME_FORMAT_ARGS)
-            .argName(TIME_FORMAT_NAME)
-            .hasArg()
-            .desc(
-                "Output time Format in csv file. "
-                    + "You can choose 1) timestamp, number, long 2) ISO8601, default 3) "
-                    + "user-defined pattern like yyyy-MM-dd\\ HH:mm:ss, default ISO8601 (optional)")
-            .build();
-    options.addOption(opTimeFormat);
-
-    Option opTimeZone =
-        Option.builder(TIME_ZONE_ARGS)
-            .argName(TIME_ZONE_NAME)
-            .hasArg()
-            .desc("Time Zone eg. +08:00 or -01:00 (optional)")
-            .build();
-    options.addOption(opTimeZone);
-
-    Option opHelp =
-        Option.builder(HELP_ARGS)
-            .longOpt(HELP_ARGS)
-            .hasArg(false)
-            .desc("Display help information")
-            .build();
-    options.addOption(opHelp);
-
-    return options;
-  }
-
-  private static void dumpFromSqlFile(String filePath) throws IOException {
-    try (BufferedReader reader = new BufferedReader(new FileReader(filePath))) {
-      String sql;
-      int index = 0;
-      while ((sql = reader.readLine()) != null) {
-        dumpResult(sql, index);
-        index++;
-      }
-    }
-  }
-
-  /**
-   * Dump files from database to CSV file.
-   *
-   * @param sql export the result of executing the sql
-   * @param index use to create dump file name
-   */
-  private static void dumpResult(String sql, int index) {
-
-    final String path = targetDirectory + targetFile + index + ".csv";
-    File tf = new File(path);
-    try {
-      if (!tf.exists() && !tf.createNewFile()) {
-        System.out.println("Could not create target file for sql statement: " + sql);
-        return;
-      }
-    } catch (IOException e) {
-      System.out.println("Cannot create dump file " + path + " " + "because: " + e.getMessage());
-      return;
-    }
-    System.out.println("Start to export data from sql statement: " + sql);
-    try (BufferedWriter bw = new BufferedWriter(new FileWriter(tf))) {
-      SessionDataSet sessionDataSet = session.executeQueryStatement(sql);
-      long startTime = System.currentTimeMillis();
-      // write data in csv file
-      writeMetadata(bw, sessionDataSet.getColumnNames());
-
-      int line = writeResultSet(sessionDataSet, bw);
-      System.out.printf(
-          "Statement [%s] has dumped to file %s successfully! It costs "
-              + "%dms to export %d lines.%n",
-          sql, path, System.currentTimeMillis() - startTime, line);
-    } catch (IOException | StatementExecutionException | IoTDBConnectionException e) {
-      System.out.println("Cannot dump result because: " + e.getMessage());
-    }
-  }
-
-  private static void writeMetadata(BufferedWriter bw, List<String> columnNames)
-      throws IOException {
-    if (!columnNames.get(0).equals("Time")) {
-      bw.write("Time" + ",");
-    }
-    for (int i = 0; i < columnNames.size() - 1; i++) {
-      bw.write(columnNames.get(i) + ",");
-    }
-    bw.write(columnNames.get(columnNames.size() - 1) + "\n");
-  }
-
-  private static int writeResultSet(SessionDataSet rs, BufferedWriter bw)
-      throws IOException, StatementExecutionException, IoTDBConnectionException {
-    int line = 0;
-    long timestamp = System.currentTimeMillis();
-    while (rs.hasNext()) {
-      RowRecord rowRecord = rs.next();
-      List<Field> fields = rowRecord.getFields();
-      writeTime(rowRecord.getTimestamp(), bw);
-      writeValue(fields, bw);
-      line++;
-      if (line % EXPORT_PER_LINE_COUNT == 0) {
-        long tmp = System.currentTimeMillis();
-        System.out.printf("%d lines have been exported, it takes %dms%n", line, (tmp - timestamp));
-        timestamp = tmp;
-      }
-    }
-    return line;
-  }
-
-  private static void writeTime(Long time, BufferedWriter bw) throws IOException {
-    ZonedDateTime dateTime;
-    String timestampPrecision = "ms";
-    switch (timeFormat) {
-      case "default":
-        String str =
-            RpcUtils.parseLongToDateWithPrecision(
-                DateTimeFormatter.ISO_OFFSET_DATE_TIME, time, zoneId, timestampPrecision);
-        bw.write(str + ",");
-        break;
-      case "timestamp":
-      case "long":
-      case "number":
-        bw.write(time + ",");
-        break;
-      default:
-        dateTime = ZonedDateTime.ofInstant(Instant.ofEpochMilli(time), zoneId);
-        bw.write(dateTime.format(DateTimeFormatter.ofPattern(timeFormat)) + ",");
-        break;
-    }
-  }
-
-  @SuppressWarnings("squid:S3776") // Suppress high Cognitive Complexity warning
-  private static void writeValue(List<Field> fields, BufferedWriter bw) throws IOException {
-    for (int j = 0; j < fields.size() - 1; j++) {
-      String value = fields.get(j).getStringValue();
-      if ("null".equalsIgnoreCase(value)) {
-        bw.write(",");
-      } else {
-        if (fields.get(j).getDataType() == TSDataType.TEXT) {
-          int location = value.indexOf("\"");
-          if (location > -1) {
-            if (location == 0 || value.charAt(location - 1) != '\\') {
-              bw.write("\"" + value.replace("\"", "\\\"") + "\",");
-            } else {
-              bw.write("\"" + value + "\",");
-            }
-          } else if (value.contains(",")) {
-            bw.write("\"" + value + "\",");
-          } else {
-            bw.write(value + ",");
-          }
-        } else {
-          bw.write(value + ",");
-        }
-      }
-    }
-    String lastValue = fields.get(fields.size() - 1).getStringValue();
-    if ("null".equalsIgnoreCase(lastValue)) {
-      bw.write("\n");
-    } else {
-      if (fields.get(fields.size() - 1).getDataType() == TSDataType.TEXT) {
-        int location = lastValue.indexOf("\"");
-        if (location > -1) {
-          if (location == 0 || lastValue.charAt(location - 1) != '\\') {
-            bw.write("\"" + lastValue.replace("\"", "\\\"") + "\"\n");
-          } else {
-            bw.write("\"" + lastValue + "\"\n");
-          }
-        } else if (lastValue.contains(",")) {
-          bw.write("\"" + lastValue + "\"\n");
-        } else {
-          bw.write(lastValue + "\n");
-        }
-      } else {
-        bw.write(lastValue + "\n");
-      }
-    }
-  }
-}
diff --git a/cli/src/main/java/org/apache/iotdb/tool/ImportCsv.java b/cli/src/main/java/org/apache/iotdb/tool/ImportCsv.java
deleted file mode 100644
index b0d3075..0000000
--- a/cli/src/main/java/org/apache/iotdb/tool/ImportCsv.java
+++ /dev/null
@@ -1,458 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.tool;
-
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.session.Session;
-import org.apache.iotdb.tsfile.common.constant.TsFileConstant;
-
-import jline.console.ConsoleReader;
-import me.tongfei.progressbar.ProgressBar;
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.CommandLineParser;
-import org.apache.commons.cli.DefaultParser;
-import org.apache.commons.cli.HelpFormatter;
-import org.apache.commons.cli.Option;
-import org.apache.commons.cli.Options;
-import org.apache.commons.cli.ParseException;
-
-import java.io.BufferedReader;
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.io.InputStreamReader;
-import java.io.LineNumberReader;
-import java.nio.charset.StandardCharsets;
-import java.text.SimpleDateFormat;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Map.Entry;
-
-/** read a CSV formatted data File and insert all the data into IoTDB. */
-public class ImportCsv extends AbstractCsvTool {
-
-  private static final String FILE_ARGS = "f";
-  private static final String FILE_NAME = "file or folder";
-  private static final String FILE_SUFFIX = "csv";
-
-  private static final String TSFILEDB_CLI_PREFIX = "ImportCsv";
-  private static final String ILLEGAL_PATH_ARGUMENT = "Path parameter is null";
-
-  // put these variable in here, because sonar fails.  have to extract some code into a function.
-  // nextNode method.
-  private static int i;
-  private static int startIndex;
-
-  /**
-   * create the commandline options.
-   *
-   * @return object Options
-   */
-  private static Options createOptions() {
-    Options options = createNewOptions();
-
-    Option opFile =
-        Option.builder(FILE_ARGS)
-            .required()
-            .argName(FILE_NAME)
-            .hasArg()
-            .desc(
-                "If input a file path, load a csv file, "
-                    + "otherwise load all csv file under this directory (required)")
-            .build();
-    options.addOption(opFile);
-
-    Option opHelp =
-        Option.builder(HELP_ARGS)
-            .longOpt(HELP_ARGS)
-            .hasArg(false)
-            .desc("Display help information")
-            .build();
-    options.addOption(opHelp);
-
-    Option opTimeZone =
-        Option.builder(TIME_ZONE_ARGS)
-            .argName(TIME_ZONE_NAME)
-            .hasArg()
-            .desc("Time Zone eg. +08:00 or -01:00 (optional)")
-            .build();
-    options.addOption(opTimeZone);
-
-    return options;
-  }
-
-  /** Data from csv To tsfile. */
-  @SuppressWarnings("squid:S1135")
-  private static void loadDataFromCSV(File file) {
-    int fileLine;
-    try {
-      fileLine = getFileLineCount(file);
-    } catch (IOException e) {
-      System.out.println("Failed to import file: " + file.getName());
-      return;
-    }
-    System.out.println("Start to import data from: " + file.getName());
-    try (BufferedReader br =
-            new BufferedReader(
-                new InputStreamReader(new FileInputStream(file), StandardCharsets.UTF_8));
-        ProgressBar pb = new ProgressBar("Import from: " + file.getName(), fileLine)) {
-      pb.setExtraMessage("Importing...");
-      String header = br.readLine();
-      String[] cols = splitCsvLine(header);
-      if (cols.length <= 1) {
-        System.out.println("The CSV file " + file.getName() + " illegal, please check first line");
-        return;
-      }
-
-      List<String> devices = new ArrayList<>();
-      List<Long> times = new ArrayList<>();
-      List<List<String>> measurementsList = new ArrayList<>();
-      List<List<String>> valuesList = new ArrayList<>();
-      Map<String, List<Integer>> devicesToPositions = new HashMap<>();
-      Map<String, List<String>> devicesToMeasurements = new HashMap<>();
-
-      for (int i = 1; i < cols.length; i++) {
-        splitColToDeviceAndMeasurement(cols[i], devicesToPositions, devicesToMeasurements, i);
-      }
-
-      SimpleDateFormat timeFormatter = null;
-      boolean useFormatter = false;
-
-      int lineNumber = 0;
-      String line;
-      while ((line = br.readLine()) != null) {
-        cols = splitCsvLine(line);
-        lineNumber++;
-        if (lineNumber == 1) {
-          timeFormatter = formatterInit(cols[0]);
-          useFormatter = (timeFormatter != null);
-        }
-        for (Entry<String, List<Integer>> deviceToPositions : devicesToPositions.entrySet()) {
-          String device = deviceToPositions.getKey();
-          devices.add(device);
-
-          times.add(parseTime(cols[0], useFormatter, timeFormatter));
-
-          List<String> values = new ArrayList<>();
-          for (int position : deviceToPositions.getValue()) {
-            values.add(cols[position]);
-          }
-          valuesList.add(values);
-
-          measurementsList.add(devicesToMeasurements.get(device));
-        }
-        if (lineNumber % 10000 == 0) {
-          try {
-            session.insertRecords(devices, times, measurementsList, valuesList);
-          } catch (StatementExecutionException e) {
-            if (e.getMessage().contains("failed to insert measurements")) {
-              System.out.println("Meet error when insert csv because " + e.getMessage());
-              System.out.println("Continue inserting... ");
-            } else {
-              throw e;
-            }
-          }
-          pb.stepTo(lineNumber + 1L);
-          devices = new ArrayList<>();
-          times = new ArrayList<>();
-          measurementsList = new ArrayList<>();
-          valuesList = new ArrayList<>();
-        }
-      }
-      // TODO change it to insertTablet, now is slow
-      try {
-        session.insertRecords(devices, times, measurementsList, valuesList);
-      } catch (StatementExecutionException e) {
-        if (e.getMessage().contains("failed to insert measurements")) {
-          System.out.println("Meet error when insert csv because " + e.getMessage());
-          System.out.println("Continue inserting... ");
-        } else {
-          throw e;
-        }
-      }
-      System.out.println("Insert csv successfully!");
-      pb.stepTo(fileLine);
-    } catch (FileNotFoundException e) {
-      System.out.println("Cannot find " + file.getName() + " because: " + e.getMessage());
-    } catch (IOException e) {
-      System.out.println("CSV file read exception because: " + e.getMessage());
-    } catch (IoTDBConnectionException | StatementExecutionException e) {
-      System.out.println("Meet error when insert csv because " + e.getMessage());
-    }
-  }
-
-  public static void main(String[] args) throws IOException {
-    Options options = createOptions();
-    HelpFormatter hf = new HelpFormatter();
-    hf.setOptionComparator(null);
-    hf.setWidth(MAX_HELP_CONSOLE_WIDTH);
-    CommandLine commandLine;
-    CommandLineParser parser = new DefaultParser();
-
-    if (args == null || args.length == 0) {
-      System.out.println("Too few params input, please check the following hint.");
-      hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-      return;
-    }
-    try {
-      commandLine = parser.parse(options, args);
-    } catch (ParseException e) {
-      System.out.println("Parse error: " + e.getMessage());
-      hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-      return;
-    }
-    if (commandLine.hasOption(HELP_ARGS)) {
-      hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-      return;
-    }
-
-    ConsoleReader reader = new ConsoleReader();
-    reader.setExpandEvents(false);
-    try {
-      parseBasicParams(commandLine, reader);
-      String filename = commandLine.getOptionValue(FILE_ARGS);
-      if (filename == null) {
-        hf.printHelp(TSFILEDB_CLI_PREFIX, options, true);
-        return;
-      }
-      parseSpecialParams(commandLine);
-      importCsvFromFile(host, port, username, password, filename, timeZoneID);
-    } catch (ArgsErrorException e) {
-      System.out.println("Args error: " + e.getMessage());
-    } catch (Exception e) {
-      System.out.println("Encounter an error, because: " + e.getMessage());
-    } finally {
-      reader.close();
-    }
-  }
-
-  private static long parseTime(String str, boolean useFormatter, SimpleDateFormat timeFormatter) {
-    try {
-      if (useFormatter) {
-        return timeFormatter.parse(str).getTime();
-      } else {
-        return Long.parseLong(str);
-      }
-    } catch (Exception e) {
-      throw new IllegalArgumentException(
-          "Input time format "
-              + str
-              + "error. Input like yyyy-MM-dd HH:mm:ss, yyyy-MM-ddTHH:mm:ss or yyyy-MM-ddTHH:mm:ss.SSSZ");
-    }
-  }
-
-  private static SimpleDateFormat formatterInit(String time) {
-
-    try {
-      Long.parseLong(time);
-      return null;
-    } catch (Exception ignored) {
-      // do nothing
-    }
-
-    for (String timeFormat : STRING_TIME_FORMAT) {
-      SimpleDateFormat format = new SimpleDateFormat(timeFormat);
-      try {
-        format.parse(time).getTime();
-        return format;
-      } catch (java.text.ParseException ignored) {
-        // do nothing
-      }
-    }
-    return null;
-  }
-
-  private static void parseSpecialParams(CommandLine commandLine) {
-    timeZoneID = commandLine.getOptionValue(TIME_ZONE_ARGS);
-  }
-
-  public static void importCsvFromFile(
-      String ip, String port, String username, String password, String filename, String timeZone) {
-    try {
-      session = new Session(ip, Integer.parseInt(port), username, password);
-      session.open(false);
-      timeZoneID = timeZone;
-      setTimeZone();
-
-      File file = new File(filename);
-      if (file.isFile()) {
-        importFromSingleFile(file);
-      } else if (file.isDirectory()) {
-        importFromDirectory(file);
-      }
-    } catch (IoTDBConnectionException e) {
-      System.out.println("Encounter an error when connecting to server, because " + e.getMessage());
-    } catch (StatementExecutionException e) {
-      System.out.println(
-          "Encounter an error when executing the statement, because " + e.getMessage());
-    } finally {
-      if (session != null) {
-        try {
-          session.close();
-        } catch (IoTDBConnectionException e) {
-          System.out.println(
-              "Encounter an error when closing the connection, because " + e.getMessage());
-        }
-      }
-    }
-  }
-
-  private static void importFromSingleFile(File file) {
-    if (file.getName().endsWith(FILE_SUFFIX)) {
-      loadDataFromCSV(file);
-    } else {
-      System.out.println(
-          "File " + file.getName() + "  should ends with '.csv' if you want to import");
-    }
-  }
-
-  private static void importFromDirectory(File file) {
-    File[] files = file.listFiles();
-    if (files == null) {
-      return;
-    }
-
-    for (File subFile : files) {
-      if (subFile.isFile()) {
-        if (subFile.getName().endsWith(FILE_SUFFIX)) {
-          loadDataFromCSV(subFile);
-        } else {
-          System.out.println(
-              "File " + file.getName() + " should ends with '.csv' if you want to import");
-        }
-      }
-    }
-  }
-
-  private static int getFileLineCount(File file) throws IOException {
-    int line;
-    try (LineNumberReader count =
-        new LineNumberReader(
-            new InputStreamReader(new FileInputStream(file), StandardCharsets.UTF_8))) {
-      while (count.skip(Long.MAX_VALUE) > 0) {
-        // Loop just in case the file is > Long.MAX_VALUE or skip() decides to not read the entire
-        // file
-      }
-      // +1 because line index starts at 0
-      line = count.getLineNumber() + 1;
-    }
-    return line;
-  }
-
-  private static void splitColToDeviceAndMeasurement(
-      String col,
-      Map<String, List<Integer>> devicesToPositions,
-      Map<String, List<String>> devicesToMeasurements,
-      int position) {
-    if (col.length() > 0) {
-      if (col.charAt(col.length() - 1) == TsFileConstant.DOUBLE_QUOTE) {
-        int endIndex = col.lastIndexOf('"', col.length() - 2);
-        // if a double quotes with escape character
-        while (endIndex != -1 && col.charAt(endIndex - 1) == '\\') {
-          endIndex = col.lastIndexOf('"', endIndex - 2);
-        }
-        if (endIndex != -1 && (endIndex == 0 || col.charAt(endIndex - 1) == '.')) {
-          putDeviceAndMeasurement(
-              col.substring(0, endIndex - 1),
-              col.substring(endIndex),
-              devicesToPositions,
-              devicesToMeasurements,
-              position);
-        } else {
-          throw new IllegalArgumentException(ILLEGAL_PATH_ARGUMENT);
-        }
-      } else if (col.charAt(col.length() - 1) != TsFileConstant.DOUBLE_QUOTE
-          && col.charAt(col.length() - 1) != TsFileConstant.PATH_SEPARATOR_CHAR) {
-        int endIndex = col.lastIndexOf(TsFileConstant.PATH_SEPARATOR_CHAR);
-        if (endIndex < 0) {
-          putDeviceAndMeasurement("", col, devicesToPositions, devicesToMeasurements, position);
-        } else {
-          putDeviceAndMeasurement(
-              col.substring(0, endIndex),
-              col.substring(endIndex + 1),
-              devicesToPositions,
-              devicesToMeasurements,
-              position);
-        }
-      } else {
-        throw new IllegalArgumentException(ILLEGAL_PATH_ARGUMENT);
-      }
-    } else {
-      putDeviceAndMeasurement("", col, devicesToPositions, devicesToMeasurements, position);
-    }
-  }
-
-  private static void putDeviceAndMeasurement(
-      String device,
-      String measurement,
-      Map<String, List<Integer>> devicesToPositions,
-      Map<String, List<String>> devicesToMeasurements,
-      int position) {
-    if (devicesToMeasurements.get(device) == null && devicesToPositions.get(device) == null) {
-      List<String> measurements = new ArrayList<>();
-      measurements.add(measurement);
-      devicesToMeasurements.put(device, measurements);
-      List<Integer> positions = new ArrayList<>();
-      positions.add(position);
-      devicesToPositions.put(device, positions);
-    } else {
-      devicesToMeasurements.get(device).add(measurement);
-      devicesToPositions.get(device).add(position);
-    }
-  }
-
-  public static String[] splitCsvLine(String path) {
-    List<String> nodes = new ArrayList<>();
-    startIndex = 0;
-    for (i = 0; i < path.length(); i++) {
-      if (path.charAt(i) == ',') {
-        nodes.add(path.substring(startIndex, i));
-        startIndex = i + 1;
-      } else if (path.charAt(i) == '"') {
-        nextNode(path, nodes, '"');
-      } else if (path.charAt(i) == '\'') {
-        nextNode(path, nodes, '\'');
-      }
-    }
-    if (startIndex <= path.length() - 1) {
-      nodes.add(path.substring(startIndex));
-    }
-    return nodes.toArray(new String[0]);
-  }
-
-  public static void nextNode(String path, List<String> nodes, char enclose) {
-    int endIndex = path.indexOf(enclose, i + 1);
-    // if a double quotes with escape character
-    while (endIndex != -1 && path.charAt(endIndex - 1) == '\\') {
-      endIndex = path.indexOf(enclose, endIndex + 1);
-    }
-    if (endIndex != -1 && (endIndex == path.length() - 1 || path.charAt(endIndex + 1) == ',')) {
-      nodes.add(path.substring(startIndex + 1, endIndex));
-      i = endIndex + 1;
-      startIndex = endIndex + 2;
-    } else {
-      throw new IllegalArgumentException("Illegal csv line" + path);
-    }
-  }
-}
diff --git a/cli/src/test/java/org/apache/iotdb/cli/AbstractCliIT.java b/cli/src/test/java/org/apache/iotdb/cli/AbstractCliIT.java
deleted file mode 100644
index 719a801..0000000
--- a/cli/src/test/java/org/apache/iotdb/cli/AbstractCliIT.java
+++ /dev/null
@@ -1,234 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli;
-
-import org.apache.iotdb.cli.AbstractCli.OperationResult;
-import org.apache.iotdb.exception.ArgsErrorException;
-import org.apache.iotdb.jdbc.IoTDBConnection;
-import org.apache.iotdb.jdbc.IoTDBDatabaseMetadata;
-
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.CommandLineParser;
-import org.apache.commons.cli.DefaultParser;
-import org.apache.commons.cli.Options;
-import org.apache.commons.cli.ParseException;
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-import org.mockito.Mock;
-import org.mockito.MockitoAnnotations;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.fail;
-import static org.mockito.Mockito.when;
-
-public class AbstractCliIT {
-  private static Logger logger = LoggerFactory.getLogger(AbstractCliIT.class);
-  @Mock private IoTDBConnection connection;
-
-  @Mock private IoTDBDatabaseMetadata databaseMetadata;
-
-  @Before
-  public void setUp() throws Exception {
-    MockitoAnnotations.initMocks(this);
-    when(connection.getMetaData()).thenReturn(databaseMetadata);
-    when(connection.getTimeZone()).thenReturn("Asia/Shanghai");
-  }
-
-  @After
-  public void tearDown() {}
-
-  @Test
-  public void testInit() {
-    AbstractCli.init();
-    String[] keywords = {
-      AbstractCli.HOST_ARGS,
-      AbstractCli.HELP_ARGS,
-      AbstractCli.PORT_ARGS,
-      AbstractCli.PASSWORD_ARGS,
-      AbstractCli.USERNAME_ARGS,
-      AbstractCli.ISO8601_ARGS,
-      AbstractCli.MAX_PRINT_ROW_COUNT_ARGS,
-    };
-    for (String keyword : keywords) {
-      if (!AbstractCli.keywordSet.contains("-" + keyword)) {
-        logger.error(keyword);
-        fail();
-      }
-    }
-  }
-
-  @Test
-  public void testCheckRequiredArg() throws ParseException, ArgsErrorException {
-    Options options = AbstractCli.createOptions();
-    CommandLineParser parser = new DefaultParser();
-    String[] args = new String[] {"-u", "user1"};
-    CommandLine commandLine = parser.parse(options, args);
-    String str =
-        AbstractCli.checkRequiredArg(
-            AbstractCli.USERNAME_ARGS, AbstractCli.USERNAME_NAME, commandLine, true, "root");
-    assertEquals("user1", str);
-
-    args =
-        new String[] {
-          "-u", "root",
-        };
-    commandLine = parser.parse(options, args);
-    str =
-        AbstractCli.checkRequiredArg(
-            AbstractCli.HOST_ARGS, AbstractCli.HOST_NAME, commandLine, false, "127.0.0.1");
-    assertEquals("127.0.0.1", str);
-    try {
-      str =
-          AbstractCli.checkRequiredArg(
-              AbstractCli.HOST_ARGS, AbstractCli.HOST_NAME, commandLine, true, "127.0.0.1");
-    } catch (ArgsErrorException e) {
-      assertEquals("IoTDB: Required values for option 'host' not provided", e.getMessage());
-    }
-    try {
-      str =
-          AbstractCli.checkRequiredArg(
-              AbstractCli.HOST_ARGS, AbstractCli.HOST_NAME, commandLine, false, null);
-    } catch (ArgsErrorException e) {
-      assertEquals("IoTDB: Required values for option 'host' is null.", e.getMessage());
-    }
-  }
-
-  @Test
-  public void testRemovePasswordArgs() {
-    AbstractCli.init();
-    String[] input = new String[] {"-h", "127.0.0.1", "-p", "6667", "-u", "root", "-pw", "root"};
-    String[] res = new String[] {"-h", "127.0.0.1", "-p", "6667", "-u", "root", "-pw", "root"};
-    isTwoStringArrayEqual(res, AbstractCli.removePasswordArgs(input));
-
-    input = new String[] {"-h", "127.0.0.1", "-p", "6667", "-pw", "root", "-u", "root"};
-    res = new String[] {"-h", "127.0.0.1", "-p", "6667", "-pw", "root", "-u", "root"};
-    isTwoStringArrayEqual(res, AbstractCli.removePasswordArgs(input));
-
-    input = new String[] {"-h", "127.0.0.1", "-p", "6667", "root", "-u", "root", "-pw"};
-    res = new String[] {"-h", "127.0.0.1", "-p", "6667", "root", "-u", "root"};
-    isTwoStringArrayEqual(res, AbstractCli.removePasswordArgs(input));
-
-    input = new String[] {"-h", "127.0.0.1", "-p", "6667", "-pw", "-u", "root"};
-    res = new String[] {"-h", "127.0.0.1", "-p", "6667", "-u", "root"};
-    isTwoStringArrayEqual(res, AbstractCli.removePasswordArgs(input));
-
-    input = new String[] {"-pw", "-h", "127.0.0.1", "-p", "6667", "root", "-u", "root"};
-    res = new String[] {"-h", "127.0.0.1", "-p", "6667", "root", "-u", "root"};
-    isTwoStringArrayEqual(res, AbstractCli.removePasswordArgs(input));
-
-    input = new String[] {};
-    res = new String[] {};
-    isTwoStringArrayEqual(res, AbstractCli.removePasswordArgs(input));
-  }
-
-  private void isTwoStringArrayEqual(String[] expected, String[] actual) {
-    for (int i = 0; i < expected.length; i++) {
-      assertEquals(expected[i], actual[i]);
-    }
-  }
-
-  @Test
-  public void testHandleInputInputCmd() {
-    assertEquals(
-        OperationResult.STOP_OPER,
-        AbstractCli.handleInputCmd(AbstractCli.EXIT_COMMAND, connection));
-    assertEquals(
-        OperationResult.STOP_OPER,
-        AbstractCli.handleInputCmd(AbstractCli.QUIT_COMMAND, connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=", AbstractCli.SET_TIMESTAMP_DISPLAY), connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=xxx", AbstractCli.SET_TIMESTAMP_DISPLAY), connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=default", AbstractCli.SET_TIMESTAMP_DISPLAY), connection));
-
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=", AbstractCli.SET_MAX_DISPLAY_NUM), connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=xxx", AbstractCli.SET_MAX_DISPLAY_NUM), connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=1", AbstractCli.SET_MAX_DISPLAY_NUM), connection));
-    testSetMaxDisplayNumber();
-
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(AbstractCli.SHOW_TIMEZONE, connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(AbstractCli.SHOW_TIMESTAMP_DISPLAY, connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(AbstractCli.SHOW_FETCH_SIZE, connection));
-
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(String.format("%s=", AbstractCli.SET_TIME_ZONE), connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=+08:00", AbstractCli.SET_TIME_ZONE), connection));
-
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(String.format("%s=", AbstractCli.SET_FETCH_SIZE), connection));
-    assertEquals(
-        OperationResult.CONTINUE_OPER,
-        AbstractCli.handleInputCmd(
-            String.format("%s=111", AbstractCli.SET_FETCH_SIZE), connection));
-  }
-
-  private void testSetMaxDisplayNumber() {
-    try {
-      AbstractCli.setMaxDisplayNumber("10");
-    } catch (NumberFormatException e) {
-      fail();
-    }
-
-    try {
-      AbstractCli.setMaxDisplayNumber("111111111111111");
-      fail();
-    } catch (NumberFormatException ignored) {
-    }
-
-    try {
-      AbstractCli.setMaxDisplayNumber("-10");
-    } catch (NumberFormatException ignored) {
-    }
-
-    try {
-      AbstractCli.setMaxDisplayNumber("0");
-    } catch (NumberFormatException ignored) {
-    }
-  }
-}
diff --git a/cli/src/test/java/org/apache/iotdb/cli/AbstractScript.java b/cli/src/test/java/org/apache/iotdb/cli/AbstractScript.java
deleted file mode 100644
index 0be9b55..0000000
--- a/cli/src/test/java/org/apache/iotdb/cli/AbstractScript.java
+++ /dev/null
@@ -1,87 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli;
-
-import java.io.*;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Properties;
-
-import static org.junit.Assert.assertEquals;
-
-public abstract class AbstractScript {
-
-  protected void testOutput(ProcessBuilder builder, String[] output) throws IOException {
-    builder.redirectErrorStream(true);
-    Process p = builder.start();
-    BufferedReader r = new BufferedReader(new InputStreamReader(p.getInputStream()));
-    String line;
-    List<String> outputList = new ArrayList<>();
-    while (true) {
-      line = r.readLine();
-      if (line == null) {
-        break;
-      } else {
-        // remove thing after "connection refused", only for test
-        if (line.contains("Connection refused")) {
-          line =
-              line.substring(0, line.indexOf("Connection refused") + "Connection refused".length());
-        }
-        outputList.add(line);
-      }
-    }
-    r.close();
-    p.destroy();
-
-    System.out.println("Process output:");
-    for (String s : outputList) {
-      System.out.println(s);
-    }
-
-    for (int i = 0; i < output.length; i++) {
-      assertEquals(output[output.length - 1 - i], outputList.get(outputList.size() - 1 - i));
-    }
-  }
-
-  protected String getCliPath() {
-    // This is usually always set by the JVM
-
-    File userDir = new File(System.getProperty("user.dir"));
-    if (!userDir.exists()) {
-      throw new RuntimeException("user.dir " + userDir.getAbsolutePath() + " doesn't exist.");
-    }
-    File target = new File(userDir, "target/maven-archiver/pom.properties");
-    Properties properties = new Properties();
-    try {
-      properties.load(new FileReader(target));
-    } catch (IOException e) {
-      return "target/iotdb-cli-";
-    }
-    return new File(
-            userDir,
-            String.format(
-                "target/%s-%s",
-                properties.getProperty("artifactId"), properties.getProperty("version")))
-        .getAbsolutePath();
-  }
-
-  protected abstract void testOnWindows() throws IOException;
-
-  protected abstract void testOnUnix() throws IOException;
-}
diff --git a/cli/src/test/java/org/apache/iotdb/cli/StartClientScriptIT.java b/cli/src/test/java/org/apache/iotdb/cli/StartClientScriptIT.java
deleted file mode 100644
index 829cd9a..0000000
--- a/cli/src/test/java/org/apache/iotdb/cli/StartClientScriptIT.java
+++ /dev/null
@@ -1,112 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.cli;
-
-import org.apache.iotdb.db.utils.EnvironmentUtils;
-
-import org.junit.*;
-
-import java.io.File;
-import java.io.IOException;
-
-public class StartClientScriptIT extends AbstractScript {
-
-  @Before
-  public void setUp() {
-    EnvironmentUtils.closeStatMonitor();
-    EnvironmentUtils.envSetUp();
-  }
-
-  @After
-  public void tearDown() throws Exception {
-    EnvironmentUtils.cleanEnv();
-  }
-
-  @Test
-  public void test() throws IOException {
-    String os = System.getProperty("os.name").toLowerCase();
-    if (os.startsWith("windows")) {
-      testOnWindows();
-    } else {
-      testOnUnix();
-    }
-  }
-
-  @Override
-  protected void testOnWindows() throws IOException {
-    String dir = getCliPath();
-    final String[] output = {
-      "IoTDB> Connection Error, please check whether the network is available or the server has started. Host is 127.0.0.1, port is 6668."
-    };
-    ProcessBuilder builder =
-        new ProcessBuilder(
-            "cmd.exe",
-            "/c",
-            dir + File.separator + "sbin" + File.separator + "start-cli.bat",
-            "-h",
-            "127.0.0.1",
-            "-p",
-            "6668",
-            "-u",
-            "root",
-            "-pw",
-            "root");
-    testOutput(builder, output);
-
-    final String[] output2 = {"Msg: The statement is executed successfully."};
-    ProcessBuilder builder2 =
-        new ProcessBuilder(
-            "cmd.exe",
-            "/c",
-            dir + File.separator + "sbin" + File.separator + "start-cli.bat",
-            "-e",
-            "\"flush\"");
-    testOutput(builder2, output2);
-  }
-
-  @Override
-  protected void testOnUnix() throws IOException {
-    String dir = getCliPath();
-    final String[] output = {
-      "IoTDB> Connection Error, please check whether the network is available or the server has started. Host is 127.0.0.1, port is 6668."
-    };
-    ProcessBuilder builder =
-        new ProcessBuilder(
-            "sh",
-            dir + File.separator + "sbin" + File.separator + "start-cli.sh",
-            "-h",
-            "127.0.0.1",
-            "-p",
-            "6668",
-            "-u",
-            "root",
-            "-pw",
-            "root");
-    testOutput(builder, output);
-
-    final String[] output2 = {"Msg: The statement is executed successfully."};
-    ProcessBuilder builder2 =
-        new ProcessBuilder(
-            "sh",
-            dir + File.separator + "sbin" + File.separator + "start-cli.sh",
-            "-e",
-            "\"flush\"");
-    testOutput(builder2, output2);
-  }
-}
diff --git a/cli/src/test/java/org/apache/iotdb/tool/CsvLineSplitTest.java b/cli/src/test/java/org/apache/iotdb/tool/CsvLineSplitTest.java
deleted file mode 100644
index fd1c9ba..0000000
--- a/cli/src/test/java/org/apache/iotdb/tool/CsvLineSplitTest.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.tool;
-
-import org.junit.Assert;
-import org.junit.Test;
-
-public class CsvLineSplitTest {
-
-  @Test
-  public void testSplit() {
-    Assert.assertArrayEquals(
-        new String[] {"", "a", "b", "c", "\\\""}, ImportCsv.splitCsvLine(",a,b,c,\"\\\"\""));
-    Assert.assertArrayEquals(
-        new String[] {"", "a", "b", "\\'"}, ImportCsv.splitCsvLine(",a,b,\"\\'\""));
-  }
-}
diff --git a/cli/src/test/java/org/apache/iotdb/tool/ExportCsvTestIT.java b/cli/src/test/java/org/apache/iotdb/tool/ExportCsvTestIT.java
deleted file mode 100644
index 23bc812..0000000
--- a/cli/src/test/java/org/apache/iotdb/tool/ExportCsvTestIT.java
+++ /dev/null
@@ -1,102 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.tool;
-
-import org.apache.iotdb.cli.AbstractScript;
-
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-
-import java.io.File;
-import java.io.IOException;
-
-public class ExportCsvTestIT extends AbstractScript {
-
-  @Before
-  public void setUp() {}
-
-  @After
-  public void tearDown() {}
-
-  @Test
-  public void test() throws IOException {
-    String os = System.getProperty("os.name").toLowerCase();
-    if (os.startsWith("windows")) {
-      testOnWindows();
-    } else {
-      testOnUnix();
-    }
-  }
-
-  @Override
-  protected void testOnWindows() throws IOException {
-    final String[] output = {
-      "````````````````````````````````````````````````",
-      "Starting IoTDB Client Export Script",
-      "````````````````````````````````````````````````",
-      "Connect failed because org.apache.thrift.transport.TTransportException: "
-          + "java.net.ConnectException: Connection refused"
-    };
-    String dir = getCliPath();
-    ProcessBuilder builder =
-        new ProcessBuilder(
-            "cmd.exe",
-            "/c",
-            dir + File.separator + "tools" + File.separator + "export-csv.bat",
-            "-h",
-            "127.0.0.1",
-            "-p",
-            "6668",
-            "-u",
-            "root",
-            "-pw",
-            "root",
-            "-td",
-            "./");
-    testOutput(builder, output);
-  }
-
-  @Override
-  protected void testOnUnix() throws IOException {
-    final String[] output = {
-      "------------------------------------------",
-      "Starting IoTDB Client Export Script",
-      "------------------------------------------",
-      "Connect failed because org.apache.thrift.transport.TTransportException: "
-          + "java.net.ConnectException: Connection refused"
-    };
-    String dir = getCliPath();
-    ProcessBuilder builder =
-        new ProcessBuilder(
-            "sh",
-            dir + File.separator + "tools" + File.separator + "export-csv.sh",
-            "-h",
-            "127.0.0.1",
-            "-p",
-            "6668",
-            "-u",
-            "root",
-            "-pw",
-            "root",
-            "-td",
-            "./");
-    testOutput(builder, output);
-  }
-}
diff --git a/cli/src/test/java/org/apache/iotdb/tool/ImportCsvTestIT.java b/cli/src/test/java/org/apache/iotdb/tool/ImportCsvTestIT.java
deleted file mode 100644
index 6516b0e..0000000
--- a/cli/src/test/java/org/apache/iotdb/tool/ImportCsvTestIT.java
+++ /dev/null
@@ -1,102 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.iotdb.tool;
-
-import org.apache.iotdb.cli.AbstractScript;
-
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-
-import java.io.File;
-import java.io.IOException;
-
-public class ImportCsvTestIT extends AbstractScript {
-
-  @Before
-  public void setUp() {}
-
-  @After
-  public void tearDown() {}
-
-  @Test
-  public void test() throws IOException {
-    String os = System.getProperty("os.name").toLowerCase();
-    if (os.startsWith("windows")) {
-      testOnWindows();
-    } else {
-      testOnUnix();
-    }
-  }
-
-  @Override
-  protected void testOnWindows() throws IOException {
-    final String[] output = {
-      "````````````````````````````````````````````````",
-      "Starting IoTDB Client Import Script",
-      "````````````````````````````````````````````````",
-      "Encounter an error when connecting to server, because org.apache.thrift.transport.TTransportException: "
-          + "java.net.ConnectException: Connection refused"
-    };
-    String dir = getCliPath();
-    ProcessBuilder builder =
-        new ProcessBuilder(
-            "cmd.exe",
-            "/c",
-            dir + File.separator + "tools" + File.separator + "import-csv.bat",
-            "-h",
-            "127.0.0.1",
-            "-p",
-            "6668",
-            "-u",
-            "root",
-            "-pw",
-            "root",
-            "-f",
-            "./");
-    testOutput(builder, output);
-  }
-
-  @Override
-  protected void testOnUnix() throws IOException {
-    final String[] output = {
-      "------------------------------------------",
-      "Starting IoTDB Client Import Script",
-      "------------------------------------------",
-      "Encounter an error when connecting to server, because org.apache.thrift.transport.TTransportException: "
-          + "java.net.ConnectException: Connection refused"
-    };
-    String dir = getCliPath();
-    ProcessBuilder builder =
-        new ProcessBuilder(
-            "sh",
-            dir + File.separator + "tools" + File.separator + "import-csv.sh",
-            "-h",
-            "127.0.0.1",
-            "-p",
-            "6668",
-            "-u",
-            "root",
-            "-pw",
-            "root",
-            "-f",
-            "./");
-    testOutput(builder, output);
-  }
-}
diff --git a/cli/src/test/resources/logback.xml b/cli/src/test/resources/logback.xml
deleted file mode 100644
index df71a20..0000000
--- a/cli/src/test/resources/logback.xml
+++ /dev/null
@@ -1,122 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<configuration>
-    <property name="LOG_PATH" value="target/logs"/>
-    <appender class="ch.qos.logback.core.rolling.RollingFileAppender" name="FILEERROR">
-        <file>${LOG_PATH}/log_error.log</file>
-        <rollingPolicy class="ch.qos.logback.core.rolling.FixedWindowRollingPolicy">
-            <fileNamePattern>${LOG_PATH}/log-error.%i.log</fileNamePattern>
-            <minIndex>1</minIndex>
-            <maxIndex>10</maxIndex>
-        </rollingPolicy>
-        <triggeringPolicy class="ch.qos.logback.core.rolling.SizeBasedTriggeringPolicy">
-            <maxFileSize>10MB</maxFileSize>
-        </triggeringPolicy>
-        <append>true</append>
-        <encoder class="ch.qos.logback.classic.encoder.PatternLayoutEncoder">
-            <pattern>%-5p [%d] %C:%L - %m %n</pattern>
-            <charset>utf-8</charset>
-        </encoder>
-        <filter class="ch.qos.logback.classic.filter.LevelFilter">
-            <level>error</level>
-            <onMatch>ACCEPT</onMatch>
-            <onMismatch>DENY</onMismatch>
-        </filter>
-    </appender>
-    <appender class="ch.qos.logback.core.rolling.RollingFileAppender" name="FILEWARN">
-        <file>${LOG_PATH}/log_warn.log</file>
-        <rollingPolicy class="ch.qos.logback.core.rolling.FixedWindowRollingPolicy">
-            <fileNamePattern>${LOG_PATH}/log-warn.%i.log</fileNamePattern>
-            <minIndex>1</minIndex>
-            <maxIndex>10</maxIndex>
-        </rollingPolicy>
-        <triggeringPolicy class="ch.qos.logback.core.rolling.SizeBasedTriggeringPolicy">
-            <maxFileSize>10MB</maxFileSize>
-        </triggeringPolicy>
-        <append>true</append>
-        <encoder class="ch.qos.logback.classic.encoder.PatternLayoutEncoder">
-            <pattern>%-5p [%d] %C:%L - %m %n</pattern>
-            <charset>utf-8</charset>
-        </encoder>
-        <filter class="ch.qos.logback.classic.filter.LevelFilter">
-            <level>WARN</level>
-            <onMatch>ACCEPT</onMatch>
-            <onMismatch>DENY</onMismatch>
-        </filter>
-    </appender>
-    <appender class="ch.qos.logback.core.rolling.RollingFileAppender" name="FILEINFO">
-        <file>${LOG_PATH}/log_info.log</file>
-        <rollingPolicy class="ch.qos.logback.core.rolling.FixedWindowRollingPolicy">
-            <fileNamePattern>${LOG_PATH}/log-info.%i.log</fileNamePattern>
-            <minIndex>1</minIndex>
-            <maxIndex>10</maxIndex>
-        </rollingPolicy>
-        <triggeringPolicy class="ch.qos.logback.core.rolling.SizeBasedTriggeringPolicy">
-            <maxFileSize>50MB</maxFileSize>
-        </triggeringPolicy>
-        <append>true</append>
-        <encoder class="ch.qos.logback.classic.encoder.PatternLayoutEncoder">
-            <pattern>%-5p [%d] %C:%L - %m %n</pattern>
-            <charset>utf-8</charset>
-        </encoder>
-        <filter class="ch.qos.logback.classic.filter.LevelFilter">
-            <level>INFO</level>
-            <onMatch>ACCEPT</onMatch>
-            <onMismatch>DENY</onMismatch>
-        </filter>
-    </appender>
-    <appender class="ch.qos.logback.core.rolling.RollingFileAppender" name="FILEDEBUG">
-        <file>${LOG_PATH}/log_debug.log</file>
-        <rollingPolicy class="ch.qos.logback.core.rolling.FixedWindowRollingPolicy">
-            <fileNamePattern>${LOG_PATH}/log-debug.%i.log</fileNamePattern>
-            <minIndex>1</minIndex>
-            <maxIndex>10</maxIndex>
-        </rollingPolicy>
-        <triggeringPolicy class="ch.qos.logback.core.rolling.SizeBasedTriggeringPolicy">
-            <maxFileSize>50MB</maxFileSize>
-        </triggeringPolicy>
-        <append>true</append>
-        <encoder class="ch.qos.logback.classic.encoder.PatternLayoutEncoder">
-            <pattern>%-5p [%d] %C:%L - %m %n</pattern>
-            <charset>utf-8</charset>
-        </encoder>
-        <filter class="ch.qos.logback.classic.filter.LevelFilter">
-            <level>DEBUG</level>
-            <onMatch>ACCEPT</onMatch>
-            <onMismatch>DENY</onMismatch>
-        </filter>
-    </appender>
-    <appender class="ch.qos.logback.core.ConsoleAppender" name="stdout">
-        <Target>System.out</Target>
-        <encoder>
-            <pattern>%-5p [%d] [%thread] %C:%L - %m %n</pattern>
-            <charset>utf-8</charset>
-        </encoder>
-        <filter class="ch.qos.logback.classic.filter.ThresholdFilter">
-            <level>DEBUG</level>
-        </filter>
-    </appender>
-    <!--<logger name="org.apache.iotdb.tsfile.write.chunk.ChunkWriterImpl level="debug" />-->
-    <root level="ERROR">
-        <appender-ref ref="FILEERROR"/>
-    </root>
-</configuration>
diff --git a/client-cpp/README.md b/client-cpp/README.md
deleted file mode 100644
index 2800fd4..0000000
--- a/client-cpp/README.md
+++ /dev/null
@@ -1,63 +0,0 @@
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-# Building C++ Client
-
-To compile cpp client, add "-P compile-cpp" option to maven build command.
-
-The compiling requires the module "compile-tools" to be built first.
-For more information, please refer to "compile-tools/README.md".
-
-
-## Compile and Test:
-
-`mvn integration-test -P compile-cpp -pl client-cpp,server -am -Diotdb.test.skip=true -Dtsfile.test.skip=true -Djdbc.test.skip=true`
-
-To compile on Windows, please install Boost first and add following Maven settings:
-```
--Dboost.include.dir=${your boost header folder} -Dboost.library.dir=${your boost lib (stage) folder}` 
-```
-
-e.g.,
-```
-mvn integration-test -P compile-cpp -pl client-cpp,server,example/client-cpp-example -am 
--D"iotdb.test.skip"=true -D"tsfile.test.skip"=true -D"jdbc.test.skip"=true 
--D"boost.include.dir"="D:\boost_1_75_0" -D"boost.library.dir"="D:\boost_1_75_0\stage\lib"
-```
-
-## 
-
-If the compilation finishes successfully, the packaged zip file will be placed under
-"client-cpp/target/client-cpp-${project.version}-cpp-${os}.zip". 
-
-On Mac machines, the hierarchy of the package should look like this:
-```
-.
-+-- client
-|   +-- include
-|       +-- Session.h
-|       +-- TSIService.h
-|       +-- rpc_types.h
-|       +-- rpc_constants.h
-|       +-- thrift
-|           +-- thrift_headers...
-|   +-- lib
-|       +-- libiotdb_session.dylib
-```
diff --git a/client-cpp/pom.xml b/client-cpp/pom.xml
deleted file mode 100644
index 4d205f4..0000000
--- a/client-cpp/pom.xml
+++ /dev/null
@@ -1,388 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-        http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <parent>
-        <artifactId>iotdb-parent</artifactId>
-        <groupId>org.apache.iotdb</groupId>
-        <version>0.12.1-SNAPSHOT</version>
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-    <artifactId>client-cpp</artifactId>
-    <name>Client for cpp</name>
-    <description>C++ client</description>
-    <packaging>pom</packaging>
-    <properties>
-        <boost.version>1.72.0</boost.version>
-        <boost.version.underline-short>1_72</boost.version.underline-short>
-        <boost.version.underline>${boost.version.underline-short}_0</boost.version.underline>
-        <cmake-version>3.17.3</cmake-version>
-        <!-- Default value of cmake root -->
-        <cmake.root.dir>${project.build.directory}/dependency/cmake/</cmake.root.dir>
-        <cmake.build.type>Release</cmake.build.type>
-        <catch2.url>https://github.com/catchorg/Catch2/releases/download/v2.13.0/catch.hpp</catch2.url>
-    </properties>
-    <modules>
-        <module>../example/client-cpp-example</module>
-    </modules>
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.iotdb</groupId>
-            <artifactId>client-cpp-tools-thrift</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-    </dependencies>
-    <profiles>
-        <profile>
-            <id>os-unix</id>
-            <activation>
-                <os>
-                    <family>unix</family>
-                </os>
-            </activation>
-            <properties>
-                <os.suffix>linux</os.suffix>
-                <!-- use Makefile as default cmake generator, users may specify other generators -->
-                <cmake.generator>Unix Makefiles</cmake.generator>
-                <cmake.root.dir>${project.parent.basedir}/compile-tools/thrift/target/cmake-${cmake-version}-Linux-x86_64/</cmake.root.dir>
-                <thrift.exec.absolute.path>${project.parent.basedir}/compile-tools/thrift/target/build/compiler/cpp/bin/thrift</thrift.exec.absolute.path>
-                <iotdb.server.script>start-server.sh</iotdb.server.script>
-            </properties>
-        </profile>
-        <profile>
-            <id>os-mac</id>
-            <activation>
-                <os>
-                    <family>mac</family>
-                </os>
-            </activation>
-            <properties>
-                <os.suffix>mac</os.suffix>
-                <!-- use Makefile as default cmake generator, users may specify other generators -->
-                <cmake.generator>Unix Makefiles</cmake.generator>
-                <cmake.root.dir>${project.parent.basedir}/compile-tools/thrift/target/cmake-${cmake-version}-Darwin-x86_64/CMake.app/Contents</cmake.root.dir>
-                <thrift.exec.absolute.path>${project.parent.basedir}/compile-tools/thrift/target/build/compiler/cpp/bin/thrift</thrift.exec.absolute.path>
-                <iotdb.server.script>start-server.sh</iotdb.server.script>
-            </properties>
-        </profile>
-        <profile>
-            <id>os-windows</id>
... 389789 lines suppressed ...

[iotdb] 01/02: spotless

Posted by yu...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

yuyuankang pushed a commit to branch research/separation
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit ba3dff98eccd52afe58665e5a93c019f4bf12d36
Author: Ring-k <yu...@hotmail.com>
AuthorDate: Wed Mar 16 00:29:58 2022 +0800

    spotless
---
 .../apache/iotdb/db/separation/statistics/SeparationTuningClient.java  | 3 +--
 1 file changed, 1 insertion(+), 2 deletions(-)

diff --git a/server/src/main/java/org/apache/iotdb/db/separation/statistics/SeparationTuningClient.java b/server/src/main/java/org/apache/iotdb/db/separation/statistics/SeparationTuningClient.java
index f886a28..1afb1bf 100644
--- a/server/src/main/java/org/apache/iotdb/db/separation/statistics/SeparationTuningClient.java
+++ b/server/src/main/java/org/apache/iotdb/db/separation/statistics/SeparationTuningClient.java
@@ -19,8 +19,7 @@ public class SeparationTuningClient implements Runnable {
   private double rs = -1;
   private double rc = -1;
   private int seqSize = -1;
-  private int totalSize =
-      IoTDBDescriptor.getInstance().getConfig().getTotalCapacity();
+  private int totalSize = IoTDBDescriptor.getInstance().getConfig().getTotalCapacity();
 
   private void tune(double estimatedRc, double estimatedRs, int recSeqSize) {
     System.out.println("print total size:" + totalSize);