You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by ja...@apache.org on 2021/02/04 09:23:36 UTC

[iotdb] branch ImproveFlush updated (e8e7bf9 -> 5a90325)

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

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


    from e8e7bf9  improve flush
     add 20b43bb  disable the merge task in PullSnapshotTaskTest (#2583)
     add 9d88a8e  [C++ Client] remove compiling boost for compling client-cpp module (#2509)
     add 9365210  [IOTDB-1077] [C++ Client] Add insertRecordsOfOneDevice() interface for C++ client (#2513)
     add ad993b8  [IOTDB-1083] There is no need to get write lock each time when we try to get or create TsFileProcessor (#2353)
     add 4b2320b  add missing override annotation (#2329)
     add de0c59b  remove print output in some tests (#2604)
     add 04b0982  [IOTDB-1137] MNode.getLeafCount error when existing sub-device (#2602)
     add 27a0e65  Add compaction chunk test (#2586)
     add 946d4b8  refactor CI by split a CI into several parts, fix code-coverage and extract jar-with-dependencies (#2603)
     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)
     new 5a90325  fix conflicts

The 1 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/client.yml                       |  98 ++++++++++
 .github/workflows/main-linux.yml                   |  69 +++++++
 .github/workflows/main-mac.yml                     |  46 +++++
 .github/workflows/{main-ci.yml => main-win.yml}    |  69 +++----
 .github/workflows/sonar_and_coverall.yml           |  76 --------
 Jenkinsfile                                        |   4 +-
 README.md                                          |   1 +
 README_ZH.md                                       |   1 +
 client-cpp/README.md                               |  31 +++
 client-cpp/pom.xml                                 |  41 ++--
 client-cpp/src/assembly/client-cpp.xml             |  16 +-
 client-cpp/src/main/CMakeLists.txt                 |  23 ++-
 client-cpp/src/main/Session.cpp                    | 173 ++++++++++++++++-
 client-cpp/src/main/Session.h                      |  19 +-
 client-cpp/src/test/CMakeLists.txt                 |  40 +++-
 client-cpp/src/test/cpp/sessionIT.cpp              | 133 +++++++++++--
 cluster/pom.xml                                    |  14 ++
 .../FilePartitionedSnapshotLogManagerTest.java     |   1 +
 .../cluster/log/snapshot/PullSnapshotTaskTest.java |  20 +-
 .../apache/iotdb/cluster/query/BaseQueryTest.java  |   2 +
 .../query/ClusterPhysicalGeneratorTest.java        |   1 +
 .../cluster/query/ClusterPlanExecutorTest.java     |   1 +
 .../cluster/server/member/DataGroupMemberTest.java |   3 +
 .../cluster/server/member/MetaGroupMemberTest.java |   5 +-
 .../PlanExecutor.md => code-coverage/README.md     |   6 +-
 .../copy-code-coverage-sources.sh                  |  15 +-
 code-coverage/pom.xml                              | 132 +++++++++++++
 compile-tools/README.md                            |  85 ++++----
 compile-tools/boost/pom.xml                        | 145 --------------
 compile-tools/boost/src/assembly/bundle.xml        |  35 ----
 compile-tools/pom.xml                              |   7 +-
 compile-tools/thrift/pom.xml                       |  51 +----
 docs/Community/Feedback.md                         |   2 +
 docs/Community/Materials.md                        | 132 ++++++++++---
 docs/zh/Community/Feedback.md                      |   4 +-
 docs/zh/Community/Materials.md                     |  95 ---------
 .../client-cpp-example/README.md                   |  31 ++-
 {client-cpp => example}/client-cpp-example/pom.xml |  12 +-
 .../client-cpp-example/src/CMakeLists.txt          |  19 +-
 .../client-cpp-example/src/SessionExample.cpp      |   0
 .../apache/iotdb/kafka/KafkaConsumerThread.java    |   1 +
 example/udf/pom.xml                                |  48 +++--
 .../iotdb/web/grafana/dao/impl/BasicDaoImpl.java   |   1 +
 hadoop/pom.xml                                     |  47 +++--
 .../apache/iotdb/hadoop/fileSystem/HDFSOutput.java |   1 +
 hive-connector/pom.xml                             |  53 ++---
 jdbc/pom.xml                                       |  47 +++--
 .../main/java/org/apache/iotdb/jdbc/Activator.java |   2 +
 pom.xml                                            | 105 +++++++---
 server/pom.xml                                     |  14 ++
 .../iotdb/db/concurrent/WrappedRunnable.java       |   1 +
 .../db/engine/cache/TimeSeriesMetadataCache.java   |   1 +
 .../engine/compaction/utils/CompactionUtils.java   |   4 +-
 .../iotdb/db/engine/memtable/AbstractMemTable.java |   2 +
 .../db/engine/modification/ModificationFile.java   |   1 +
 .../engine/storagegroup/StorageGroupProcessor.java |  96 ++++-----
 .../org/apache/iotdb/db/metadata/MManager.java     |   2 +-
 .../org/apache/iotdb/db/metadata/PartialPath.java  |   1 +
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |  27 +--
 .../iotdb/db/metrics/source/MetricsSource.java     |  10 +
 .../iotdb/db/qp/physical/crud/LastQueryPlan.java   |   1 +
 .../apache/iotdb/db/qp/physical/sys/CountPlan.java |   1 +
 .../db/qp/physical/sys/ShowChildPathsPlan.java     |   1 +
 .../db/qp/physical/sys/ShowStorageGroupPlan.java   |   1 +
 .../db/query/dataset/AlignByDeviceDataSet.java     |   2 +
 .../iotdb/db/query/dataset/ShowDevicesDataSet.java |   1 +
 .../db/query/dataset/ShowTimeseriesDataSet.java    |   1 +
 .../query/reader/series/SeriesAggregateReader.java |   1 +
 .../apache/iotdb/db/query/udf/builtin/UDTFAbs.java |   1 +
 .../iotdb/db/query/udf/builtin/UDTFBottomK.java    |   1 +
 .../db/query/udf/builtin/UDTFCommonDerivative.java |   1 +
 .../udf/builtin/UDTFCommonValueDifference.java     |   1 +
 .../iotdb/db/query/udf/builtin/UDTFTopK.java       |   1 +
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  24 ++-
 .../db/tools/upgrade/TsFileOnlineUpgradeTool.java  |   1 +
 .../watermark/GroupedLSBWatermarkEncoder.java      |   6 +
 .../iotdb/db/utils/datastructure/BinaryTVList.java |   4 +
 .../db/utils/datastructure/BooleanTVList.java      |   4 +
 .../iotdb/db/utils/datastructure/DoubleTVList.java |   4 +
 .../iotdb/db/utils/datastructure/FloatTVList.java  |   4 +
 .../iotdb/db/utils/datastructure/IntTVList.java    |   4 +
 .../iotdb/db/utils/datastructure/LongTVList.java   |   4 +
 .../iotdb/db/utils/datastructure/TVList.java       |   1 +
 .../db/writelog/node/ExclusiveWriteLogNode.java    |   1 +
 .../IoTDBDefaultThreadExceptionHandlerTest.java    |   1 +
 .../db/engine/compaction/CompactionChunkTest.java  | 215 +++++++++++++++++++++
 .../engine/compaction/LevelCompactionLogTest.java  |   2 +
 .../compaction/LevelCompactionMergeTest.java       |   2 +
 .../compaction/LevelCompactionRecoverTest.java     |   2 +
 .../compaction/LevelCompactionSelectorTest.java    |   2 +
 .../LevelCompactionTsFileManagementTest.java       |   2 +
 .../NoCompactionTsFileManagementTest.java          |   2 +
 .../apache/iotdb/db/engine/merge/MergeLogTest.java |   3 +-
 .../iotdb/db/engine/merge/MergeOverLapTest.java    |   2 +
 .../iotdb/db/engine/merge/MergeTaskTest.java       |   3 +-
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  37 +++-
 .../org/apache/iotdb/db/metadata/MTreeTest.java    |  33 +++-
 .../ElasticSerializableRowRecordListTest.java      |   2 +
 .../ElasticSerializableTVListTest.java             |   2 +
 .../SerializableBinaryTVListTest.java              |   2 +
 .../SerializableBooleanTVListTest.java             |   2 +
 .../SerializableDoubleTVListTest.java              |   2 +
 .../datastructure/SerializableFloatTVListTest.java |   2 +
 .../datastructure/SerializableIntTVListTest.java   |   2 +
 .../datastructure/SerializableLongTVListTest.java  |   2 +
 .../SerializableRowRecordListTest.java             |   2 +
 .../db/sync/receiver/load/FileLoaderTest.java      |   3 -
 service-rpc/pom.xml                                |  20 --
 session/pom.xml                                    |  47 +++--
 .../iotdb/session/pool/SessionDataSetWrapper.java  |   1 +
 site/src/main/.vuepress/config.js                  |   2 +-
 thrift/pom.xml                                     |  20 --
 tsfile/pom.xml                                     |  47 +++--
 .../iotdb/tsfile/file/metadata/ChunkMetadata.java  |   1 +
 .../tsfile/file/metadata/TimeseriesMetadata.java   |   1 +
 .../fileInputFactory/HDFSInputFactory.java         |   1 +
 .../fileInputFactory/LocalFSInputFactory.java      |   1 +
 .../fileOutputFactory/LocalFSOutputFactory.java    |   1 +
 .../tsfile/fileSystem/fsFactory/HDFSFactory.java   |  11 ++
 .../fileSystem/fsFactory/LocalFSFactory.java       |  11 ++
 .../apache/iotdb/tsfile/read/ReadOnlyTsFile.java   |   1 +
 .../iotdb/tsfile/read/TsFileSequenceReader.java    |   1 +
 .../reader/series/AbstractFileSeriesReader.java    |   1 +
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |   1 +
 .../org/apache/iotdb/tsfile/compress/GZIPTest.java |  13 +-
 .../encoding/decoder/LongRleDecoderTest.java       |  17 +-
 .../regular/RegularDataEncoderIntegerTest.java     |   2 -
 .../regular/RegularDataEncoderLongTest.java        |   2 -
 .../read/query/executor/QueryExecutorTest.java     |  17 +-
 .../iotdb/tsfile/read/reader/PageReaderTest.java   |   5 -
 .../apache/iotdb/tsfile/utils/BytesUtilsTest.java  |  13 +-
 zeppelin-interpreter/pom.xml                       |  49 +++--
 132 files changed, 1868 insertions(+), 938 deletions(-)
 create mode 100644 .github/workflows/client.yml
 create mode 100644 .github/workflows/main-linux.yml
 create mode 100644 .github/workflows/main-mac.yml
 rename .github/workflows/{main-ci.yml => main-win.yml} (77%)
 delete mode 100644 .github/workflows/sonar_and_coverall.yml
 copy docs/zh/SystemDesign/QueryEngine/PlanExecutor.md => code-coverage/README.md (89%)
 copy test/e2e/cases/cli/cleanup.sh => code-coverage/copy-code-coverage-sources.sh (84%)
 mode change 100644 => 100755
 create mode 100644 code-coverage/pom.xml
 delete mode 100644 compile-tools/boost/pom.xml
 delete mode 100644 compile-tools/boost/src/assembly/bundle.xml
 delete mode 100644 docs/zh/Community/Materials.md
 copy docs/UserGuide/System Tools/MLogParser Tool.md => example/client-cpp-example/README.md (58%)
 rename {client-cpp => example}/client-cpp-example/pom.xml (95%)
 rename {client-cpp => example}/client-cpp-example/src/CMakeLists.txt (67%)
 rename {client-cpp => example}/client-cpp-example/src/SessionExample.cpp (100%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/CompactionChunkTest.java


[iotdb] 01/01: fix conflicts

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

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

commit 5a903251e5e241b50010129fb200199617d9757b
Merge: e8e7bf9 b793ada
Author: JackieTien97 <Ja...@foxmail.com>
AuthorDate: Thu Feb 4 17:23:06 2021 +0800

    fix conflicts

 .github/workflows/client.yml                       |  98 ++++++++++
 .github/workflows/main-linux.yml                   |  69 +++++++
 .github/workflows/main-mac.yml                     |  46 +++++
 .github/workflows/{main-ci.yml => main-win.yml}    |  69 +++----
 .github/workflows/sonar_and_coverall.yml           |  76 --------
 Jenkinsfile                                        |   4 +-
 README.md                                          |   1 +
 README_ZH.md                                       |   1 +
 client-cpp/README.md                               |  31 +++
 client-cpp/pom.xml                                 |  41 ++--
 client-cpp/src/assembly/client-cpp.xml             |  16 +-
 client-cpp/src/main/CMakeLists.txt                 |  23 ++-
 client-cpp/src/main/Session.cpp                    | 173 ++++++++++++++++-
 client-cpp/src/main/Session.h                      |  19 +-
 client-cpp/src/test/CMakeLists.txt                 |  40 +++-
 client-cpp/src/test/cpp/sessionIT.cpp              | 133 +++++++++++--
 cluster/pom.xml                                    |  14 ++
 .../FilePartitionedSnapshotLogManagerTest.java     |   1 +
 .../cluster/log/snapshot/PullSnapshotTaskTest.java |  20 +-
 .../apache/iotdb/cluster/query/BaseQueryTest.java  |   2 +
 .../query/ClusterPhysicalGeneratorTest.java        |   1 +
 .../cluster/query/ClusterPlanExecutorTest.java     |   1 +
 .../cluster/server/member/DataGroupMemberTest.java |   3 +
 .../cluster/server/member/MetaGroupMemberTest.java |   5 +-
 {client-cpp => code-coverage}/README.md            |  12 +-
 .../copy-code-coverage-sources.sh                  |  22 +--
 code-coverage/pom.xml                              | 132 +++++++++++++
 compile-tools/README.md                            |  85 ++++----
 compile-tools/boost/pom.xml                        | 145 --------------
 compile-tools/boost/src/assembly/bundle.xml        |  35 ----
 compile-tools/pom.xml                              |   7 +-
 compile-tools/thrift/pom.xml                       |  51 +----
 docs/Community/Feedback.md                         |   2 +
 docs/Community/Materials.md                        | 132 ++++++++++---
 docs/zh/Community/Feedback.md                      |   4 +-
 docs/zh/Community/Materials.md                     |  95 ---------
 .../client-cpp-example}/README.md                  |  28 ++-
 {client-cpp => example}/client-cpp-example/pom.xml |  12 +-
 .../client-cpp-example/src/CMakeLists.txt          |  19 +-
 .../client-cpp-example/src/SessionExample.cpp      |   0
 .../apache/iotdb/kafka/KafkaConsumerThread.java    |   1 +
 example/udf/pom.xml                                |  48 +++--
 .../iotdb/web/grafana/dao/impl/BasicDaoImpl.java   |   1 +
 hadoop/pom.xml                                     |  47 +++--
 .../apache/iotdb/hadoop/fileSystem/HDFSOutput.java |   1 +
 hive-connector/pom.xml                             |  53 ++---
 jdbc/pom.xml                                       |  47 +++--
 .../main/java/org/apache/iotdb/jdbc/Activator.java |   2 +
 pom.xml                                            | 105 +++++++---
 server/pom.xml                                     |  14 ++
 .../iotdb/db/concurrent/WrappedRunnable.java       |   1 +
 .../db/engine/cache/TimeSeriesMetadataCache.java   |   1 +
 .../engine/compaction/utils/CompactionUtils.java   |   4 +-
 .../iotdb/db/engine/memtable/AbstractMemTable.java |   2 +
 .../db/engine/modification/ModificationFile.java   |   1 +
 .../engine/storagegroup/StorageGroupProcessor.java |  96 ++++-----
 .../org/apache/iotdb/db/metadata/MManager.java     |   2 +-
 .../org/apache/iotdb/db/metadata/PartialPath.java  |   1 +
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |  27 +--
 .../iotdb/db/metrics/source/MetricsSource.java     |  10 +
 .../iotdb/db/qp/physical/crud/LastQueryPlan.java   |   1 +
 .../apache/iotdb/db/qp/physical/sys/CountPlan.java |   1 +
 .../db/qp/physical/sys/ShowChildPathsPlan.java     |   1 +
 .../db/qp/physical/sys/ShowStorageGroupPlan.java   |   1 +
 .../db/query/dataset/AlignByDeviceDataSet.java     |   2 +
 .../iotdb/db/query/dataset/ShowDevicesDataSet.java |   1 +
 .../db/query/dataset/ShowTimeseriesDataSet.java    |   1 +
 .../query/reader/series/SeriesAggregateReader.java |   1 +
 .../apache/iotdb/db/query/udf/builtin/UDTFAbs.java |   1 +
 .../iotdb/db/query/udf/builtin/UDTFBottomK.java    |   1 +
 .../db/query/udf/builtin/UDTFCommonDerivative.java |   1 +
 .../udf/builtin/UDTFCommonValueDifference.java     |   1 +
 .../iotdb/db/query/udf/builtin/UDTFTopK.java       |   1 +
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  24 ++-
 .../db/tools/upgrade/TsFileOnlineUpgradeTool.java  |   1 +
 .../watermark/GroupedLSBWatermarkEncoder.java      |   6 +
 .../iotdb/db/utils/datastructure/BinaryTVList.java |   4 +
 .../db/utils/datastructure/BooleanTVList.java      |   4 +
 .../iotdb/db/utils/datastructure/DoubleTVList.java |   4 +
 .../iotdb/db/utils/datastructure/FloatTVList.java  |   4 +
 .../iotdb/db/utils/datastructure/IntTVList.java    |   4 +
 .../iotdb/db/utils/datastructure/LongTVList.java   |   4 +
 .../iotdb/db/utils/datastructure/TVList.java       |   1 +
 .../db/writelog/node/ExclusiveWriteLogNode.java    |   1 +
 .../IoTDBDefaultThreadExceptionHandlerTest.java    |   1 +
 .../db/engine/compaction/CompactionChunkTest.java  | 215 +++++++++++++++++++++
 .../engine/compaction/LevelCompactionLogTest.java  |   2 +
 .../compaction/LevelCompactionMergeTest.java       |   2 +
 .../compaction/LevelCompactionRecoverTest.java     |   2 +
 .../compaction/LevelCompactionSelectorTest.java    |   2 +
 .../LevelCompactionTsFileManagementTest.java       |   2 +
 .../NoCompactionTsFileManagementTest.java          |   2 +
 .../apache/iotdb/db/engine/merge/MergeLogTest.java |   3 +-
 .../iotdb/db/engine/merge/MergeOverLapTest.java    |   2 +
 .../iotdb/db/engine/merge/MergeTaskTest.java       |   3 +-
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  37 +++-
 .../org/apache/iotdb/db/metadata/MTreeTest.java    |  33 +++-
 .../ElasticSerializableRowRecordListTest.java      |   2 +
 .../ElasticSerializableTVListTest.java             |   2 +
 .../SerializableBinaryTVListTest.java              |   2 +
 .../SerializableBooleanTVListTest.java             |   2 +
 .../SerializableDoubleTVListTest.java              |   2 +
 .../datastructure/SerializableFloatTVListTest.java |   2 +
 .../datastructure/SerializableIntTVListTest.java   |   2 +
 .../datastructure/SerializableLongTVListTest.java  |   2 +
 .../SerializableRowRecordListTest.java             |   2 +
 .../db/sync/receiver/load/FileLoaderTest.java      |   3 -
 service-rpc/pom.xml                                |  20 --
 session/pom.xml                                    |  47 +++--
 .../iotdb/session/pool/SessionDataSetWrapper.java  |   1 +
 site/src/main/.vuepress/config.js                  |   2 +-
 thrift/pom.xml                                     |  20 --
 tsfile/pom.xml                                     |  47 +++--
 .../iotdb/tsfile/file/metadata/ChunkMetadata.java  |   1 +
 .../tsfile/file/metadata/TimeseriesMetadata.java   |   1 +
 .../fileInputFactory/HDFSInputFactory.java         |   1 +
 .../fileInputFactory/LocalFSInputFactory.java      |   1 +
 .../fileOutputFactory/LocalFSOutputFactory.java    |   1 +
 .../tsfile/fileSystem/fsFactory/HDFSFactory.java   |  11 ++
 .../fileSystem/fsFactory/LocalFSFactory.java       |  11 ++
 .../apache/iotdb/tsfile/read/ReadOnlyTsFile.java   |   1 +
 .../iotdb/tsfile/read/TsFileSequenceReader.java    |   1 +
 .../reader/series/AbstractFileSeriesReader.java    |   1 +
 .../iotdb/tsfile/write/chunk/ChunkWriterImpl.java  |   1 +
 .../org/apache/iotdb/tsfile/compress/GZIPTest.java |  13 +-
 .../encoding/decoder/LongRleDecoderTest.java       |  17 +-
 .../regular/RegularDataEncoderIntegerTest.java     |   2 -
 .../regular/RegularDataEncoderLongTest.java        |   2 -
 .../read/query/executor/QueryExecutorTest.java     |  17 +-
 .../iotdb/tsfile/read/reader/PageReaderTest.java   |   5 -
 .../apache/iotdb/tsfile/utils/BytesUtilsTest.java  |  13 +-
 zeppelin-interpreter/pom.xml                       |  49 +++--
 132 files changed, 1871 insertions(+), 945 deletions(-)

diff --cc tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/ChunkWriterImpl.java
index 0b92c6f,f5bca68..d3afc3d
--- a/tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/ChunkWriterImpl.java
+++ b/tsfile/src/main/java/org/apache/iotdb/tsfile/write/chunk/ChunkWriterImpl.java
@@@ -351,8 -356,10 +351,9 @@@ public class ChunkWriterImpl implement
      if (pageWriter != null && pageWriter.getPointNumber() > 0) {
        writePageToPageBuffer();
      }
 -    chunkDataSize = pageBuffer.size();
    }
    
+   @Override
    public void clearPageWriter() {
      pageWriter = null;
    }