You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by hx...@apache.org on 2021/02/15 05:56:27 UTC

[iotdb] branch change_rpc_port updated (a7345e3 -> 1201834)

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

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


    from a7345e3  merge with master
     add 0e2ebd9  Improve flush pipeline , remove synchronized qualifier in PublicBAOS(#2596)
     add ceb9756  Add a badge of code quality & Upgrade JDK of sonar and coverall from 8 to 11(#2610)
     add 1110eb2  bug fix - fetch size calculation error for group by month when the time window is less than 1 month (#2571)
     add b793ada  add slides in 2020 (#2615)
     add 8a56871  [Github Issue 2624, 2625]Avoid OOM if user don't close Statement and Session manually (#2629)
     add 517f27f  Avoid using synchronized method in IO Task of flush pipeline (#2628)
     add d01cd9e  fixes document navigation name. (#2627)
     add 967f96b  fix possible NPE during end query process (#2634)
     add 31774ed  remove sonar token; add manual trigger of action.
     add 90a8a49  add github action environment for sonar (#2643)
     add c5d48cf  Add more detailed log for better tracing (#2636)
     add 08eaac9  [C++ Client]Add more detailed walkthrough of Cpp client build to README (#2620)
     add d5a9941  [IOTDB-1091] SDT improvement store last point (#2576)
     add 064cd96  IOTDB-1140 optimize regular data encoding (#2621)
     add 3efdcac  [IOTDB-1091] add linear fill test case for sdt encoding (#2500)
     add cc5ff6f  [IOTDB-1147] Fix the concurrent bug in FlushManager debug logger cause NoSuchElementException e… (#2623)
     add f3262c6  [ISSUE-2585] show devices with storage group (#2475)
     add aa97980  fix last query non cached path bug (#2651)
     add 425b35d  [IOTDB-1149]finish continue print for -e param when set maxPRC<=0 (#2649)
     add ddd2eb8  Remove duplicate method of getDefaultEncoding (#2655)
     add d466dbd  alter log and doc (#2660)
     add 11edabd  Enhancement: add backgroup exec for cli -e function (#2658)
     add b6586ff  [ISSUE-2656] Update GZIP compression type in user doc (#2657)
     add af42f2b  Move source mods to new TsFile after merge (#2591)
     add 119fe81  [IOTDB-1154] Remove `final` if there are no subclasses by design.(Happy New Year) (#2674)
     add 31c7848  [IOTDB-1155] One letter improvement, which add detailed error log information for exceptions. (#2675)
     add 05a628d  fix dependency error because some jars are removed from maven's central repo
     new 81e8ac5  Merge remote-tracking branch 'origin/master' into change_rpc_port
     new 1a6ce08  fix merge conflict
     new 1201834  fix merge conflict

The 3 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:
 .github/workflows/main-linux.yml                   |   8 +-
 README.md                                          |   1 +
 README_ZH.md                                       |   1 +
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4   |   2 +-
 .../java/org/apache/iotdb/cli/AbstractCli.java     |  12 +-
 cli/src/main/java/org/apache/iotdb/cli/Cli.java    |  18 +-
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |   2 -
 .../java/org/apache/iotdb/cluster/ClientMain.java  |   2 +-
 .../java/org/apache/iotdb/cluster/ClusterMain.java | 166 ++++++-------
 .../iotdb/cluster/client/DataClientProvider.java   |   2 +-
 .../cluster/server/member/RaftMemberMBean.java     |   2 +-
 .../apache/iotdb/cluster/utils/ClusterUtils.java   |   3 +-
 .../cluster/client/async/AsyncClientPoolTest.java  |  12 +-
 .../cluster/client/async/AsyncDataClientTest.java  |   2 +-
 .../cluster/client/async/AsyncMetaClientTest.java  |   2 +-
 ...uster.properties => iotdb-cluster-1.properties} |  25 +-
 ...uster.properties => iotdb-cluster-2.properties} |  25 +-
 ...uster.properties => iotdb-cluster-3.properties} |  25 +-
 ...engine.properties => iotdb-engine-1.properties} |  10 +-
 ...engine.properties => iotdb-engine-2.properties} |  10 +-
 ...engine.properties => iotdb-engine-3.properties} |  10 +-
 compile-tools/README.md                            |  27 +-
 docs/Community/Feedback.md                         |   2 +
 docs/Community/Materials.md                        | 132 +++++++---
 docs/UserGuide/Concept/Compression.md              |   4 +-
 docs/UserGuide/Concept/Encoding.md                 |   2 +-
 .../DDL Data Definition Language.md                |  41 ++-
 docs/UserGuide/Operation Manual/SQL Reference.md   |   9 +-
 docs/zh/Community/Feedback.md                      |   4 +-
 docs/zh/Community/Materials.md                     |  95 -------
 docs/zh/SystemDesign/DataQuery/SeriesReader.md     |   2 +-
 docs/zh/UserGuide/Concept/Compression.md           |   3 +-
 docs/zh/UserGuide/Concept/Encoding.md              |   2 +-
 docs/zh/UserGuide/Get Started/Publication.md       |   4 +-
 .../DDL Data Definition Language.md                |  42 +++-
 .../zh/UserGuide/Operation Manual/SQL Reference.md |   9 +-
 .../iotdb/jdbc/AbstractIoTDBJDBCResultSet.java     |   5 +-
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |   4 +
 pom.xml                                            |   2 +-
 .../resources/conf/iotdb-engine.properties         |   4 +-
 .../org/apache/iotdb/db/conf/IoTDBConfigCheck.java |  11 +-
 .../level/LevelCompactionTsFileManagement.java     |  38 ++-
 .../engine/compaction/utils/CompactionUtils.java   |  34 +--
 .../apache/iotdb/db/engine/flush/FlushManager.java |  43 ++--
 .../iotdb/db/engine/flush/MemTableFlushTask.java   |  11 +-
 .../engine/storagegroup/StorageGroupProcessor.java |   4 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  30 +--
 .../java/org/apache/iotdb/db/metadata/MTree.java   |  13 +-
 .../db/qp/logical/sys/ShowDevicesOperator.java     |   9 +
 .../iotdb/db/qp/physical/sys/ShowDevicesPlan.java  |   9 +-
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    |   5 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |   2 +-
 .../iotdb/db/query/control/QueryFileManager.java   |  20 +-
 .../iotdb/db/query/dataset/ShowDevicesDataSet.java |  20 +-
 .../iotdb/db/query/dataset/ShowDevicesResult.java  |  11 +-
 .../dataset/ShowResult.java}                       |  31 ++-
 .../db/query/dataset/ShowTimeSeriesResult.java     |  22 +-
 .../iotdb/db/query/executor/LastQueryExecutor.java |  22 +-
 .../org/apache/iotdb/db/service/JMXService.java    |   2 +-
 .../org/apache/iotdb/db/service/MQTTService.java   |   8 +-
 .../apache/iotdb/db/service/MetricsService.java    |   6 +-
 .../org/apache/iotdb/db/service/RPCService.java    |   2 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  42 +++-
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |   1 -
 .../iotdb/db/writelog/io/SingleFileLogReader.java  |   5 +-
 .../db/engine/compaction/CompactionChunkTest.java  |   4 +-
 ...ectorTest.java => LevelCompactionModsTest.java} |  49 ++--
 .../compaction/LevelCompactionRecoverTest.java     |  10 +-
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  37 ++-
 .../iotdb/db/integration/IoTDBAddSubDeviceIT.java  |  42 +++-
 .../iotdb/db/integration/IoTDBCheckConfigIT.java   | 157 ++++++++++++
 .../iotdb/db/integration/IoTDBEncodingIT.java      | 276 +++++++++++++++++++++
 .../iotdb/db/integration/IoTDBMetadataFetchIT.java |  37 +++
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   | 117 +++++++--
 .../iotdb/db/query/dataset/ListDataSetTest.java    |  21 ++
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |   5 +-
 .../apache/iotdb/session/SessionConnection.java    |   4 +-
 .../org/apache/iotdb/session/SessionDataSet.java   |   8 +-
 .../iotdb/session/IoTDBSessionIteratorIT.java      |   1 -
 site/src/main/.vuepress/config.js                  |  10 +-
 .../iotdb/tsfile/common/conf/TSFileDescriptor.java |   2 +-
 .../org/apache/iotdb/tsfile/utils/PublicBAOS.java  |  38 +++
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |  61 +++--
 .../zeppelin/iotdb/IoTDBInterpreterTest.java       |  13 +
 84 files changed, 1499 insertions(+), 527 deletions(-)
 copy cluster/src/test/resources/{node1conf/iotdb-cluster.properties => iotdb-cluster-1.properties} (63%)
 copy cluster/src/test/resources/{node1conf/iotdb-cluster.properties => iotdb-cluster-2.properties} (63%)
 copy cluster/src/test/resources/{node1conf/iotdb-cluster.properties => iotdb-cluster-3.properties} (63%)
 copy cluster/src/test/resources/{node1conf/iotdb-engine.properties => iotdb-engine-1.properties} (88%)
 copy cluster/src/test/resources/{node2conf/iotdb-engine.properties => iotdb-engine-2.properties} (88%)
 copy cluster/src/test/resources/{node3conf/iotdb-engine.properties => iotdb-engine-3.properties} (88%)
 delete mode 100644 docs/zh/Community/Materials.md
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/exception/NullFieldException.java => server/src/main/java/org/apache/iotdb/db/query/dataset/ShowDevicesResult.java (77%)
 copy server/src/main/java/org/apache/iotdb/db/{exception/metadata/DeleteFailedException.java => query/dataset/ShowResult.java} (61%)
 copy server/src/test/java/org/apache/iotdb/db/engine/compaction/{LevelCompactionSelectorTest.java => LevelCompactionModsTest.java} (52%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCheckConfigIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBEncodingIT.java


[iotdb] 03/03: fix merge conflict

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

hxd pushed a commit to branch change_rpc_port
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit 12018342974695cf48ae23d8669f52eb07a10af4
Author: xiangdong huang <sa...@gmail.com>
AuthorDate: Mon Feb 15 13:55:32 2021 +0800

    fix merge conflict
---
 .../java/org/apache/iotdb/cluster/ClusterMain.java | 134 ++++++++++-----------
 .../apache/iotdb/cluster/utils/ClusterNode.java    |   4 +-
 .../apache/iotdb/cluster/utils/ClusterUtils.java   |   2 +-
 .../cluster/client/async/AsyncClientPoolTest.java  |  12 +-
 .../cluster/client/async/AsyncDataClientTest.java  |   2 +-
 .../cluster/client/async/AsyncMetaClientTest.java  |   2 +-
 6 files changed, 78 insertions(+), 78 deletions(-)

diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java b/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
index 236c38c..d05a305 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
@@ -224,78 +224,78 @@ public class ClusterMain {
   private static void replaceDefaultProps(String[] params) {
     Options options = new Options();
 
-    Option metaPort = new Option(OPTION_INTERVAL_META_PORT, OPTION_INTERVAL_META_PORT, true,
-        "port for metadata service");
-    metaPort.setRequired(false);
-    options.addOption(metaPort);
-
-    Option dataPort = new Option(OPTION_INTERVAL_DATA_PORT, OPTION_INTERVAL_DATA_PORT, true,
-        "port for data service");
-    dataPort.setRequired(false);
-    options.addOption(dataPort);
-
-    Option clusterRpcPort = new Option(OPTION_CLUSTER_RPC_PORT, OPTION_CLUSTER_RPC_PORT, true,
-        "port for client service");
-    clusterRpcPort.setRequired(false);
-    options.addOption(clusterRpcPort);
-
-    Option clusterRpcIP = new Option(OPTION_CLUSTER_RPC_IP, OPTION_CLUSTER_RPC_IP, true,
-        "IP for client service");
-    clusterRpcIP.setRequired(false);
-    options.addOption(clusterRpcIP);
-
-    Option seedNodes = new Option(OPTION_SEED_NODES, OPTION_SEED_NODES, true,
-        "comma-separated {IP/DOMAIN}:meta_port:data_port:client_port pairs");
-    seedNodes.setRequired(false);
-    options.addOption(seedNodes);
-
-    Option debugRpcPort = new Option(OPTION_DEBUG_RPC_PORT, OPTION_DEBUG_RPC_PORT, true,
-        "port for debug client service (using single node mode)");
-    clusterRpcPort.setRequired(false);
-    options.addOption(debugRpcPort);
+//    Option metaPort = new Option(OPTION_INTERVAL_META_PORT, OPTION_INTERVAL_META_PORT, true,
+//        "port for metadata service");
+//    metaPort.setRequired(false);
+//    options.addOption(metaPort);
+//
+//    Option dataPort = new Option(OPTION_INTERVAL_DATA_PORT, OPTION_INTERVAL_DATA_PORT, true,
+//        "port for data service");
+//    dataPort.setRequired(false);
+//    options.addOption(dataPort);
+//
+//    Option clusterRpcPort = new Option(OPTION_CLUSTER_RPC_PORT, OPTION_CLUSTER_RPC_PORT, true,
+//        "port for client service");
+//    clusterRpcPort.setRequired(false);
+//    options.addOption(clusterRpcPort);
+//
+//    Option clusterRpcIP = new Option(OPTION_CLUSTER_RPC_IP, OPTION_CLUSTER_RPC_IP, true,
+//        "IP for client service");
+//    clusterRpcIP.setRequired(false);
+//    options.addOption(clusterRpcIP);
+//
+//    Option seedNodes = new Option(OPTION_SEED_NODES, OPTION_SEED_NODES, true,
+//        "comma-separated {IP/DOMAIN}:meta_port:data_port:client_port pairs");
+//    seedNodes.setRequired(false);
+//    options.addOption(seedNodes);
+//
+//    Option debugRpcPort = new Option(OPTION_DEBUG_RPC_PORT, OPTION_DEBUG_RPC_PORT, true,
+//        "port for debug client service (using single node mode)");
+//    clusterRpcPort.setRequired(false);
+//    options.addOption(debugRpcPort);
 
     CommandLine commandLine = parseCommandLine(options, params);
     if (commandLine == null) {
       logger.error("replaces properties failed, use default conf params");
     } else {
-      ClusterConfig clusterConfig = ClusterDescriptor.getInstance().getConfig();
-      if (commandLine.hasOption(OPTION_INTERVAL_META_PORT)) {
-        clusterConfig.setInternalMetaPort(Integer.parseInt(commandLine.getOptionValue(
-            OPTION_INTERVAL_META_PORT)));
-        logger.debug("replace local meta port with={}", clusterConfig.getInternalMetaPort());
-      }
-
-      if (commandLine.hasOption(OPTION_INTERVAL_DATA_PORT)) {
-        clusterConfig.setInternalDataPort(Integer.parseInt(commandLine.getOptionValue(
-            OPTION_INTERVAL_DATA_PORT)));
-        logger.debug("replace local data port with={}", clusterConfig.getInternalDataPort());
-      }
-
-      if (commandLine.hasOption(OPTION_CLUSTER_RPC_PORT)) {
-        clusterConfig.setClusterRpcPort(Integer.parseInt(commandLine.getOptionValue(
-            OPTION_CLUSTER_RPC_PORT)));
-        logger.debug("replace local cluster rpc port with={}", clusterConfig.getClusterRpcPort());
-      }
-
-      if (commandLine.hasOption(OPTION_CLUSTER_RPC_IP)) {
-        IoTDBDescriptor.getInstance().getConfig()
-            .setRpcAddress(commandLine.getOptionValue(OPTION_CLUSTER_RPC_IP));
-        logger.debug("replace local cluster rpc port with={}", clusterConfig.getClusterRpcPort());
-      }
-
-      if (commandLine.hasOption(OPTION_SEED_NODES)) {
-        String seedNodeUrls = commandLine.getOptionValue(OPTION_SEED_NODES);
-        clusterConfig.setSeedNodeUrls(ClusterDescriptor.getSeedUrlList(seedNodeUrls));
-        logger.debug("replace seed nodes with={}", clusterConfig.getSeedNodeUrls());
-      }
-
-      if (commandLine.hasOption(OPTION_DEBUG_RPC_PORT)) {
-        IoTDBDescriptor.getInstance().getConfig().setRpcPort(Integer.parseInt(commandLine.getOptionValue(
-            OPTION_DEBUG_RPC_PORT)));
-        IoTDBDescriptor.getInstance().getConfig().setEnableRPCService(true);
-        logger.debug("replace local cluster (single node) rpc port with={}", commandLine.getOptionValue(
-            OPTION_DEBUG_RPC_PORT));
-      }
+//      ClusterConfig clusterConfig = ClusterDescriptor.getInstance().getConfig();
+//      if (commandLine.hasOption(OPTION_INTERVAL_META_PORT)) {
+//        clusterConfig.setInternalMetaPort(Integer.parseInt(commandLine.getOptionValue(
+//            OPTION_INTERVAL_META_PORT)));
+//        logger.debug("replace local meta port with={}", clusterConfig.getInternalMetaPort());
+//      }
+//
+//      if (commandLine.hasOption(OPTION_INTERVAL_DATA_PORT)) {
+//        clusterConfig.setInternalDataPort(Integer.parseInt(commandLine.getOptionValue(
+//            OPTION_INTERVAL_DATA_PORT)));
+//        logger.debug("replace local data port with={}", clusterConfig.getInternalDataPort());
+//      }
+//
+//      if (commandLine.hasOption(OPTION_CLUSTER_RPC_PORT)) {
+//        clusterConfig.setClusterRpcPort(Integer.parseInt(commandLine.getOptionValue(
+//            OPTION_CLUSTER_RPC_PORT)));
+//        logger.debug("replace local cluster rpc port with={}", clusterConfig.getClusterRpcPort());
+//      }
+//
+//      if (commandLine.hasOption(OPTION_CLUSTER_RPC_IP)) {
+//        IoTDBDescriptor.getInstance().getConfig()
+//            .setRpcAddress(commandLine.getOptionValue(OPTION_CLUSTER_RPC_IP));
+//        logger.debug("replace local cluster rpc port with={}", clusterConfig.getClusterRpcPort());
+//      }
+//
+//      if (commandLine.hasOption(OPTION_SEED_NODES)) {
+//        String seedNodeUrls = commandLine.getOptionValue(OPTION_SEED_NODES);
+//        clusterConfig.setSeedNodeUrls(ClusterDescriptor.getSeedUrlList(seedNodeUrls));
+//        logger.debug("replace seed nodes with={}", clusterConfig.getSeedNodeUrls());
+//      }
+//
+//      if (commandLine.hasOption(OPTION_DEBUG_RPC_PORT)) {
+//        IoTDBDescriptor.getInstance().getConfig().setRpcPort(Integer.parseInt(commandLine.getOptionValue(
+//            OPTION_DEBUG_RPC_PORT)));
+//        IoTDBDescriptor.getInstance().getConfig().setEnableRPCService(true);
+//        logger.debug("replace local cluster (single node) rpc port with={}", commandLine.getOptionValue(
+//            OPTION_DEBUG_RPC_PORT));
+//      }
     }
   }
 
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
index 334c90f..1e5b15b 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
@@ -32,8 +32,8 @@ public class ClusterNode extends Node {
   public ClusterNode() {
   }
 
-  public ClusterNode(String ip, int metaPort, int nodeIdentifier, int dataPort, int clientPort) {
-    super(ip, metaPort, nodeIdentifier, dataPort, clientPort);
+  public ClusterNode(String ip, int metaPort, int nodeIdentifier, int dataPort) {
+    super(ip, metaPort, nodeIdentifier, dataPort);
   }
 
   public ClusterNode(Node other) {
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
index 7919595..f9207af 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
@@ -284,7 +284,7 @@ public class ClusterUtils {
     int dataPort = Integer.parseInt(str.substring(dataPortFirstPos, dataPortLastPos));
     int clientPort = Integer.parseInt(str.substring(clientPortFirstPos, clientPortLastPos));
     //TODO hxd: we do not set values to all fields of a Node.
-    return new Node(ip, metaPort, id, dataPort, clientPort);
+    return new Node(ip, metaPort, id, dataPort).setClientPort(clientPort);
   }
 
   public static Node parseNode(String nodeUrl) {
diff --git a/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncClientPoolTest.java b/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncClientPoolTest.java
index 9581903..12eb645 100644
--- a/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncClientPoolTest.java
+++ b/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncClientPoolTest.java
@@ -53,7 +53,7 @@ public class AsyncClientPoolTest {
   }
 
   private void getClient() throws IOException {
-    AsyncClientPool asyncClientPool = new AsyncClientPool("Test", testAsyncClientFactory);
+    AsyncClientPool asyncClientPool = new AsyncClientPool(testAsyncClientFactory);
     for (int i = 0; i < 10; i++) {
       AsyncClient client = asyncClientPool.getClient(TestUtils.getNode(i));
       if (client instanceof TestAsyncClient) {
@@ -64,7 +64,7 @@ public class AsyncClientPoolTest {
   }
 
   private void putClient() throws IOException {
-    AsyncClientPool asyncClientPool = new AsyncClientPool("Test", testAsyncClientFactory);
+    AsyncClientPool asyncClientPool = new AsyncClientPool(testAsyncClientFactory);
     List<AsyncClient> testClients = new ArrayList<>();
     for (int i = 0; i < 10; i++) {
       AsyncClient client = asyncClientPool.getClient(TestUtils.getNode(i));
@@ -95,7 +95,7 @@ public class AsyncClientPoolTest {
     int maxClientNum = ClusterDescriptor.getInstance().getConfig().getMaxClientPerNodePerMember();
     ClusterDescriptor.getInstance().getConfig().setMaxClientPerNodePerMember(5);
     testAsyncClientFactory = new TestAsyncClientFactory();
-    AsyncClientPool asyncClientPool = new AsyncClientPool("Test", testAsyncClientFactory);
+    AsyncClientPool asyncClientPool = new AsyncClientPool(testAsyncClientFactory);
 
     for (int i = 0; i < 5; i++) {
       asyncClientPool.getClient(TestUtils.getNode(0));
@@ -121,7 +121,7 @@ public class AsyncClientPoolTest {
     try {
       ClusterDescriptor.getInstance().getConfig().setMaxClientPerNodePerMember(10);
       testAsyncClientFactory = new TestAsyncClientFactory();
-      AsyncClientPool asyncClientPool = new AsyncClientPool("Test", testAsyncClientFactory);
+      AsyncClientPool asyncClientPool = new AsyncClientPool(testAsyncClientFactory);
 
       Node node = TestUtils.getNode(0);
       List<AsyncClient> clients = new ArrayList<>();
@@ -160,7 +160,7 @@ public class AsyncClientPoolTest {
     try {
       ClusterDescriptor.getInstance().getConfig().setMaxClientPerNodePerMember(1);
       testAsyncClientFactory = new TestAsyncClientFactory();
-      AsyncClientPool asyncClientPool = new AsyncClientPool("Test", testAsyncClientFactory);
+      AsyncClientPool asyncClientPool = new AsyncClientPool(testAsyncClientFactory);
 
       Node node = TestUtils.getNode(0);
       List<AsyncClient> clients = new ArrayList<>();
@@ -177,7 +177,7 @@ public class AsyncClientPoolTest {
   @Test
   public void testRecreateClient() throws IOException {
     testAsyncClientFactory = new TestAsyncClientFactory();
-    AsyncClientPool asyncClientPool = new AsyncClientPool("Test", new AsyncMetaClient.FactoryAsync(new Factory()));
+    AsyncClientPool asyncClientPool = new AsyncClientPool(new AsyncMetaClient.FactoryAsync(new Factory()));
 
     AsyncMetaClient client = (AsyncMetaClient) asyncClientPool.getClient(TestUtils.getNode(0));
     client.onError(new Exception());
diff --git a/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncDataClientTest.java b/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncDataClientTest.java
index 5f9afab..7030fc1 100644
--- a/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncDataClientTest.java
+++ b/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncDataClientTest.java
@@ -25,7 +25,7 @@ public class AsyncDataClientTest {
 
   @Test
   public void test() throws IOException, TException {
-    AsyncClientPool asyncClientPool = new AsyncClientPool("Test", new SingleManagerFactory(new Factory()));
+    AsyncClientPool asyncClientPool = new AsyncClientPool(new SingleManagerFactory(new Factory()));
     AsyncDataClient client;
     Node node = TestUtils.getNode(0);
     client = new AsyncDataClient(new Factory(), new TAsyncClientManager(),
diff --git a/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncMetaClientTest.java b/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncMetaClientTest.java
index 5e795f0..ffca8c5 100644
--- a/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncMetaClientTest.java
+++ b/cluster/src/test/java/org/apache/iotdb/cluster/client/async/AsyncMetaClientTest.java
@@ -25,7 +25,7 @@ public class AsyncMetaClientTest {
 
   @Test
   public void test() throws IOException, TException {
-    AsyncClientPool asyncClientPool = new AsyncClientPool("Test", new FactoryAsync(new Factory()));
+    AsyncClientPool asyncClientPool = new AsyncClientPool(new FactoryAsync(new Factory()));
     AsyncMetaClient client;
     Node node = TestUtils.getNode(0);
     client = new AsyncMetaClient(new Factory(), new TAsyncClientManager(),


[iotdb] 02/03: fix merge conflict

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

hxd pushed a commit to branch change_rpc_port
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit 1a6ce0868abb6e73af01daa09d6c98afbe984fe7
Author: xiangdong huang <sa...@gmail.com>
AuthorDate: Mon Feb 15 13:40:44 2021 +0800

    fix merge conflict
---
 .../java/org/apache/iotdb/cluster/ClusterMain.java | 32 ++++------------
 .../iotdb/cluster/client/DataClientProvider.java   |  2 +-
 .../cluster/server/member/RaftMemberMBean.java     |  2 +-
 .../apache/iotdb/cluster/utils/ClusterNode.java    |  4 +-
 .../apache/iotdb/cluster/utils/ClusterUtils.java   |  3 +-
 .../src/test/resources/iotdb-cluster-1.properties  | 43 ++++++++++++++++++++++
 .../src/test/resources/iotdb-cluster-2.properties  | 43 ++++++++++++++++++++++
 .../src/test/resources/iotdb-cluster-3.properties  | 43 ++++++++++++++++++++++
 .../src/test/resources/iotdb-engine-1.properties   | 29 +++++++++++++++
 .../src/test/resources/iotdb-engine-2.properties   | 29 +++++++++++++++
 .../src/test/resources/iotdb-engine-3.properties   | 29 +++++++++++++++
 11 files changed, 230 insertions(+), 29 deletions(-)

diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java b/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
index 224eace..236c38c 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
@@ -32,6 +32,7 @@ import org.apache.commons.cli.ParseException;
 import org.apache.iotdb.cluster.client.async.AsyncMetaClient;
 import org.apache.iotdb.cluster.client.sync.SyncClientAdaptor;
 import org.apache.iotdb.cluster.config.ClusterConfig;
+import org.apache.iotdb.cluster.config.ClusterConstant;
 import org.apache.iotdb.cluster.config.ClusterDescriptor;
 import org.apache.iotdb.cluster.exception.ConfigInconsistentException;
 import org.apache.iotdb.cluster.exception.StartUpCheckFailureException;
@@ -41,6 +42,7 @@ import org.apache.iotdb.cluster.rpc.thrift.Node;
 import org.apache.iotdb.cluster.server.MetaClusterServer;
 import org.apache.iotdb.cluster.server.Response;
 import org.apache.iotdb.cluster.utils.ClusterUtils;
+import org.apache.iotdb.db.conf.IoTDBConstant;
 import org.apache.iotdb.db.conf.IoTDBDescriptor;
 import org.apache.iotdb.db.exception.StartupException;
 import org.apache.iotdb.db.exception.query.QueryProcessException;
@@ -65,37 +67,18 @@ public class ClusterMain {
   // metaport-of-removed-node
   private static final String MODE_REMOVE = "-r";
 
-  private static final String OPTION_INTERVAL_META_PORT = "internal_meta_port";
-  private static final String OPTION_INTERVAL_DATA_PORT = "internal_data_port";
-  private static final String OPTION_CLUSTER_RPC_PORT = "rpc_port";
-  private static final String OPTION_SEED_NODES = "seed_nodes";
-  private static final String OPTION_DEBUG_RPC_PORT = "debug_rpc_port";
-  private static final String OPTION_CLUSTER_RPC_IP = "rpc_address";
-
   private static MetaClusterServer metaServer;
 
   public static void main(String[] args) {
     if (args.length < 1) {
       logger.error("Usage: <-s|-a|-r> "
-              + "[-{} <internal meta port>] "
-              + "[-{} <internal data port>] "
-              + "[-{} <cluster rpc port>] "
-              + "[-{} <cluster RPC address>]\n"
-              + "[-{} <node1:meta_port:data_port:cluster_rpc_port,"
-              + "node2:meta_port:data_port:cluster_rpc_port,"
-              + "...,noden:meta_port:data_port:cluster_rpc_port,>] "
-              + "[-{} <debug rpc port>]"
+              + "[-D{} <cluster module configure file>] "
+              + "[-D{} <server module configure file>] "
               + "-s: start the node as a seed\n"
               + "-a: start the node as a new node\n"
-              + "-r: remove the node out of the cluster\n"
-              + "or: set CLUSTER_CONF and IOTDB_CONF environment variable",
-          OPTION_INTERVAL_META_PORT,
-          OPTION_INTERVAL_DATA_PORT,
-          OPTION_CLUSTER_RPC_PORT,
-          OPTION_CLUSTER_RPC_IP,
-          OPTION_SEED_NODES,
-          //debug rpc is for starting another rpc port for the singleton IoTDB server.
-          OPTION_DEBUG_RPC_PORT
+              + "-r: remove the node out of the cluster\n",
+          ClusterConstant.CLUSTER_CONF,
+          IoTDBConstant.IOTDB_CONF
       );
 
       return;
@@ -105,6 +88,7 @@ public class ClusterMain {
     // the server's configuration.
     IoTDBDescriptor.getInstance().getConfig().setEnableRPCService(false);
     IoTDBDescriptor.getInstance().getConfig().setSyncEnable(false);
+    //auto create schema is took over by cluster module, so we disable it in the server module.
     IoTDBDescriptor.getInstance().getConfig().setAutoCreateSchemaEnabled(false);
 
     // params check
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/client/DataClientProvider.java b/cluster/src/main/java/org/apache/iotdb/cluster/client/DataClientProvider.java
index df35039..9a1c4df 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/client/DataClientProvider.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/client/DataClientProvider.java
@@ -46,7 +46,7 @@ public class DataClientProvider {
     if (!ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
       dataSyncClientPool = new SyncClientPool(new SyncDataClient.FactorySync(factory));
     } else {
-      dataAsyncClientPool = new AsyncClientPool("dataClientProvider", new FactoryAsync(factory));
+      dataAsyncClientPool = new AsyncClientPool(new FactoryAsync(factory));
     }
   }
 
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/server/member/RaftMemberMBean.java b/cluster/src/main/java/org/apache/iotdb/cluster/server/member/RaftMemberMBean.java
index 87150b2..48af171 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/server/member/RaftMemberMBean.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/server/member/RaftMemberMBean.java
@@ -23,7 +23,7 @@ import java.util.List;
 import java.util.Map;
 import org.apache.iotdb.cluster.rpc.thrift.Node;
 import org.apache.iotdb.cluster.server.NodeCharacter;
-import org.apache.iotdb.cluster.server.Peer;
+import org.apache.iotdb.cluster.server.monitor.Peer;
 
 /**
  * interfaces that the mbean of RaftMember will use
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
index 1e5b15b..334c90f 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterNode.java
@@ -32,8 +32,8 @@ public class ClusterNode extends Node {
   public ClusterNode() {
   }
 
-  public ClusterNode(String ip, int metaPort, int nodeIdentifier, int dataPort) {
-    super(ip, metaPort, nodeIdentifier, dataPort);
+  public ClusterNode(String ip, int metaPort, int nodeIdentifier, int dataPort, int clientPort) {
+    super(ip, metaPort, nodeIdentifier, dataPort, clientPort);
   }
 
   public ClusterNode(Node other) {
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
index cb8c0b6..7919595 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/utils/ClusterUtils.java
@@ -282,8 +282,9 @@ public class ClusterUtils {
     int metaPort = Integer.parseInt(str.substring(metaPortFirstPos, metaPortLastPos));
     int id = Integer.parseInt(str.substring(idFirstPos, idLastPos));
     int dataPort = Integer.parseInt(str.substring(dataPortFirstPos, dataPortLastPos));
+    int clientPort = Integer.parseInt(str.substring(clientPortFirstPos, clientPortLastPos));
     //TODO hxd: we do not set values to all fields of a Node.
-    return new Node(ip, metaPort, id, dataPort);
+    return new Node(ip, metaPort, id, dataPort, clientPort);
   }
 
   public static Node parseNode(String nodeUrl) {
diff --git a/cluster/src/test/resources/iotdb-cluster-1.properties b/cluster/src/test/resources/iotdb-cluster-1.properties
new file mode 100644
index 0000000..996b347
--- /dev/null
+++ b/cluster/src/test/resources/iotdb-cluster-1.properties
@@ -0,0 +1,43 @@
+#
+# 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.
+#
+
+cluster_rpc_ip=127.0.0.1
+internal_ip=127.0.0.1
+
+internal_meta_port=9003
+internal_data_port=40010
+
+seed_nodes=127.0.0.1:9003:40010:6667,127.0.0.1:9005:40012:6668,127.0.0.1:9007:40014:6669
+
+default_replica_num=2
+consistency_level=mid
+
+connection_timeout_ms=20000
+write_operation_timeout_ms=30000
+read_operation_timeout_ms=30000
+catch_up_timeout_ms=300000
+use_batch_in_catch_up=true
+min_num_of_logs_in_mem=1000
+max_num_of_logs_in_mem=2000
+log_deletion_check_interval_second=-1
+
+
+is_use_async_server=false
+is_use_async_applier=true
+is_enable_raft_log_persistence=true
diff --git a/cluster/src/test/resources/iotdb-cluster-2.properties b/cluster/src/test/resources/iotdb-cluster-2.properties
new file mode 100644
index 0000000..ad0f09a
--- /dev/null
+++ b/cluster/src/test/resources/iotdb-cluster-2.properties
@@ -0,0 +1,43 @@
+#
+# 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.
+#
+
+cluster_rpc_ip=127.0.0.1
+internal_ip=127.0.0.1
+
+internal_meta_port=9005
+internal_data_port=40012
+
+seed_nodes=127.0.0.1:9003:40010:6667,127.0.0.1:9005:40012:6668,127.0.0.1:9007:40014:6669
+
+default_replica_num=2
+consistency_level=mid
+
+connection_timeout_ms=20000
+write_operation_timeout_ms=30000
+read_operation_timeout_ms=30000
+catch_up_timeout_ms=300000
+use_batch_in_catch_up=true
+min_num_of_logs_in_mem=1000
+max_num_of_logs_in_mem=2000
+log_deletion_check_interval_second=-1
+
+
+is_use_async_server=false
+is_use_async_applier=true
+is_enable_raft_log_persistence=true
diff --git a/cluster/src/test/resources/iotdb-cluster-3.properties b/cluster/src/test/resources/iotdb-cluster-3.properties
new file mode 100644
index 0000000..7d7d94a
--- /dev/null
+++ b/cluster/src/test/resources/iotdb-cluster-3.properties
@@ -0,0 +1,43 @@
+#
+# 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.
+#
+
+cluster_rpc_ip=127.0.0.1
+internal_ip=127.0.0.1
+
+internal_meta_port=9007
+internal_data_port=40014
+
+seed_nodes=127.0.0.1:9003:40010:6667,127.0.0.1:9005:40012:6668,127.0.0.1:9007:40014:6669
+
+default_replica_num=2
+consistency_level=mid
+
+connection_timeout_ms=20000
+write_operation_timeout_ms=30000
+read_operation_timeout_ms=30000
+catch_up_timeout_ms=300000
+use_batch_in_catch_up=true
+min_num_of_logs_in_mem=1000
+max_num_of_logs_in_mem=2000
+log_deletion_check_interval_second=-1
+
+
+is_use_async_server=false
+is_use_async_applier=true
+is_enable_raft_log_persistence=true
diff --git a/cluster/src/test/resources/iotdb-engine-1.properties b/cluster/src/test/resources/iotdb-engine-1.properties
new file mode 100644
index 0000000..f21cda6
--- /dev/null
+++ b/cluster/src/test/resources/iotdb-engine-1.properties
@@ -0,0 +1,29 @@
+#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.
+
+
+base_dir=target/tmp1
+data_dirs=target/data1
+wal_dir=target/wal1
+index_root_dir=target/index1
+udf_root_dir=target/ext1
+tracing_dir=target/data/tracing1
+
+rpc_port=6667
+metrics_port=8181
+sync_server_port=5555
+mqtt_port=1883
\ No newline at end of file
diff --git a/cluster/src/test/resources/iotdb-engine-2.properties b/cluster/src/test/resources/iotdb-engine-2.properties
new file mode 100644
index 0000000..ecdffea
--- /dev/null
+++ b/cluster/src/test/resources/iotdb-engine-2.properties
@@ -0,0 +1,29 @@
+#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.
+
+
+base_dir=target/tmp2
+data_dirs=target/data2
+wal_dir=target/wal2
+index_root_dir=target/index2
+udf_root_dir=target/ext2
+tracing_dir=target/data/tracing2
+
+rpc_port=6668
+metrics_port=8182
+sync_server_port=5556
+mqtt_port=1884
\ No newline at end of file
diff --git a/cluster/src/test/resources/iotdb-engine-3.properties b/cluster/src/test/resources/iotdb-engine-3.properties
new file mode 100644
index 0000000..1269f45
--- /dev/null
+++ b/cluster/src/test/resources/iotdb-engine-3.properties
@@ -0,0 +1,29 @@
+#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.
+
+
+base_dir=target/tmp3
+data_dirs=target/data3
+wal_dir=target/wal3
+index_root_dir=target/index3
+udf_root_dir=target/ext3
+tracing_dir=target/data/tracing3
+
+rpc_port=6669
+metrics_port=8183
+sync_server_port=5557
+mqtt_port=1885
\ No newline at end of file


[iotdb] 01/03: Merge remote-tracking branch 'origin/master' into change_rpc_port

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

hxd pushed a commit to branch change_rpc_port
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit 81e8ac55208bc311d5e7e3ccfba21c37afeca244
Merge: a7345e3 05a628d
Author: xiangdong huang <sa...@gmail.com>
AuthorDate: Mon Feb 15 12:45:47 2021 +0800

    Merge remote-tracking branch 'origin/master' into change_rpc_port

 .github/workflows/main-linux.yml                   |   8 +-
 README.md                                          |   1 +
 README_ZH.md                                       |   1 +
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4   |   2 +-
 .../java/org/apache/iotdb/cli/AbstractCli.java     |  12 +-
 cli/src/main/java/org/apache/iotdb/cli/Cli.java    |  18 +-
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |   2 -
 .../java/org/apache/iotdb/cluster/ClientMain.java  |   2 +-
 compile-tools/README.md                            |  27 +-
 docs/Community/Feedback.md                         |   2 +
 docs/Community/Materials.md                        | 132 +++++++---
 docs/UserGuide/Concept/Compression.md              |   4 +-
 docs/UserGuide/Concept/Encoding.md                 |   2 +-
 .../DDL Data Definition Language.md                |  41 ++-
 docs/UserGuide/Operation Manual/SQL Reference.md   |   9 +-
 docs/zh/Community/Feedback.md                      |   4 +-
 docs/zh/Community/Materials.md                     |  95 -------
 docs/zh/SystemDesign/DataQuery/SeriesReader.md     |   2 +-
 docs/zh/UserGuide/Concept/Compression.md           |   3 +-
 docs/zh/UserGuide/Concept/Encoding.md              |   2 +-
 docs/zh/UserGuide/Get Started/Publication.md       |   4 +-
 .../DDL Data Definition Language.md                |  42 +++-
 .../zh/UserGuide/Operation Manual/SQL Reference.md |   9 +-
 .../iotdb/jdbc/AbstractIoTDBJDBCResultSet.java     |   5 +-
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |   4 +
 pom.xml                                            |   2 +-
 .../resources/conf/iotdb-engine.properties         |   4 +-
 .../org/apache/iotdb/db/conf/IoTDBConfigCheck.java |  11 +-
 .../level/LevelCompactionTsFileManagement.java     |  38 ++-
 .../engine/compaction/utils/CompactionUtils.java   |  34 +--
 .../apache/iotdb/db/engine/flush/FlushManager.java |  43 ++--
 .../iotdb/db/engine/flush/MemTableFlushTask.java   |  11 +-
 .../engine/storagegroup/StorageGroupProcessor.java |   4 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  30 +--
 .../java/org/apache/iotdb/db/metadata/MTree.java   |  13 +-
 .../db/qp/logical/sys/ShowDevicesOperator.java     |   9 +
 .../iotdb/db/qp/physical/sys/ShowDevicesPlan.java  |   9 +-
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    |   5 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |   2 +-
 .../iotdb/db/query/control/QueryFileManager.java   |  20 +-
 .../iotdb/db/query/dataset/ShowDevicesDataSet.java |  20 +-
 .../dataset/ShowDevicesResult.java}                |  18 +-
 .../dataset/ShowResult.java}                       |  35 ++-
 .../db/query/dataset/ShowTimeSeriesResult.java     |  22 +-
 .../iotdb/db/query/executor/LastQueryExecutor.java |  22 +-
 .../org/apache/iotdb/db/service/JMXService.java    |   2 +-
 .../org/apache/iotdb/db/service/MQTTService.java   |   8 +-
 .../apache/iotdb/db/service/MetricsService.java    |   6 +-
 .../org/apache/iotdb/db/service/RPCService.java    |   2 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  42 +++-
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |   1 -
 .../iotdb/db/writelog/io/SingleFileLogReader.java  |   5 +-
 .../db/engine/compaction/CompactionChunkTest.java  |   4 +-
 .../engine/compaction/LevelCompactionModsTest.java |  90 +++++++
 .../compaction/LevelCompactionRecoverTest.java     |  10 +-
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  37 ++-
 .../iotdb/db/integration/IoTDBAddSubDeviceIT.java  |  42 +++-
 .../iotdb/db/integration/IoTDBCheckConfigIT.java   | 157 ++++++++++++
 .../iotdb/db/integration/IoTDBEncodingIT.java      | 276 +++++++++++++++++++++
 .../iotdb/db/integration/IoTDBMetadataFetchIT.java |  37 +++
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   | 117 +++++++--
 .../iotdb/db/query/dataset/ListDataSetTest.java    |  21 ++
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |   5 +-
 .../apache/iotdb/session/SessionConnection.java    |   4 +-
 .../org/apache/iotdb/session/SessionDataSet.java   |   8 +-
 .../iotdb/session/IoTDBSessionIteratorIT.java      |   1 -
 site/src/main/.vuepress/config.js                  |  10 +-
 .../iotdb/tsfile/common/conf/TSFileDescriptor.java |   2 +-
 .../org/apache/iotdb/tsfile/utils/PublicBAOS.java  |  38 +++
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |  61 +++--
 .../zeppelin/iotdb/IoTDBInterpreterTest.java       |  13 +
 71 files changed, 1390 insertions(+), 394 deletions(-)