You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by hu...@apache.org on 2022/05/31 11:37:42 UTC

[iotdb] branch lmh/AlignByDeviceDebug created (now 24e1478bc5)

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

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


      at 24e1478bc5 Merge remote-tracking branch 'origin/master' into lmh/AlignByDeviceDebug

This branch includes the following new commits:

     new fe064b03bb fix UT
     new 9f6f4cf654 Merge remote-tracking branch 'origin/master' into lmh/AlignByDeviceDebug
     new 24e1478bc5 Merge remote-tracking branch 'origin/master' into lmh/AlignByDeviceDebug

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.



[iotdb] 03/03: Merge remote-tracking branch 'origin/master' into lmh/AlignByDeviceDebug

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

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

commit 24e1478bc5d42061a57c41b82e12a482e529d4e4
Merge: 9f6f4cf654 d9d2465f0d
Author: Minghui Liu <li...@foxmail.com>
AuthorDate: Tue May 31 14:20:29 2022 +0800

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

 .../execution/schedule/AbstractDriverThread.java   |  8 +++-
 .../db/mpp/execution/schedule/DriverScheduler.java | 34 ++++++++++-------
 .../schedule/FragmentInstanceAbortedException.java |  1 +
 .../db/mpp/plan/analyze/ExpressionAnalyzer.java    | 10 ++++-
 .../db/mpp/plan/planner/LocalExecutionPlanner.java |  6 +--
 .../java/org/apache/iotdb/db/service/DataNode.java |  9 +++--
 ...erTest.java => DefaultDriverSchedulerTest.java} |  2 +-
 .../execution/schedule/DriverSchedulerTest.java    |  2 +-
 .../DriverTaskTimeoutSentinelThreadTest.java       | 43 ++++++++++++++++++++++
 9 files changed, 90 insertions(+), 25 deletions(-)


[iotdb] 01/03: fix UT

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

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

commit fe064b03bbb7fc5eec30015aaa80d8648123f897
Author: Minghui Liu <li...@foxmail.com>
AuthorDate: Tue May 31 09:23:03 2022 +0800

    fix UT
---
 .../apache/iotdb/db/mpp/plan/plan/QueryLogicalPlanUtil.java    | 10 +++++-----
 1 file changed, 5 insertions(+), 5 deletions(-)

diff --git a/server/src/test/java/org/apache/iotdb/db/mpp/plan/plan/QueryLogicalPlanUtil.java b/server/src/test/java/org/apache/iotdb/db/mpp/plan/plan/QueryLogicalPlanUtil.java
index f38534b825..b7853c21eb 100644
--- a/server/src/test/java/org/apache/iotdb/db/mpp/plan/plan/QueryLogicalPlanUtil.java
+++ b/server/src/test/java/org/apache/iotdb/db/mpp/plan/plan/QueryLogicalPlanUtil.java
@@ -152,11 +152,6 @@ public class QueryLogicalPlanUtil {
 
     QueryId queryId = new QueryId("test");
     List<PlanNode> sourceNodeList = new ArrayList<>();
-    sourceNodeList.add(
-        new AlignedSeriesScanNode(
-            queryId.genPlanNodeId(),
-            (AlignedPath) schemaMap.get("root.sg.d2.a"),
-            OrderBy.TIMESTAMP_ASC));
     sourceNodeList.add(
         new SeriesScanNode(
             queryId.genPlanNodeId(),
@@ -172,6 +167,11 @@ public class QueryLogicalPlanUtil {
             queryId.genPlanNodeId(),
             (MeasurementPath) schemaMap.get("root.sg.d2.s4"),
             OrderBy.TIMESTAMP_ASC));
+    sourceNodeList.add(
+        new AlignedSeriesScanNode(
+            queryId.genPlanNodeId(),
+            (AlignedPath) schemaMap.get("root.sg.d2.a"),
+            OrderBy.TIMESTAMP_ASC));
     TimeJoinNode timeJoinNode =
         new TimeJoinNode(queryId.genPlanNodeId(), OrderBy.TIMESTAMP_ASC, sourceNodeList);
     OffsetNode offsetNode = new OffsetNode(queryId.genPlanNodeId(), timeJoinNode, 10);


[iotdb] 02/03: Merge remote-tracking branch 'origin/master' into lmh/AlignByDeviceDebug

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

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

commit 9f6f4cf6540ada1f6e9cc2094754bc3a44245e22
Merge: fe064b03bb b343478a41
Author: Minghui Liu <li...@foxmail.com>
AuthorDate: Tue May 31 09:25:56 2022 +0800

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

 .../service/AbstractThriftServiceThread.java       |  38 +------
 .../iotdb/db/engine/memtable/AbstractMemTable.java |   7 +-
 .../iotdb/db/engine/storagegroup/DataRegion.java   |   5 +-
 .../db/engine/storagegroup/TsFileProcessor.java    |   2 +-
 .../SmoothQueueSlidingWindowAggregator.java        |   1 +
 .../execution/operator/process/FilterOperator.java |  80 +++++++--------
 .../operator/process/LinearFillOperator.java       |   3 +-
 .../operator/process/TransformOperator.java        |  70 +++++++------
 .../operator/process/merge/SingleColumnMerger.java |   4 +-
 .../db/mpp/plan/statement/crud/QueryStatement.java |   4 +
 .../query/reader/chunk/MemAlignedPageReader.java   |  10 +-
 .../java/org/apache/iotdb/db/service/DataNode.java |   9 +-
 .../java/org/apache/iotdb/db/service/IoTDB.java    |   9 +-
 .../thrift/impl/DataNodeTSIServiceImpl.java        |  24 ++---
 .../java/org/apache/iotdb/db/wal/WALManager.java   |  15 ++-
 .../allocation/AbstractNodeAllocationStrategy.java |   9 ++
 .../db/wal/allocation/FirstCreateStrategy.java     |   4 +-
 .../iotdb/db/wal/buffer/AbstractWALBuffer.java     |   4 +-
 .../org/apache/iotdb/db/wal/buffer/WALBuffer.java  |   7 +-
 .../iotdb/db/wal/checkpoint/CheckpointManager.java |  40 +++++---
 .../iotdb/db/wal/checkpoint/MemTableInfo.java      |   1 -
 .../apache/iotdb/db/wal/io/CheckpointReader.java   |  22 ++--
 .../java/org/apache/iotdb/db/wal/node/WALNode.java |   7 +-
 .../db/wal/recover/CheckpointRecoverUtils.java     |  32 +++++-
 .../iotdb/db/wal/recover/WALNodeRecoverTask.java   |  34 ++++++-
 .../iotdb/db/wal/utils/CheckpointFileUtils.java    |   3 +-
 .../apache/iotdb/db/wal/utils/WALFileUtils.java    |  30 +++---
 .../execution/operator/LinearFillOperatorTest.java | 113 ++++++++++++++++++++-
 .../db/wal/allocation/FirstCreateStrategyTest.java |   2 +-
 .../db/wal/checkpoint/CheckpointManagerTest.java   |   6 +-
 .../apache/iotdb/db/wal/io/CheckpointFileTest.java |  12 ++-
 .../iotdb/db/wal/node/ConsensusReqReaderTest.java  |  14 +--
 .../org/apache/iotdb/db/wal/node/WALNodeTest.java  |   2 +-
 .../iotdb/tsfile/read/common/block/TsBlock.java    |   3 +-
 34 files changed, 407 insertions(+), 219 deletions(-)