You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by lt...@apache.org on 2019/05/31 01:24:41 UTC

[incubator-iotdb] branch cluster updated (1af785f -> ffc9d89)

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

lta pushed a change to branch cluster
in repository https://gitbox.apache.org/repos/asf/incubator-iotdb.git.


    from 1af785f  fix bug
     new 305906a  fix a bug of aggre query and groupby query
     add 8fc0c7e  fix unstable unit test and polish ReadOnlyTsFile query logic (#177)
     add 5b26774  modify error statement in doc (#182)
     add 84bdd5a  [IOTDB-100]Fix return error message while executing sum aggregation query (#181)
     add 2fbd949  [IOTDB-95]keep stack trace when logging or throwing an Exception (#180)
     add 000891f  fix bug where IOTDB_HOME is misused (#184)
     new f57d49f  merge master
     new 130bcff  update engine properties
     new 3f7af57  update engine properties
     new ffc9d89  update

The 5 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:
 README.md                                          |   9 +
 .../iotdb/cluster/entity/raft/RaftService.java     |   4 +-
 .../cluster/query/executor/ClusterQueryRouter.java |   6 +
 .../rpc/raft/impl/RaftNodeAsClientManager.java     |  30 ---
 docs/Documentation/QuickStart.md                   |  10 +
 .../UserGuideV0.7.0/4-Deployment and Management.md |  71 +++++-
 .../UserGuideV0.7.0/5-SQL Documentation.md         |   4 +-
 .../iotdb/tsfile/hadoop/TSFRecordWriter.java       |  11 +-
 .../iotdb/tsfile/hadoop/example/TsFileHelper.java  |   6 +-
 .../cn/edu/thu/tsfile/hadoop/TsFileTestHelper.java |   6 +-
 iotdb-cli/cli/bin/export-csv.bat                   |  10 +-
 iotdb-cli/cli/bin/export-csv.sh                    |   8 +-
 iotdb-cli/cli/bin/import-csv.bat                   |  10 +-
 iotdb-cli/cli/bin/import-csv.sh                    |   8 +-
 iotdb-cli/cli/bin/start-client.bat                 |   8 +-
 iotdb-cli/cli/bin/start-client.sh                  |   6 +-
 .../java/org/apache/iotdb/cli/tool/ImportCsv.java  |   4 +-
 iotdb/iotdb/conf/iotdb-engine.properties           |   2 +-
 .../iotdb/db/auth/authorizer/BasicAuthorizer.java  |   3 +-
 .../exception/BufferWriteProcessorException.java   |   2 +-
 .../db/exception/FileNodeProcessorException.java   |   2 +-
 .../db/exception/OverflowProcessorException.java   |   2 +-
 .../db/exception/qp/IllegalASTFormatException.java |   7 +
 .../db/exception/qp/LogicalOperatorException.java  |   7 +
 .../db/exception/qp/LogicalOptimizeException.java  |   7 +
 .../db/exception/qp/QueryProcessorException.java   |   4 +
 .../org/apache/iotdb/db/qp/QueryProcessor.java     |   2 +-
 .../iotdb/db/qp/executor/QueryProcessExecutor.java |   2 +-
 .../db/qp/logical/crud/BasicFunctionOperator.java  |   2 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |   2 +-
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |   9 +-
 .../db/query/aggregation/AggregateFunction.java    |   1 -
 .../db/query/aggregation/impl/MeanAggrFunc.java    |  11 +-
 .../db/query/aggregation/impl/SumAggrFunc.java     |  10 +
 .../apache/iotdb/db/service/CloseMergeService.java |   6 +-
 .../java/org/apache/iotdb/db/service/IoTDB.java    |   9 +-
 .../org/apache/iotdb/db/service/JDBCService.java   |   9 +-
 .../org/apache/iotdb/db/service/JMXService.java    |   5 +-
 .../java/org/apache/iotdb/db/service/Monitor.java  |   3 +-
 .../apache/iotdb/db/service/RegisterManager.java   |   2 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  13 +-
 .../org/apache/iotdb/db/sql/parse/ParseDriver.java |   2 +-
 .../org/apache/iotdb/db/utils/RecordUtils.java     |   2 +-
 .../writelog/manager/MultiFileLogNodeManager.java  |   9 +-
 .../db/writelog/node/ExclusiveWriteLogNode.java    |   2 +-
 .../recover/ExclusiveLogRecoverPerformer.java      |  11 +-
 .../db/writelog/replay/ConcreteLogReplayer.java    |   2 +-
 .../iotdb/db/integration/IoTDBAggregationIT.java   |  86 +++++++-
 .../org/apache/iotdb/jdbc/IoTDBConnection.java     |   6 +-
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |   6 +-
 .../org/apache/iotdb/tsfile/DefaultSource.scala    |   9 +-
 .../tsfile/common/constant/QueryConstant.java      |   6 -
 .../tsfile/exception/write/PageException.java      |   8 +
 .../exception/write/WriteProcessException.java     |  16 +-
 .../apache/iotdb/tsfile/read/ReadOnlyTsFile.java   |  17 +-
 .../apache/iotdb/tsfile/read/common/TimeRange.java | 225 +++++++++++--------
 .../tsfile/read/controller/MetadataQuerier.java    |  39 +---
 .../read/controller/MetadataQuerierByFileImpl.java | 189 ++++++++--------
 .../tsfile/read/query/executor/TsFileExecutor.java | 100 ++++-----
 .../iotdb/tsfile/write/chunk/ChunkBuffer.java      |   7 +-
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |   7 +-
 .../iotdb/tsfile/read/ReadInPartitionTest.java     | 244 ++++++++++++---------
 .../iotdb/tsfile/read/common/TimeRangeTest.java    |  42 +++-
 .../controller/MetadataQuerierByFileImplTest.java  | 156 ++++++++-----
 64 files changed, 880 insertions(+), 644 deletions(-)


[incubator-iotdb] 02/05: merge master

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

lta pushed a commit to branch cluster
in repository https://gitbox.apache.org/repos/asf/incubator-iotdb.git

commit f57d49f4c10ded893688ba61a085d25d07a8c1a6
Merge: 305906a 000891f
Author: lta <li...@163.com>
AuthorDate: Tue May 28 14:25:48 2019 +0800

    merge master

 README.md                                          |   9 +
 docs/Documentation/QuickStart.md                   |  10 +
 .../UserGuideV0.7.0/4-Deployment and Management.md |  71 +++++-
 .../UserGuideV0.7.0/5-SQL Documentation.md         |   4 +-
 .../iotdb/tsfile/hadoop/TSFRecordWriter.java       |  11 +-
 .../iotdb/tsfile/hadoop/example/TsFileHelper.java  |   6 +-
 .../cn/edu/thu/tsfile/hadoop/TsFileTestHelper.java |   6 +-
 iotdb-cli/cli/bin/export-csv.bat                   |  10 +-
 iotdb-cli/cli/bin/export-csv.sh                    |   8 +-
 iotdb-cli/cli/bin/import-csv.bat                   |  10 +-
 iotdb-cli/cli/bin/import-csv.sh                    |   8 +-
 iotdb-cli/cli/bin/start-client.bat                 |   8 +-
 iotdb-cli/cli/bin/start-client.sh                  |   6 +-
 .../java/org/apache/iotdb/cli/tool/ImportCsv.java  |   4 +-
 .../iotdb/db/auth/authorizer/BasicAuthorizer.java  |   3 +-
 .../exception/BufferWriteProcessorException.java   |   2 +-
 .../db/exception/FileNodeProcessorException.java   |   2 +-
 .../db/exception/OverflowProcessorException.java   |   2 +-
 .../db/exception/qp/IllegalASTFormatException.java |   7 +
 .../db/exception/qp/LogicalOperatorException.java  |   7 +
 .../db/exception/qp/LogicalOptimizeException.java  |   7 +
 .../db/exception/qp/QueryProcessorException.java   |   4 +
 .../org/apache/iotdb/db/qp/QueryProcessor.java     |   2 +-
 .../iotdb/db/qp/executor/QueryProcessExecutor.java |   2 +-
 .../db/qp/logical/crud/BasicFunctionOperator.java  |   2 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |   2 +-
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |   9 +-
 .../db/query/aggregation/AggregateFunction.java    |   1 -
 .../db/query/aggregation/impl/MeanAggrFunc.java    |  11 +-
 .../db/query/aggregation/impl/SumAggrFunc.java     |  10 +
 .../apache/iotdb/db/service/CloseMergeService.java |   6 +-
 .../java/org/apache/iotdb/db/service/IoTDB.java    |   9 +-
 .../org/apache/iotdb/db/service/JDBCService.java   |   9 +-
 .../org/apache/iotdb/db/service/JMXService.java    |   5 +-
 .../java/org/apache/iotdb/db/service/Monitor.java  |   3 +-
 .../apache/iotdb/db/service/RegisterManager.java   |   2 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  13 +-
 .../org/apache/iotdb/db/sql/parse/ParseDriver.java |   2 +-
 .../org/apache/iotdb/db/utils/RecordUtils.java     |   2 +-
 .../writelog/manager/MultiFileLogNodeManager.java  |   9 +-
 .../db/writelog/node/ExclusiveWriteLogNode.java    |   2 +-
 .../recover/ExclusiveLogRecoverPerformer.java      |  11 +-
 .../db/writelog/replay/ConcreteLogReplayer.java    |   2 +-
 .../iotdb/db/integration/IoTDBAggregationIT.java   |  86 +++++++-
 .../org/apache/iotdb/jdbc/IoTDBConnection.java     |   6 +-
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |   6 +-
 .../org/apache/iotdb/tsfile/DefaultSource.scala    |   9 +-
 .../tsfile/common/constant/QueryConstant.java      |   6 -
 .../tsfile/exception/write/PageException.java      |   8 +
 .../exception/write/WriteProcessException.java     |  16 +-
 .../apache/iotdb/tsfile/read/ReadOnlyTsFile.java   |  17 +-
 .../apache/iotdb/tsfile/read/common/TimeRange.java | 225 +++++++++++--------
 .../tsfile/read/controller/MetadataQuerier.java    |  39 +---
 .../read/controller/MetadataQuerierByFileImpl.java | 189 ++++++++--------
 .../tsfile/read/query/executor/TsFileExecutor.java | 100 ++++-----
 .../iotdb/tsfile/write/chunk/ChunkBuffer.java      |   7 +-
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |   7 +-
 .../iotdb/tsfile/read/ReadInPartitionTest.java     | 244 ++++++++++++---------
 .../iotdb/tsfile/read/common/TimeRangeTest.java    |  42 +++-
 .../controller/MetadataQuerierByFileImplTest.java  | 156 ++++++++-----
 60 files changed, 871 insertions(+), 611 deletions(-)

diff --cc iotdb/src/main/java/org/apache/iotdb/db/service/TSServiceImpl.java
index 4614ade,592b009..3be00aa
--- a/iotdb/src/main/java/org/apache/iotdb/db/service/TSServiceImpl.java
+++ b/iotdb/src/main/java/org/apache/iotdb/db/service/TSServiceImpl.java
@@@ -471,9 -465,10 +471,10 @@@ public class TSServiceImpl implements T
                "Fail to generate physcial plan and execute for statement "
                    + "%s beacuse %s",
                statement, e.getMessage());
+           LOGGER.warn("Error occurred when executing {}", statement, e);
            result.add(Statement.EXECUTE_FAILED);
            isAllSuccessful = false;
 -          batchErrorMessage = errMessage;
 +          batchErrorMessage.append(String.format(ERROR_MESSAGE_FORMAT_IN_BATCH, i, errMessage));
          }
        }
        if (isAllSuccessful) {


[incubator-iotdb] 05/05: update

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

lta pushed a commit to branch cluster
in repository https://gitbox.apache.org/repos/asf/incubator-iotdb.git

commit ffc9d8981d4dd4c654c14e44fac2b710749add09
Author: lta <li...@163.com>
AuthorDate: Fri May 31 09:24:20 2019 +0800

    update
---
 .../iotdb/cluster/entity/raft/RaftService.java     |  4 +--
 .../rpc/raft/impl/RaftNodeAsClientManager.java     | 30 ----------------------
 2 files changed, 2 insertions(+), 32 deletions(-)

diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/entity/raft/RaftService.java b/cluster/src/main/java/org/apache/iotdb/cluster/entity/raft/RaftService.java
index 45d2221..d910f0f 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/entity/raft/RaftService.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/entity/raft/RaftService.java
@@ -47,11 +47,11 @@ public class RaftService implements IService {
 
   public RaftService(String groupId, PeerId[] peerIds, PeerId serverId, RpcServer rpcServer, StateMachine fsm, boolean startRpcServer) {
     this.peerIdList = new ArrayList<>(peerIds.length);
-    peerIdList.addAll(Arrays.asList(peerIds));
+    this.peerIdList.addAll(Arrays.asList(peerIds));
     this.fsm = fsm;
     this.groupId = groupId;
     this.startRpcServer = startRpcServer;
-    raftGroupService = new RaftGroupService(groupId, serverId, null, rpcServer);
+    this.raftGroupService = new RaftGroupService(groupId, serverId, null, rpcServer);
   }
 
   @Override
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/rpc/raft/impl/RaftNodeAsClientManager.java b/cluster/src/main/java/org/apache/iotdb/cluster/rpc/raft/impl/RaftNodeAsClientManager.java
index d19ea88..088177f 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/rpc/raft/impl/RaftNodeAsClientManager.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/rpc/raft/impl/RaftNodeAsClientManager.java
@@ -216,36 +216,6 @@ public class RaftNodeAsClientManager {
 
     @Override
     public void asyncHandleRequest(SingleQPTask qpTask) {
-//      LOGGER.debug("Node as client to send request to leader: {}", qpTask.getTargetNode());
-//      try {
-//        boltClientService.getRpcClient()
-//            .invokeWithCallback(qpTask.getTargetNode().getEndpoint().toString(),
-//                qpTask.getRequest(),
-//                new InvokeCallback() {
-//
-//                  @Override
-//                  public void onResponse(Object result) {
-//                    BasicResponse response = (BasicResponse) result;
-//                    qpTask.receive(response);
-//                  }
-//
-//                  @Override
-//                  public void onException(Throwable e) {
-//                    LOGGER.error("Bolt rpc client occurs errors when handling Request", e);
-//                    qpTask.setTaskState(TaskState.EXCEPTION);
-//                    qpTask.receive(null);
-//                  }
-//
-//                  @Override
-//                  public Executor getExecutor() {
-//                    return null;
-//                  }
-//                }, TASK_TIMEOUT_MS);
-//      } catch (RemotingException | InterruptedException e) {
-//        LOGGER.error(e.getMessage());
-//        qpTask.setTaskState(TaskState.RAFT_CONNECTION_EXCEPTION);
-//        qpTask.receive(null);
-//      }
       LOGGER.debug("Node as client to send request to leader: {}", qpTask.getTargetNode());
       try {
         BasicResponse response = (BasicResponse) boltClientService.getRpcClient()


[incubator-iotdb] 01/05: fix a bug of aggre query and groupby query

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

lta pushed a commit to branch cluster
in repository https://gitbox.apache.org/repos/asf/incubator-iotdb.git

commit 305906a194d077202510010916c51656c7798c7d
Author: lta <li...@163.com>
AuthorDate: Tue May 28 14:24:18 2019 +0800

    fix a bug of aggre query and groupby query
---
 .../org/apache/iotdb/cluster/query/executor/ClusterQueryRouter.java | 6 ++++++
 1 file changed, 6 insertions(+)

diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/query/executor/ClusterQueryRouter.java b/cluster/src/main/java/org/apache/iotdb/cluster/query/executor/ClusterQueryRouter.java
index 9f9dc41..d56540e 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/query/executor/ClusterQueryRouter.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/query/executor/ClusterQueryRouter.java
@@ -108,6 +108,9 @@ public class ClusterQueryRouter extends AbstractQueryRouter {
       if (expression != null) {
         IExpression optimizedExpression = ExpressionOptimizer.getInstance()
             .optimize(expression, selectedSeries);
+        // update query expression of origin query plan, it's necessary.
+        queryManager.getOriginQueryPlan().setExpression(optimizedExpression);
+
         AggregateEngineExecutor engineExecutor = new ClusterAggregateEngineExecutor(
             selectedSeries, aggres, optimizedExpression, queryManager);
         if (optimizedExpression.getType() == ExpressionType.GLOBAL_TIME) {
@@ -166,6 +169,9 @@ public class ClusterQueryRouter extends AbstractQueryRouter {
 
     IExpression optimizedExpression = ExpressionOptimizer.getInstance()
         .optimize(expression, selectedSeries);
+    // update query expression of origin query plan, it's necessary.
+    queryManager.getOriginQueryPlan().setExpression(optimizedExpression);
+
     try {
       if (optimizedExpression.getType() == ExpressionType.GLOBAL_TIME) {
         queryManager.initQueryResource(QueryType.GLOBAL_TIME, getReadDataConsistencyLevel());


[incubator-iotdb] 04/05: update engine properties

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

lta pushed a commit to branch cluster
in repository https://gitbox.apache.org/repos/asf/incubator-iotdb.git

commit 3f7af57c972074e4e4492e268b6c8beebe6e4796
Author: lta <li...@163.com>
AuthorDate: Wed May 29 15:21:28 2019 +0800

    update engine properties
---
 iotdb/iotdb/conf/iotdb-engine.properties | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/iotdb/iotdb/conf/iotdb-engine.properties b/iotdb/iotdb/conf/iotdb-engine.properties
index 9dfe1c9..7015e60 100644
--- a/iotdb/iotdb/conf/iotdb-engine.properties
+++ b/iotdb/iotdb/conf/iotdb-engine.properties
@@ -218,4 +218,4 @@ IP_white_list=0.0.0.0/0
 # Choose a sync strategy of loading historical data:
 #1. It's more likely to update historical data, please choose "true".
 #2. It's more likely not to update historical data or you don't know exactly, please choose "false". 
-update_historical_data_possibility=false
+update_historical_data_possibility=false
\ No newline at end of file


[incubator-iotdb] 03/05: update engine properties

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

lta pushed a commit to branch cluster
in repository https://gitbox.apache.org/repos/asf/incubator-iotdb.git

commit 130bcfff2c7a4dd21ad3d86b9ffeda4a49ffc639
Author: lta <li...@163.com>
AuthorDate: Wed May 29 15:20:19 2019 +0800

    update engine properties
---
 iotdb/iotdb/conf/iotdb-engine.properties | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/iotdb/iotdb/conf/iotdb-engine.properties b/iotdb/iotdb/conf/iotdb-engine.properties
index 5cd37f4..9dfe1c9 100644
--- a/iotdb/iotdb/conf/iotdb-engine.properties
+++ b/iotdb/iotdb/conf/iotdb-engine.properties
@@ -218,4 +218,4 @@ IP_white_list=0.0.0.0/0
 # Choose a sync strategy of loading historical data:
 #1. It's more likely to update historical data, please choose "true".
 #2. It's more likely not to update historical data or you don't know exactly, please choose "false". 
-updateHistoricalDataPossibility=false
+update_historical_data_possibility=false