You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by xu...@apache.org on 2022/01/14 02:38:36 UTC

[iotdb] branch xkf_id_table_flush_time updated (ed80d2e -> ba35343)

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

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


    from ed80d2e  fix IT
     add 04622bb  [IOTDB-2346] Select INTO Reports NPE for time series containing binary values of NULL (#4767)
     add a2dba1b  [IOTDB-2347] Fix aligned timeseries auto create bug (#4770)
     add 50f171b  [IOTDB-2288] Modify serializing an empty page (#4723)
     add 058a07c  [IOTDB-2275] Don't compile grafana plugin when execute mvn clean package -pl distribution -am -DskipTests (#4779)
     add c528332  [IOTDB-2142][IOTDB-2281][IOTDB-2286][IOTDB-2258] fix csv bugs and add a parm to use aligned interface (#4762)
     add 16bfac1  [IOTDB-2257] Add consistency checks for measurement lists size and value lists size in the SELECT statement (#4739)
     add 262c5c6  [IOTDB-2349] An exception should be thrown when aggregate function and data type do not match (#4780)
     add e8810dd  [IOTDB-2235]Optimize the constructor of InsertRowsOfOneDevicePlan (#4781)
     add ebdf88f  [IOTDB-2278][IOTDB-2319] CQ doesn't work in master branch (#4788)
     add 73f80c6  [IOTDB-2332] Clause 'without null' is not supported in nested expressions (#4789)
     add cbc5d2e  [IOTDB-2352] Update Session docs for 0.13 (#4777)
     add a4f5b0e  [IOTDB-2280] Cache configuration order adjustment in iotdb-rest.properties (#4716)
     add e65f4c6  [IOTDB-2298] Refactor SQL of schema template (#4775)
     add 899f1c8  [IOTDB-2365] Reduce the iteration times when constrcuting page data (#4787)
     add 37bb7e2  [IOTDB-2205] Optimize unaligned int/long read/write functions in BytesUtils (#4676)
     add 2c1f895  update doc (#4795)
     add 47f4923  [IOTDB-2187] Update code of pulsar example with session API (#4793)
     add a198683  [IOTDB-2111] ServiceProvider: Support MQTT / REST protocols in cluster mode (#4580)
     add 5466c5f  [IOTDB-2354] row number is not as expected when using nested expressions in GROUP BY(#4790)
     add 3d4bd3d  [IOTDB-2356] TTL doesn't work (#4794)
     add bcdab51  [IOTDB-2325] Fix config manual which is different with system config (#4785)
     add 6445241  [IOTDB-2366] Change Executors.newXxx to IoTDBThreadPoolFactory.newXxx (#4791)
     add 21acded  [IOTDB-1360] Support aligned timeseries in in-space compaction (#4729)
     add e7f50b6  [IOTDB-2381] Fix deadlock caused by incorrect buffer pool size counter (#4797)
     add 39d19de  [IOTDB-2350] Select into datatype cast error when writing back during the nested query (#4801)
     add 84a3b01  Add Jprofiler link in Contribute guide (#4806)
     add 48e21f2  [IOTDB-2387] Suggest disabling time partition function by default (#4799)
     add 7fea9c8  [IOTDB-2385] Fix write degrade after limit chunk size in inner space compaction (#4798)
     add ab24ce0  [IOTDB-2337] Trigger: Perhaps trigger privileges are better based on paths (#4802)
     add 84a1df3  [IOTDB-2342] Add compatible interface with 0.12.x for creating template of flat measurements (#4720)
     add 8944470  [IOTDB-2320] MemoryLeak cause by wal Scheduled trim task thread (#4804)
     add 302e9b9  [IOTDB-2323] Fix remove lock file in syncClient error (#4803)
     add ba35343  Merge branch 'master' of https://github.com/apache/iotdb into xkf_id_table_flush_time

No new revisions were added by this update.

Summary of changes:
 .../org/apache/iotdb/db/qp/sql/IoTDBSqlParser.g4   |  18 +-
 .../main/java/org/apache/iotdb/tool/ImportCsv.java | 110 +++-
 .../org/apache/iotdb/cluster/ClusterIoTDB.java     |  19 +-
 .../iotdb/cluster/server/ClusterTSServiceImpl.java |  65 +--
 .../ClusterServiceProvider.java}                   |  35 +-
 .../cluster/utils/nodetool/ClusterMonitor.java     |   5 +-
 docs/Development/ContributeGuide.md                |   7 +-
 docs/UserGuide/API/Programming-Java-Native-API.md  | 611 ++++++++++-----------
 .../Administration-Management/Administration.md    |   8 +-
 docs/UserGuide/Advanced-Features/Triggers.md       |   8 +-
 docs/UserGuide/Appendix/Config-Manual.md           |  29 +-
 docs/UserGuide/Appendix/SQL-Reference.md           |  10 +-
 .../Data-Concept/Data-Model-and-Terminology.md     |  19 +-
 docs/UserGuide/Data-Concept/Data-Type.md           |  10 +-
 docs/UserGuide/Data-Concept/Time-Partition.md      |   4 +-
 .../DDL-Data-Definition-Language.md                |   4 +-
 .../DML-Data-Manipulation-Language.md              |  14 +-
 docs/UserGuide/System-Tools/CSV-Tool.md            |  10 +-
 .../UserGuide/API/Programming-Java-Native-API.md   | 404 ++++++++------
 .../Administration-Management/Administration.md    |   8 +-
 docs/zh/UserGuide/Advanced-Features/Triggers.md    |   8 +-
 docs/zh/UserGuide/Appendix/Config-Manual.md        | 137 ++---
 docs/zh/UserGuide/Appendix/SQL-Reference.md        |  18 +-
 .../Data-Concept/Data-Model-and-Terminology.md     |  35 +-
 docs/zh/UserGuide/Data-Concept/Data-Type.md        |  10 +-
 docs/zh/UserGuide/Data-Concept/Time-Partition.md   |   4 +-
 .../Ecosystem Integration/Grafana Plugin.md        |   4 +-
 .../DDL-Data-Definition-Language.md                |  22 +-
 .../DML-Data-Manipulation-Language.md              |  12 +-
 docs/zh/UserGuide/System-Tools/CSV-Tool.md         |  14 +-
 example/pulsar/pom.xml                             |   5 +
 .../java/org/apache/iotdb/pulsar/Constant.java     |  38 +-
 .../org/apache/iotdb/pulsar/PulsarConsumer.java    |  69 +--
 .../apache/iotdb/pulsar/PulsarConsumerThread.java  |  72 ++-
 .../org/apache/iotdb/pulsar/PulsarProducer.java    |  38 +-
 grafana-plugin/pom.xml                             | 125 +++--
 .../iotdb/influxdb/session/InfluxDBSession.java    |   8 +-
 .../apache/iotdb/db/integration/IOTDBInsertIT.java |  33 +-
 .../IoTDBAlignedTimeSeriesCompactionIT.java        | 486 ++++++++++++++++
 .../{auth => }/IoTDBAuthorizationIT.java           |  96 +++-
 .../db/integration/IoTDBContinuousQueryIT.java     | 118 +---
 .../db/integration/IoTDBQueryMemoryControlIT.java  |  20 +-
 .../db/integration/IoTDBSchemaTemplateIT.java      |  52 +-
 .../iotdb/db/integration/IoTDBSelectIntoIT.java    |  41 +-
 .../aggregation/IoTDBAggregationIT.java            |  21 +-
 .../aggregation/IoTDBAggregationLargeDataIT.java   |  40 +-
 .../aggregation/IoTDBAggregationSmallDataIT.java   |  33 +-
 .../aggregation/IoTDBUDFNestAggregationIT.java     | 226 ++++++++
 .../IoTDBUserDefinedAggregationFunctionIT.java     |  21 +-
 .../aligned/IOTDBInsertAlignedValuesIT.java        | 115 ++++
 pom.xml                                            |   2 +
 .../resources/conf/iotdb-engine.properties         |  21 +-
 .../assembly/resources/conf/iotdb-rest.properties  |  18 +-
 .../org/apache/iotdb/db/auth/AuthorityChecker.java |   2 +-
 .../apache/iotdb/db/auth/entity/PrivilegeType.java |   3 +-
 .../org/apache/iotdb/db/concurrent/ThreadName.java |   8 +
 .../java/org/apache/iotdb/db/conf/IoTDBConfig.java |   4 +-
 .../apache/iotdb/db/cq/ContinuousQueryService.java |  13 +-
 .../apache/iotdb/db/cq/ContinuousQueryTask.java    | 144 +++--
 .../org/apache/iotdb/db/engine/StorageEngine.java  |  26 +-
 .../inner/sizetiered/SizeTieredCompactionTask.java |   3 +-
 .../utils/AlignedSeriesCompactionExecutor.java     | 152 +++++
 .../inner/utils/InnerSpaceCompactionUtils.java     |  83 +--
 .../inner/utils/MultiTsFileDeviceIterator.java     | 166 +++++-
 .../selectinto/InsertTabletPlanGenerator.java      |   8 +-
 .../db/engine/storagegroup/TsFileResource.java     |   8 +-
 .../storagegroup/VirtualStorageGroupProcessor.java |  50 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  35 +-
 .../iotdb/db/metadata/template/Template.java       |  10 +-
 .../iotdb/db/protocol/influxdb/dto/IoTDBPoint.java |   4 +-
 .../{MetaManager.java => InfluxDBMetaManager.java} |  43 +-
 .../iotdb/db/protocol/mqtt/PublishHandler.java     |  24 +-
 .../rest/handler/AuthorizationHandler.java         |  16 +-
 .../protocol/rest/impl/GrafanaApiServiceImpl.java  |  25 +-
 .../db/protocol/rest/impl/RestApiServiceImpl.java  |  29 +-
 .../main/java/org/apache/iotdb/db/qp/Planner.java  |  11 -
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  |   2 +-
 .../qp/logical/crud/AggregationQueryOperator.java  |  47 +-
 .../iotdb/db/qp/logical/crud/InsertOperator.java   |  48 +-
 .../iotdb/db/qp/logical/crud/SelectComponent.java  |   6 +
 .../logical/sys/CreateContinuousQueryOperator.java |  30 +-
 .../db/qp/logical/sys/CreateTemplateOperator.java  |  16 +-
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |   4 +
 .../physical/crud/InsertRowsOfOneDevicePlan.java   |  18 +-
 .../qp/physical/sys/CreateContinuousQueryPlan.java |  58 +-
 .../db/qp/physical/sys/CreateTriggerPlan.java      |   5 +
 .../iotdb/db/qp/physical/sys/DropTriggerPlan.java  |  27 +
 .../iotdb/db/qp/physical/sys/StartTriggerPlan.java |  27 +
 .../iotdb/db/qp/physical/sys/StopTriggerPlan.java  |  27 +
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    | 100 ++--
 .../db/query/control/SessionTimeoutManager.java    |   6 +-
 .../db/query/dataset/UDTFAlignByTimeDataSet.java   |  28 +-
 .../iotdb/db/query/executor/QueryRouter.java       |   5 +-
 .../db/query/udf/core/layer/InputRowUtils.java     |  19 +
 .../query/udf/core/layer/RawQueryInputLayer.java   |  11 +-
 .../row/ElasticSerializableRowRecordList.java      |  16 +-
 .../java/org/apache/iotdb/db/service/IoTDB.java    |  52 +-
 .../org/apache/iotdb/db/service/SettleService.java |   7 +-
 ...icServiceProvider.java => ServiceProvider.java} | 104 ++--
 .../service/basic/StandaloneServiceProvider.java   |  55 ++
 .../service/thrift/impl/InfluxDBServiceImpl.java   |  37 +-
 .../db/service/thrift/impl/TSServiceImpl.java      | 252 +++++----
 .../iotdb/db/sync/sender/transfer/SyncClient.java  |   2 +
 .../java/org/apache/iotdb/db/utils/AuthUtils.java  |   4 +
 .../compaction/TestUtilsForAlignedSeries.java      | 228 ++++++++
 .../compaction/inner/InnerSeqCompactionTest.java   |   9 +-
 .../inner/InnerSpaceCompactionExceptionTest.java   |  14 +-
 .../InnerSpaceCompactionUtilsAlignedTest.java      | 532 ++++++++++++++++++
 .../InnerSpaceCompactionUtilsNoAlignedTest.java    |  55 +-
 .../inner/InnerSpaceCompactionUtilsOldTest.java    |   2 +-
 .../compaction/inner/InnerUnseqCompactionTest.java |   3 +-
 .../SizeTieredCompactionRecoverTest.java           |  34 +-
 .../recover/SizeTieredCompactionRecoverTest.java   |  16 +-
 .../compaction/utils/CompactionCheckerUtils.java   |  32 +-
 .../iotdb/db/metadata/MManagerBasicTest.java       |  45 ++
 .../ElasticSerializableRowRecordListTest.java      |  20 +-
 server/src/test/resources/iotdb-rest.properties    |  18 +-
 .../main/java/org/apache/iotdb/rpc/RpcUtils.java   |   1 -
 .../iotdb/rpc/StatementExecutionException.java     |   1 -
 .../java/org/apache/iotdb/session/Session.java     | 160 ++++--
 .../org/apache/iotdb/session/pool/SessionPool.java |  82 +++
 .../java/org/apache/iotdb/session/SessionTest.java | 122 +++-
 .../apache/iotdb/session/template/TemplateUT.java  |  27 +-
 session/src/test/resources/iotdb-rest.properties   |  18 +-
 .../encoding/encoder/DeltaBinaryEncoder.java       |  10 +-
 .../tsfile/file/metadata/enums/TSDataType.java     |  18 +
 .../read/TsFileAlignedSeriesReaderIterator.java    |  79 +++
 .../iotdb/tsfile/read/TsFileSequenceReader.java    |  34 +-
 .../tsfile/read/reader/page/AlignedPageReader.java |  40 +-
 .../tsfile/read/reader/page/TimePageReader.java    |  12 +-
 .../tsfile/read/reader/page/ValuePageReader.java   |  53 +-
 .../org/apache/iotdb/tsfile/utils/BytesUtils.java  | 127 +++--
 .../tsfile/write/chunk/AlignedChunkWriterImpl.java |  33 ++
 .../iotdb/tsfile/write/chunk/ValueChunkWriter.java |   7 +-
 .../iotdb/tsfile/write/page/ValuePageWriter.java   |   3 +
 .../apache/iotdb/tsfile/write/record/Tablet.java   |   2 +-
 .../iotdb/tsfile/write/writer/TsFileIOWriter.java  |  18 +-
 137 files changed, 5058 insertions(+), 2037 deletions(-)
 copy cluster/src/main/java/org/apache/iotdb/cluster/server/{ClusterTSServiceImpl.java => basic/ClusterServiceProvider.java} (78%)
 create mode 100644 integration/src/test/java/org/apache/iotdb/db/integration/IoTDBAlignedTimeSeriesCompactionIT.java
 rename integration/src/test/java/org/apache/iotdb/db/integration/{auth => }/IoTDBAuthorizationIT.java (93%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/engine/compaction/inner/utils/AlignedSeriesCompactionExecutor.java
 rename server/src/main/java/org/apache/iotdb/db/protocol/influxdb/meta/{MetaManager.java => InfluxDBMetaManager.java} (88%)
 rename server/src/main/java/org/apache/iotdb/db/service/basic/{BasicServiceProvider.java => ServiceProvider.java} (74%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/service/basic/StandaloneServiceProvider.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/TestUtilsForAlignedSeries.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/inner/InnerSpaceCompactionUtilsAlignedTest.java
 create mode 100644 tsfile/src/main/java/org/apache/iotdb/tsfile/read/TsFileAlignedSeriesReaderIterator.java