You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by ej...@apache.org on 2021/01/05 07:05:51 UTC

[iotdb] branch sliding_mem_table updated (42614f0 -> fa77020)

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

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


    from 42614f0  finish wal lock
     add 69dbcfa  update download links (#2249)
     add ca24aaf  fix error in site/config.js.
     add 5a1ba81  [IoTDB-1051] Fix duplicate declaration of plugin :maven-assembly-plugin in hadoop/pom.xml
     add 61db87b  fix start-node script
     add c8bc153  fix
     add d7e291c  Merge pull request #2223 from LebronAl/cluster_fix_auto_create_schema_bug
     add 9e2a8f7  fix
     add 2455b69  Merge pull request #2252 from LebronAl/cluster_dispatcher_build_request_optimize
     add 2bd067b  [To rel/0.11] Remove unnecessary dependency of com.clearspring.analytics:stream and fastutil (#2254) (#2255)
     add f2e7413  getObject should not return String for all data types (#2247)
     add 9431e53  [IOTDB-1050] Fix Count timeserise column name is wrong (#2238)
     add 0288b76  Eliminate boost build logs to avoid exceeding maximum log length
     add bc02a56  disable travis for cpp module
     add 3c266e0  enable deploying the website automatically
     add a98eca4  fix tools declaration in Jenkinsfile
     add 6a5e527  [IOTDB-507] Add zeppelin-interpreter module  (#2096)
     add 316f30d  fix doc error
     add c666c3a  Merge pull request #2260 from neuyilan/apache_master_1213_fix_docs
     add 6787a2e  Avoid overflow by converting to long (#2209)
     add bf11ac5  [IOTDB-1054] Remove unsupported compress type like GZIP, LZO etc (#2262)
     add c8cf5c9  [IOTDB-1053] Optimize enum `CompressionType` (#2261)
     add 6a68db0  Fix the risk of deadlock by WeakReference (#1968)
     add da02c71  [IOTDB-825] aggregation by natural month (#2029)
     add a75b722  [IOTDB-868] change mlog from txt to bin (#1721)
     add 8da5cdf  change null pointer log way (#2266)
     add 3812910  Move memtable plan index from ChunkGroupFooter to a separate marker (#2263)
     add 087a2a2  fix SDT chinese doc (#2269)
     add a712b52  Add compaction test (#2220)
     add fd68ec5  using sonar secret token
     add f563161  fix fileNotException
     add 8252ed8  revert fix fileNotException
     add 12abbe9  fix file not found when restart and reader for txt mlog (#2272)
     add c7f6bea  [IOTDB-1057] Remove Data type ALL in create time series sentence (#2268)
     add eef210c  [IOTDB-1060] Support full deletion for delete statement without where clause (#2276)
     add 07a7689  Arrange query test (#2245)
     add b85ddfc  Fix Last query output when last value does not exist in a series (#2275)
     add 39e68b2  Fix hive-connector CI (#2279)
     add 491c17f  fix TsFile doc (#2282)
     add f77b851  Add Unit tests for Utils module (#2246)
     add e97d532  add auth test UT (#2271)
     add 413fe1b  Fix the path of seed_nodes configuration (#2206)
     add 113bd38  add new committer HouliangQi (#2286)
     add 35fb6c0  change parallelism in timeseries metadata cache (#2289)
     add 758c450  Fixed a section number in the sync tool document (#2296)
     add 923cf57  add new committer Xinyu Tan (#2297)
     add ebe335c  Remove extra commas to make the param annotation take effect (#2295)
     add b30cec2  fix some doc grammar issues in the cluster module  (#2287)
     add 59e9b9c  add missing information of javadoc in cluster module (#2285)
     add b75ceb0  Revert "using sonar secret token" (#2298)
     add 2bdae11  Fix dependency bug and add documents (#2299)
     add 2c88609  [IOTDB-1066] Code improvement (#2300)
     add eed2a4a  fix ArithmeticException (#2284)
     add 740e7c9  fix client is null caluse NullException
     add f51b7bf  remend the async client pool comment
     add 2acfd66  Merge pull request #2277 from neuyilan/apache_master_1217_fix_client_is_null
     add 5d91586  add SDT docs (#2307)
     add becbd87  upgrade guava version (#2303)
     add bb40b81  fix a bug of cal MaxDeduplicatedPathNum (#2310)
     add 5fb992f  Fix sync schema bug (#2309)
     add 1ee1dd5  Update PartialPathTest.java (#2274)
     add 1981766  remove useless coeds
     add 852fbb9  Merge pull request #2302 from neuyilan/apache_master_1222_remove_useless_code
     add 537aebf  [IOTDB-944] Support UDTF (User-defined Timeseries Generating Function) (#1828)
     add ac8c887  Update TsFileIOWriter.java (#2320)
     add 21d356c  Fix documents that are not linked to official websites (#2324)
     add 92e26fb  fix incorrect MetadataException printf info. (#2323)
     add b4f41ba  Remove a useless comma in the usage info of cluster (#2328)
     add d76076d  refactor the code
     add 095803c  Merge pull request #2339 from neuyilan/apache_master_1225_refactor_the_code
     add 63c2aad  fix wal buffer annotation (#2311)
     add ec88e69  Bump maven wrapper from 3.6.1 to 3.6.3
     add 231b334  Remove extra bracket to make the param annotation take effect
     add 69de3d6  1. add pr template; 2. disable enforcer check in travis; 3. test sonar token
     add 0b25cba  supply the cluster version status code (#2342)
     add 258d4ce  Fix a potential overflow in udf (#2345)
     add a3ea467  Fix the default value of operation timeout (#2330)
     add a898e72  Delete update operation (#2288)
     add 3496136  fix
     add 346da56  fix fix
     add 10ae899  Merge pull request #2362 from LebronAl/fix_serialToParallelPool_init_bug
     add 3e24aef  [IOTDB-1086] Improve document of Zeppelin installation (#2354)
     add 8ffc98d  [IOTDB-1090] Unable to update UDF (#2361)
     add 7c2628e  [IOTDB-1065] Fix deletion bug while trying to delete data from a timeseries which contains comma (#2306)
     add 83e2722  fix some typo &  make code more understandable (#2360)
     add a71204e  fix concurrent bug of mlogWriter (#2335)
     add fa77020  merge master

No new revisions were added by this update.

Summary of changes:
 .github/pull_request_template.md                   |   93 ++
 .github/workflows/sonar_and_coverall.yml           |    2 +-
 .mvn/wrapper/maven-wrapper.properties              |    2 +-
 .travis.yml                                        |   10 +-
 Jenkinsfile                                        |   29 +-
 LICENSE-binary                                     |    2 -
 .../antlr4/org/apache/iotdb/db/qp/sql/SqlBase.g4   |   64 +-
 .../java/org/apache/iotdb/cli/AbstractCli.java     |  110 +-
 cli/src/main/java/org/apache/iotdb/cli/Cli.java    |    5 +-
 cli/src/main/java/org/apache/iotdb/cli/WinCli.java |    5 +-
 .../main/java/org/apache/iotdb/tool/ExportCsv.java |    4 +-
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |   35 +-
 cluster/src/assembly/resources/sbin/add-node.bat   |    6 +-
 cluster/src/assembly/resources/sbin/add-node.sh    |    6 +-
 cluster/src/assembly/resources/sbin/start-node.bat |    8 +-
 cluster/src/assembly/resources/sbin/start-node.sh  |    6 +-
 .../java/org/apache/iotdb/cluster/ClusterMain.java |    8 +-
 .../iotdb/cluster/client/DataClientProvider.java   |   17 +-
 .../cluster/client/async/AsyncClientPool.java      |   12 +-
 .../iotdb/cluster/client/sync/SyncClientPool.java  |   21 +-
 .../apache/iotdb/cluster/config/ClusterConfig.java |    4 +-
 .../apache/iotdb/cluster/log/LogDispatcher.java    |    4 +-
 .../cluster/log/applier/AsyncDataLogApplier.java   |    4 +-
 .../apache/iotdb/cluster/metadata/CMManager.java   |   25 +-
 .../cluster/partition/slot/SlotPartitionTable.java |    4 +-
 .../cluster/query/ClusterConcatPathOptimizer.java  |    4 +-
 .../iotdb/cluster/query/ClusterPlanExecutor.java   |   10 +-
 .../iotdb/cluster/query/ClusterPlanRouter.java     |    9 -
 .../iotdb/cluster/query/LocalQueryExecutor.java    |    2 +-
 .../cluster/query/fill/ClusterPreviousFill.java    |   11 +-
 .../iotdb/cluster/query/reader/DataSourceInfo.java |    2 +-
 .../apache/iotdb/cluster/server/ClientServer.java  |    2 +-
 .../cluster/server/member/MetaGroupMember.java     |   18 +-
 .../iotdb/cluster/server/member/RaftMember.java    |   10 +-
 .../cluster/server/service/BaseSyncService.java    |    7 +-
 .../apache/iotdb/cluster/utils/ClusterUtils.java   |    4 +-
 .../cluster/client/DataClientProviderTest.java     |   12 +-
 .../org/apache/iotdb/cluster/common/IoTDBTest.java |    2 +-
 .../cluster/log/applier/DataLogApplierTest.java    |    4 +-
 .../cluster/partition/SlotPartitionTableTest.java  |   14 -
 .../query/ClusterPhysicalGeneratorTest.java        |   10 +-
 .../cluster/query/ClusterPlanExecutorTest.java     |    4 +-
 compile-tools/boost/pom.xml                        |    4 +
 docs/Download/README.md                            |   16 +-
 docs/SystemDesign/SchemaManager/SchemaManager.md   |   20 +-
 docs/SystemDesign/TsFile/Format.md                 |    4 +-
 docs/UserGuide/Client/Status Codes.md              |    8 +
 docs/UserGuide/Concept/SDT.md                      |   63 ++
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  187 ++++
 .../DML Data Manipulation Language.md              |  100 +-
 docs/UserGuide/Operation Manual/SQL Reference.md   |    7 +-
 .../Operation Manual/UDF User Defined Function.md  |  423 +++++++
 docs/UserGuide/Server/Cluster Setup.md             |   12 +-
 docs/UserGuide/Server/ServerFileList.md            |    1 -
 .../UserGuide/System Tools/MLogParser Tool.md      |   21 +-
 docs/UserGuide/System Tools/Sync Tool.md           |    2 +-
 docs/zh/Download/README.md                         |   16 +-
 .../zh/SystemDesign/SchemaManager/SchemaManager.md |   20 +-
 docs/zh/SystemDesign/StorageEngine/Compaction.md   |   10 +-
 docs/zh/SystemDesign/TsFile/Format.md              |    4 +-
 docs/zh/UserGuide/Client/Status Codes.md           |    9 +-
 docs/zh/UserGuide/Concept/SDT.md                   |   83 +-
 .../Ecosystem Integration/Zeppelin-IoTDB.md        |  189 ++++
 .../DML Data Manipulation Language.md              |  103 +-
 .../zh/UserGuide/Operation Manual/SQL Reference.md |    7 +-
 .../Operation Manual/UDF User Defined Function.md  |  423 +++++++
 docs/zh/UserGuide/Server/Cluster Setup.md          |   16 +-
 docs/zh/UserGuide/Server/ServerFileList.md         |    1 -
 .../zh/UserGuide/System Tools/MLogParser Tool.md   |   21 +-
 docs/zh/UserGuide/System Tools/Sync Tool.md        |    2 +-
 example/pom.xml                                    |    1 +
 example/udf/pom.xml                                |   82 ++
 .../java/org/apache/iotdb/udf/UDTFExample.java     |   56 +
 hadoop/pom.xml                                     |   22 +-
 hive-connector/pom.xml                             |    8 +-
 pom.xml                                            |   12 +-
 server/file-changelists/mlog-changelist.md         |    4 +
 server/pom.xml                                     |    5 -
 .../resources/conf/iotdb-engine.properties         |   31 +-
 .../assembly/resources/tools/mlog/mLogParser.bat   |   62 +-
 .../assembly/resources/tools/mlog/mLogParser.sh    |   40 +-
 .../org/apache/iotdb/db/auth/AuthException.java    |    5 -
 .../org/apache/iotdb/db/auth/AuthorityChecker.java |   15 +-
 .../iotdb/db/auth/authorizer/BasicAuthorizer.java  |    2 +-
 .../db/auth/authorizer/LocalFileAuthorizer.java    |    2 +-
 .../iotdb/db/auth/authorizer/OpenIdAuthorizer.java |   10 +-
 .../apache/iotdb/db/auth/entity/PathPrivilege.java |    4 +-
 .../apache/iotdb/db/auth/entity/PrivilegeType.java |    2 +-
 .../java/org/apache/iotdb/db/conf/IoTDBConfig.java |  123 +-
 .../org/apache/iotdb/db/conf/IoTDBConfigCheck.java |   35 +-
 .../org/apache/iotdb/db/conf/IoTDBConstant.java    |    5 +
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  |   49 +
 .../db/engine/cache/TimeSeriesMetadataCache.java   |   10 +-
 .../level/LevelCompactionTsFileManagement.java     |  152 +--
 .../no/NoCompactionTsFileManagement.java           |   10 +-
 .../compaction/utils/CompactionLogAnalyzer.java    |   19 +-
 .../engine/compaction/utils/CompactionLogger.java  |   16 +-
 .../engine/compaction/utils/CompactionUtils.java   |   84 +-
 .../iotdb/db/engine/flush/MemTableFlushTask.java   |    1 +
 .../iotdb/db/engine/memtable/AbstractMemTable.java |    4 +-
 .../io/LocalTextModificationAccessor.java          |   61 +-
 .../engine/storagegroup/StorageGroupProcessor.java |    5 +-
 .../db/engine/storagegroup/TsFileResource.java     |   14 +-
 .../UDFRegistrationException.java}                 |   72 +-
 .../{MLogWriter.java => MLogTxtWriter.java}        |   72 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  236 ++--
 .../java/org/apache/iotdb/db/metadata/MTree.java   |  127 ++-
 .../apache/iotdb/db/metadata/MetadataConstant.java |   10 +-
 .../iotdb/db/metadata/logfile/MLogReader.java      |   74 ++
 .../iotdb/db/metadata/logfile/MLogTxtReader.java   |   79 ++
 .../iotdb/db/metadata/logfile/MLogWriter.java      |  454 ++++++++
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |   25 +-
 .../iotdb/db/metadata/mnode/MeasurementMNode.java  |   37 +-
 .../iotdb/db/metadata/mnode/StorageGroupMNode.java |   22 +-
 .../main/java/org/apache/iotdb/db/qp/Planner.java  |    9 +-
 .../apache/iotdb/db/qp/constant/DatetimeUtils.java |   40 +
 .../apache/iotdb/db/qp/constant/SQLConstant.java   |   14 +-
 .../apache/iotdb/db/qp/executor/IPlanExecutor.java |   11 +-
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  |   72 +-
 .../org/apache/iotdb/db/qp/logical/Operator.java   |    8 +-
 .../iotdb/db/qp/logical/crud/QueryOperator.java    |   18 +
 .../iotdb/db/qp/logical/crud/SFWOperator.java      |   16 +-
 .../iotdb/db/qp/logical/crud/SelectOperator.java   |   47 +-
 .../CreateFunctionOperator.java}                   |   99 +-
 .../DropFunctionOperator.java}                     |   81 +-
 .../ShowFunctionsOperator.java}                    |   78 +-
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |   28 +-
 .../iotdb/db/qp/physical/crud/GroupByTimePlan.java |   19 +
 .../iotdb/db/qp/physical/crud/QueryPlan.java       |    2 +-
 .../apache/iotdb/db/qp/physical/crud/UDFPlan.java  |   52 +
 .../apache/iotdb/db/qp/physical/crud/UDTFPlan.java |  133 +++
 .../iotdb/db/qp/physical/crud/UpdatePlan.java      |  135 ---
 ...tStorageGroupPlan.java => ChangeAliasPlan.java} |   74 +-
 ...rageGroupPlan.java => ChangeTagOffsetPlan.java} |   76 +-
 .../sys/{ShowPlan.java => CreateFunctionPlan.java} |  114 +-
 .../qp/physical/sys/CreateMultiTimeSeriesPlan.java |    4 +-
 .../db/qp/physical/sys/CreateTimeSeriesPlan.java   |   66 +-
 .../db/qp/physical/sys/DeleteTimeSeriesPlan.java   |    4 +
 .../iotdb/db/qp/physical/sys/DropFunctionPlan.java |   81 +-
 .../{SetStorageGroupPlan.java => MNodePlan.java}   |   88 +-
 .../db/qp/physical/sys/MeasurementMNodePlan.java   |  143 +++
 .../db/qp/physical/sys/SetStorageGroupPlan.java    |   18 +-
 .../iotdb/db/qp/physical/sys/SetTTLPlan.java       |    1 -
 .../sys/ShowFunctionsPlan.java}                    |   75 +-
 .../apache/iotdb/db/qp/physical/sys/ShowPlan.java  |    6 +-
 ...geGroupPlan.java => StorageGroupMNodePlan.java} |   79 +-
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    |  168 ++-
 .../iotdb/db/qp/strategy/LogicalGenerator.java     |    7 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |  132 ++-
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |  192 +++-
 .../db/query/aggregation/AggregateResult.java      |    2 +-
 .../db/query/aggregation/AggregationType.java      |    1 -
 .../db/query/control/QueryResourceManager.java     |    8 +-
 .../iotdb/db/query/control/TracingManager.java     |    2 +-
 .../db/query/dataset/AlignByDeviceDataSet.java     |    4 +-
 .../dataset/DirectAlignByTimeDataSet.java}         |   74 +-
 .../dataset/DirectNonAlignDataSet.java}            |   72 +-
 .../apache/iotdb/db/query/dataset/ListDataSet.java |    4 +-
 .../db/query/dataset/NonAlignEngineDataSet.java    |   28 +-
 .../dataset/RawQueryDataSetWithValueFilter.java    |    4 +-
 .../dataset/RawQueryDataSetWithoutValueFilter.java |   24 +-
 .../db/query/dataset/ShowTimeseriesDataSet.java    |   11 +-
 .../db/query/dataset/UDTFAlignByTimeDataSet.java   |  277 +++++
 .../apache/iotdb/db/query/dataset/UDTFDataSet.java |  152 +++
 .../db/query/dataset/UDTFNonAlignDataSet.java      |  191 ++++
 .../dataset/groupby/GroupByEngineDataSet.java      |   74 +-
 .../query/dataset/groupby/GroupByFillDataSet.java  |    4 +-
 .../query/dataset/groupby/GroupByTimeDataSet.java  |    4 +-
 .../groupby/GroupByWithValueFilterDataSet.java     |    2 +-
 .../groupby/GroupByWithoutValueFilterDataSet.java  |    2 +-
 .../iotdb/db/query/executor/IQueryRouter.java      |    8 +-
 .../iotdb/db/query/executor/LastQueryExecutor.java |   18 +-
 .../iotdb/db/query/executor/QueryRouter.java       |   51 +-
 .../db/query/executor/RawDataQueryExecutor.java    |   22 +-
 .../iotdb/db/query/executor/UDTFQueryExecutor.java |   84 ++
 .../UpdateOperator.java => query/udf/api/UDF.java} |   70 +-
 .../org/apache/iotdb/db/query/udf/api/UDTF.java    |  101 ++
 .../apache/iotdb/db/query/udf/api/access/Row.java  |  119 ++
 .../iotdb/db/query/udf/api/access/RowIterator.java |   89 +-
 .../iotdb/db/query/udf/api/access/RowWindow.java   |   61 +
 .../db/query/udf/api/collector/PointCollector.java |  137 +++
 .../api/customizer/config/UDFConfigurations.java}  |   79 +-
 .../api/customizer/config/UDTFConfigurations.java  |  104 ++
 .../api/customizer/parameter/UDFParameters.java    |  119 ++
 .../api/customizer/strategy/AccessStrategy.java    |   64 ++
 .../strategy/RowByRowAccessStrategy.java           |   61 +
 .../strategy/SlidingSizeWindowAccessStrategy.java  |  123 ++
 .../strategy/SlidingTimeWindowAccessStrategy.java  |  249 +++++
 .../iotdb/db/query/udf/core/access/RowImpl.java    |   93 ++
 .../db/query/udf/core/access/RowIteratorImpl.java  |   58 +
 .../db/query/udf/core/access/RowWindowImpl.java    |   75 ++
 .../db/query/udf/core/context/UDFContext.java      |  134 +++
 .../db/query/udf/core/executor/UDTFExecutor.java   |   92 ++
 .../iotdb/db/query/udf/core/input/InputLayer.java  |  563 ++++++++++
 .../iotdb/db/query/udf/core/input/SafetyLine.java  |   60 +
 .../db/query/udf/core/reader/LayerPointReader.java |   88 +-
 .../udf/core/reader/LayerRowReader.java}           |   79 +-
 .../udf/core/reader/LayerRowWindowReader.java      |   76 +-
 .../core/transformer/RawQueryPointTransformer.java |   72 ++
 .../db/query/udf/core/transformer/Transformer.java |   93 ++
 .../core/transformer/UDFQueryRowTransformer.java   |   85 +-
 .../transformer/UDFQueryRowWindowTransformer.java  |   46 +
 .../udf/core/transformer/UDFQueryTransformer.java  |   89 ++
 .../query/udf/datastructure/SerializableList.java  |  165 +++
 .../primitive/ElasticSerializableIntList.java      |  109 ++
 .../udf/datastructure/primitive/IntList.java}      |   74 +-
 .../primitive/SerializableIntList.java             |  131 +++
 .../datastructure/primitive/WrappedIntArray.java   |   90 +-
 .../row/ElasticSerializableRowRecordList.java      |  234 ++++
 .../row/SerializableRowRecordList.java             |  245 ++++
 .../tv/ElasticSerializableBinaryTVList.java        |  121 ++
 .../tv/ElasticSerializableTVList.java              |  312 ++++++
 .../datastructure/tv/SerializableBinaryTVList.java |   79 ++
 .../tv/SerializableBooleanTVList.java              |   69 ++
 .../datastructure/tv/SerializableDoubleTVList.java |   69 ++
 .../datastructure/tv/SerializableFloatTVList.java  |   69 ++
 .../datastructure/tv/SerializableIntTVList.java    |   69 ++
 .../datastructure/tv/SerializableLongTVList.java   |   69 ++
 .../udf/datastructure/tv/SerializableTVList.java   |   99 ++
 .../udf/service/TemporaryQueryDataFileService.java |  136 +++
 .../iotdb/db/query/udf/service/UDFClassLoader.java |   83 ++
 .../query/udf/service/UDFClassLoaderManager.java   |  122 ++
 .../iotdb/db/query/udf/service/UDFLogWriter.java   |   69 ++
 .../udf/service/UDFRegistrationInformation.java    |   57 +
 .../query/udf/service/UDFRegistrationService.java  |  339 ++++++
 .../java/org/apache/iotdb/db/service/IoTDB.java    |    6 +
 .../org/apache/iotdb/db/service/ServiceType.java   |    9 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  118 +-
 .../db/sync/receiver/transfer/SyncServiceImpl.java |   22 +-
 .../iotdb/db/sync/sender/transfer/SyncClient.java  |   48 +-
 .../org/apache/iotdb/db/tools/mlog/MLogParser.java |  194 ++++
 .../db/tools/upgrade/TsFileOnlineUpgradeTool.java  |    1 +
 .../java/org/apache/iotdb/db/utils/QueryUtils.java |    1 -
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |   25 +-
 .../org/apache/iotdb/db/utils/SerializeUtils.java  |   12 +-
 .../iotdb/db/utils/datastructure/TVList.java       |    6 +-
 .../org/apache/iotdb/db/writelog/io/LogWriter.java |   56 +-
 .../db/writelog/node/ExclusiveWriteLogNode.java    |   13 +-
 .../iotdb/db/writelog/recover/LogReplayer.java     |    9 -
 .../apache/iotdb/db/auth/AuthorityCheckerTest.java |  144 +++
 .../{ => authorizer}/LocalFileAuthorizerTest.java  |  295 +++--
 .../db/auth/authorizer/OpenIdAuthorizerTest.java   |  107 +-
 .../iotdb/db/auth/entity/PathPrivilegeTest.java}   |   36 +-
 .../org/apache/iotdb/db/auth/entity/RoleTest.java  |   33 +-
 .../org/apache/iotdb/db/auth/entity/UserTest.java  |   44 +
 .../auth/{ => role}/LocalFileRoleAccessorTest.java |   13 +-
 .../auth/{ => role}/LocalFileRoleManagerTest.java  |   45 +-
 .../auth/{ => user}/LocalFileUserAccessorTest.java |   13 +-
 .../auth/{ => user}/LocalFileUserManagerTest.java  |   69 +-
 .../engine/compaction/LevelCompactionLogTest.java  |   82 ++
 .../compaction/LevelCompactionMergeTest.java       |  142 +++
 .../compaction/LevelCompactionRecoverTest.java     |  507 +++++++++
 .../compaction/LevelCompactionSelectorTest.java    |   73 ++
 .../LevelCompactionTest.java}                      |   68 +-
 .../LevelCompactionTsFileManagementTest.java       |  120 ++
 .../NoCompactionTsFileManagementTest.java          |  127 +++
 .../apache/iotdb/db/engine/merge/MergeTest.java    |    2 +-
 .../iotdb/db/engine/storagegroup/TTLTest.java      |    2 +-
 .../iotdb/db/integration/IOTDBGroupByIT.java       |  101 ++
 .../apache/iotdb/db/integration/IOTDBInsertIT.java |    4 +-
 .../iotdb/db/integration/IoTDBAddSubDeviceIT.java  |   15 +-
 .../iotdb/db/integration/IoTDBAlignByDeviceIT.java |   31 +-
 .../org/apache/iotdb/db/integration/IoTDBAsIT.java |   10 +
 .../db/integration/IoTDBAutoCreateSchemaIT.java    |   19 +-
 .../iotdb/db/integration/IoTDBCompactionIT.java    |  154 ---
 .../db/integration/IoTDBCreateSnapshotIT.java      |   74 +-
 .../iotdb/db/integration/IoTDBDeletionIT.java      |   53 +
 .../apache/iotdb/db/integration/IoTDBLastIT.java   |   13 +-
 .../db/integration/IoTDBLevelCompactionIT.java     | 1180 ++++++++++++++++++++
 .../iotdb/db/integration/IoTDBRestartIT.java       |    2 -
 .../iotdb/db/integration/IoTDBResultSetIT.java     |    4 +-
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   |    6 +-
 .../iotdb/db/integration/IoTDBUDFManagementIT.java |  308 +++++
 .../db/integration/IoTDBUDFWindowQueryIT.java      |  513 +++++++++
 .../integration/IoTDBUDTFAlignByTimeQueryIT.java   |  525 +++++++++
 .../db/integration/IoTDBUDTFHybridQueryIT.java     |  166 +++
 .../db/integration/IoTDBUDTFNonAlignQueryIT.java   |  337 ++++++
 .../IoTDBAggregationByLevelIT.java                 |    9 +-
 .../IoTDBAggregationDeleteIT.java                  |   16 +-
 .../{ => aggregation}/IoTDBAggregationIT.java      |    2 +-
 .../IoTDBAggregationLargeDataIT.java               |  247 +---
 .../IoTDBAggregationSmallDataIT.java               |  179 +--
 .../{ => auth}/IoTDBAuthorizationIT.java           |    2 +-
 .../apache/iotdb/db/metadata/PartialPathTest.java  |   34 +-
 .../iotdb/db/mqtt/BrokerAuthenticatorTest.java     |   16 +
 .../iotdb/db/qp/plan/ConcatOptimizerTest.java      |    7 +-
 .../apache/iotdb/db/qp/plan/PhysicalPlanTest.java  |  222 +++-
 .../db/query/aggregation/AggregateResultTest.java  |   19 +-
 .../query/aggregation/DescAggregateResultTest.java |  126 +++
 .../iotdb/db/query/control/TracingManagerTest.java |  111 ++
 .../iotdb/db/query/dataset/ListDataSetTest.java    |  126 +++
 .../db/query/dataset/ShowTimeSeriesResultTest.java |   57 +
 .../iotdb/db/query/dataset/SingleDataSetTest.java  |  133 +++
 .../query/dataset/UDTFAlignByTimeDataSetTest.java  |  578 ++++++++++
 .../dataset/groupby/GroupByEngineDataSetTest.java  |  476 ++++++++
 .../{ => groupby}/GroupByFillDataSetTest.java      |    2 +-
 .../{ => groupby}/GroupByLevelDataSetTest.java     |    2 +-
 .../{ => groupby}/GroupByTimeDataSetTest.java      |    2 +-
 .../query/executor/GroupByEngineDataSetTest.java   |  177 ---
 .../ElasticSerializableRowRecordListTest.java      |  224 ++++
 .../ElasticSerializableTVListTest.java             |  251 +++++
 .../SerializableBinaryTVListTest.java              |   80 ++
 .../SerializableBooleanTVListTest.java             |   80 ++
 .../SerializableDoubleTVListTest.java              |   79 ++
 .../datastructure/SerializableFloatTVListTest.java |   78 ++
 .../datastructure/SerializableIntTVListTest.java   |   78 ++
 .../udf/datastructure/SerializableListTest.java}   |   85 +-
 .../datastructure/SerializableLongTVListTest.java  |   78 ++
 .../SerializableRowRecordListTest.java             |  143 +++
 .../udf/datastructure/SerializableTVListTest.java} |   79 +-
 .../iotdb/db/query/udf/example/Accumulator.java    |   82 ++
 .../apache/iotdb/db/query/udf/example/Adder.java   |   78 ++
 .../apache/iotdb/db/query/udf/example/Counter.java |   76 ++
 .../iotdb/db/query/udf/example/Multiplier.java     |   54 +
 .../SlidingSizeWindowConstructorTester0.java       |   53 +
 .../SlidingSizeWindowConstructorTester1.java       |   54 +
 .../SlidingTimeWindowConstructionTester.java       |   61 +
 .../org/apache/iotdb/db/tools/MLogParserTest.java  |  150 +++
 .../org/apache/iotdb/db/tools/WalCheckerTest.java  |    5 +-
 .../iotdb/db/utils/CopyOnReadLinkedListTest.java   |   67 ++
 .../iotdb/db/utils/EncodingInferenceUtilsTest.java |   45 +
 .../apache/iotdb/db/utils/EnvironmentUtils.java    |    5 +
 .../org/apache/iotdb/db/utils/MemUtilsTest.java    |  114 ++
 .../org/apache/iotdb/db/utils/SchemaUtilsTest.java |   64 ++
 .../apache/iotdb/db/utils/SerializeUtilsTest.java  |  312 ++++++
 .../db/utils/datastructure/BinaryTVListTest.java   |   58 +
 .../db/utils/datastructure/BooleanTVListTest.java  |   62 +
 .../db/utils/datastructure/DoubleTVListTest.java   |   72 ++
 .../db/utils/datastructure/FloatTVListTest.java    |   72 ++
 .../db/utils/datastructure/IntTVListTest.java      |   71 ++
 .../db/utils/datastructure/LongTVListTest.java     |   18 +
 .../apache/iotdb/db/writelog/PerformanceTest.java  |   14 +-
 .../iotdb/db/writelog/io/LogWriterReaderTest.java  |    4 +-
 .../db/writelog/io/MultiFileLogReaderTest.java     |    4 +-
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |   43 +-
 .../main/java/org/apache/iotdb/rpc/RpcUtils.java   |   90 ++
 .../java/org/apache/iotdb/rpc/TSStatusCode.java    |    1 -
 .../iotdb/session/IoTDBSessionIteratorIT.java      |  178 ++-
 .../apache/iotdb/session/IoTDBSessionSimpleIT.java |   10 +-
 .../java/org/apache/iotdb/session/SessionUT.java   |    2 +-
 site/README-zh.md                                  |    2 +-
 site/README.md                                     |    2 +-
 site/src/main/.vuepress/config.js                  |   30 +-
 .../theme/global-components/Contributor.vue        |   14 +
 spark-iotdb-connector/pom.xml                      |    8 +-
 tsfile/format-changelist.md                        |    2 +-
 .../org/apache/iotdb/tsfile/file/MetaMarker.java   |    4 +
 .../iotdb/tsfile/file/footer/ChunkGroupFooter.java |   31 +-
 .../file/metadata/MetadataIndexConstructor.java    |    9 +-
 .../tsfile/file/metadata/MetadataIndexNode.java    |    7 +-
 .../file/metadata/enums/CompressionType.java       |  118 +-
 .../iotdb/tsfile/read/TsFileSequenceReader.java    |   20 +-
 .../org/apache/iotdb/tsfile/read/common/Field.java |    4 -
 .../apache/iotdb/tsfile/read/common/RowRecord.java |    2 +-
 .../query/dataset/DataSetWithTimeGenerator.java    |    4 +-
 .../query/dataset/DataSetWithoutTimeGenerator.java |    4 +-
 .../tsfile/read/query/dataset/EmptyDataSet.java    |    4 +-
 .../tsfile/read/query/dataset/QueryDataSet.java    |    4 +-
 .../iotdb/tsfile/utils/ReadWriteIOUtils.java       |   11 +-
 .../iotdb/tsfile/write/writer/TsFileIOWriter.java  |   12 +-
 .../tsfile/read/TsFileSequenceReaderTest.java      |    2 +-
 .../iotdb/tsfile/write/TsFileIOWriterTest.java     |    8 +
 zeppelin-interpreter/IoTDB-Zeppelin-Demo.zpln      |  377 +++++++
 zeppelin-interpreter/pom.xml                       |  142 +++
 .../apache/zeppelin/iotdb/IoTDBInterpreter.java    |  213 ++++
 .../src/main/resources/interpreter-setting.json    |   70 ++
 .../zeppelin/iotdb/IoTDBInterpreterTest.java       |  273 +++++
 367 files changed, 23038 insertions(+), 3757 deletions(-)
 create mode 100644 .github/pull_request_template.md
 create mode 100644 docs/UserGuide/Ecosystem Integration/Zeppelin-IoTDB.md
 create mode 100644 docs/UserGuide/Operation Manual/UDF User Defined Function.md
 copy server/file-changelists/mlog-changelist.md => docs/UserGuide/System Tools/MLogParser Tool.md (66%)
 create mode 100644 docs/zh/UserGuide/Ecosystem Integration/Zeppelin-IoTDB.md
 create mode 100644 docs/zh/UserGuide/Operation Manual/UDF User Defined Function.md
 copy server/file-changelists/mlog-changelist.md => docs/zh/UserGuide/System Tools/MLogParser Tool.md (66%)
 create mode 100644 example/udf/pom.xml
 create mode 100644 example/udf/src/main/java/org/apache/iotdb/udf/UDTFExample.java
 copy cluster/src/assembly/resources/sbin/add-node.bat => server/src/assembly/resources/tools/mlog/mLogParser.bat (50%)
 mode change 100755 => 100644
 copy cluster/src/assembly/resources/sbin/add-node.sh => server/src/assembly/resources/tools/mlog/mLogParser.sh (55%)
 mode change 100755 => 100644
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => exception/UDFRegistrationException.java} (65%)
 rename server/src/main/java/org/apache/iotdb/db/metadata/{MLogWriter.java => MLogTxtWriter.java} (70%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/logfile/MLogReader.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/logfile/MLogTxtReader.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/metadata/logfile/MLogWriter.java
 copy server/src/main/java/org/apache/iotdb/db/qp/logical/{crud/UpdateOperator.java => sys/CreateFunctionOperator.java} (51%)
 copy server/src/main/java/org/apache/iotdb/db/qp/logical/{crud/UpdateOperator.java => sys/DropFunctionOperator.java} (66%)
 copy server/src/main/java/org/apache/iotdb/db/qp/logical/{crud/UpdateOperator.java => sys/ShowFunctionsOperator.java} (68%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/UDFPlan.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/UDTFPlan.java
 delete mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/UpdatePlan.java
 copy server/src/main/java/org/apache/iotdb/db/qp/physical/sys/{SetStorageGroupPlan.java => ChangeAliasPlan.java} (60%)
 copy server/src/main/java/org/apache/iotdb/db/qp/physical/sys/{SetStorageGroupPlan.java => ChangeTagOffsetPlan.java} (59%)
 copy server/src/main/java/org/apache/iotdb/db/qp/physical/sys/{ShowPlan.java => CreateFunctionPlan.java} (60%)
 copy cluster/src/main/java/org/apache/iotdb/cluster/query/ClusterConcatPathOptimizer.java => server/src/main/java/org/apache/iotdb/db/qp/physical/sys/DropFunctionPlan.java (61%)
 copy server/src/main/java/org/apache/iotdb/db/qp/physical/sys/{SetStorageGroupPlan.java => MNodePlan.java} (53%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/sys/MeasurementMNodePlan.java
 copy server/src/main/java/org/apache/iotdb/db/qp/{logical/crud/UpdateOperator.java => physical/sys/ShowFunctionsPlan.java} (65%)
 copy server/src/main/java/org/apache/iotdb/db/qp/physical/sys/{SetStorageGroupPlan.java => StorageGroupMNodePlan.java} (51%)
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => query/dataset/DirectAlignByTimeDataSet.java} (62%)
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => query/dataset/DirectNonAlignDataSet.java} (62%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDTFAlignByTimeDataSet.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDTFDataSet.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/dataset/UDTFNonAlignDataSet.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/executor/UDTFQueryExecutor.java
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => query/udf/api/UDF.java} (65%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/UDTF.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/access/Row.java
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/file/MetaMarker.java => server/src/main/java/org/apache/iotdb/db/query/udf/api/access/RowIterator.java (51%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/access/RowWindow.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/collector/PointCollector.java
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => query/udf/api/customizer/config/UDFConfigurations.java} (60%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/config/UDTFConfigurations.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/parameter/UDFParameters.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/AccessStrategy.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/RowByRowAccessStrategy.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/SlidingSizeWindowAccessStrategy.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/api/customizer/strategy/SlidingTimeWindowAccessStrategy.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/access/RowImpl.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/access/RowIteratorImpl.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/access/RowWindowImpl.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/context/UDFContext.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/executor/UDTFExecutor.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/input/InputLayer.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/input/SafetyLine.java
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/file/MetaMarker.java => server/src/main/java/org/apache/iotdb/db/query/udf/core/reader/LayerPointReader.java (53%)
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => query/udf/core/reader/LayerRowReader.java} (62%)
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/file/MetaMarker.java => server/src/main/java/org/apache/iotdb/db/query/udf/core/reader/LayerRowWindowReader.java (62%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/RawQueryPointTransformer.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/Transformer.java
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/file/MetaMarker.java => server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/UDFQueryRowTransformer.java (51%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/UDFQueryRowWindowTransformer.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/core/transformer/UDFQueryTransformer.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/SerializableList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/ElasticSerializableIntList.java
 copy server/src/main/java/org/apache/iotdb/db/{qp/logical/crud/UpdateOperator.java => query/udf/datastructure/primitive/IntList.java} (65%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/SerializableIntList.java
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/EmptyDataSet.java => server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/primitive/WrappedIntArray.java (62%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/row/ElasticSerializableRowRecordList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/row/SerializableRowRecordList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/ElasticSerializableBinaryTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/ElasticSerializableTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableBinaryTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableBooleanTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableDoubleTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableFloatTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableIntTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableLongTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/datastructure/tv/SerializableTVList.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/TemporaryQueryDataFileService.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFClassLoader.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFClassLoaderManager.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFLogWriter.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFRegistrationInformation.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/query/udf/service/UDFRegistrationService.java
 create mode 100644 server/src/main/java/org/apache/iotdb/db/tools/mlog/MLogParser.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/auth/AuthorityCheckerTest.java
 rename server/src/test/java/org/apache/iotdb/db/auth/{ => authorizer}/LocalFileAuthorizerTest.java (52%)
 copy server/src/{main/java/org/apache/iotdb/db/auth/entity/PrivilegeType.java => test/java/org/apache/iotdb/db/auth/entity/PathPrivilegeTest.java} (51%)
 copy tsfile/src/main/java/org/apache/iotdb/tsfile/read/query/dataset/EmptyDataSet.java => server/src/test/java/org/apache/iotdb/db/auth/entity/RoleTest.java (53%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/auth/entity/UserTest.java
 rename server/src/test/java/org/apache/iotdb/db/auth/{ => role}/LocalFileRoleAccessorTest.java (85%)
 rename server/src/test/java/org/apache/iotdb/db/auth/{ => role}/LocalFileRoleManagerTest.java (73%)
 rename server/src/test/java/org/apache/iotdb/db/auth/{ => user}/LocalFileUserAccessorTest.java (89%)
 rename server/src/test/java/org/apache/iotdb/db/auth/{ => user}/LocalFileUserManagerTest.java (70%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionLogTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionMergeTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionRecoverTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionSelectorTest.java
 copy server/src/test/java/org/apache/iotdb/db/engine/{merge/MergeTest.java => compaction/LevelCompactionTest.java} (79%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/LevelCompactionTsFileManagementTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/engine/compaction/NoCompactionTsFileManagementTest.java
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCompactionIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBLevelCompactionIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDFManagementIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDFWindowQueryIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFAlignByTimeQueryIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFHybridQueryIT.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBUDTFNonAlignQueryIT.java
 rename server/src/test/java/org/apache/iotdb/db/integration/{ => aggregation}/IoTDBAggregationByLevelIT.java (97%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{ => aggregation}/IoTDBAggregationDeleteIT.java (89%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{ => aggregation}/IoTDBAggregationIT.java (99%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{ => aggregation}/IoTDBAggregationLargeDataIT.java (77%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{ => aggregation}/IoTDBAggregationSmallDataIT.java (87%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{ => auth}/IoTDBAuthorizationIT.java (99%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/aggregation/DescAggregateResultTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/control/TracingManagerTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/ListDataSetTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/ShowTimeSeriesResultTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/SingleDataSetTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/UDTFAlignByTimeDataSetTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/dataset/groupby/GroupByEngineDataSetTest.java
 rename server/src/test/java/org/apache/iotdb/db/query/dataset/{ => groupby}/GroupByFillDataSetTest.java (99%)
 rename server/src/test/java/org/apache/iotdb/db/query/dataset/{ => groupby}/GroupByLevelDataSetTest.java (99%)
 rename server/src/test/java/org/apache/iotdb/db/query/dataset/{ => groupby}/GroupByTimeDataSetTest.java (99%)
 delete mode 100644 server/src/test/java/org/apache/iotdb/db/query/executor/GroupByEngineDataSetTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/ElasticSerializableRowRecordListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/ElasticSerializableTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableBinaryTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableBooleanTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableDoubleTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableFloatTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableIntTVListTest.java
 copy server/src/{main/java/org/apache/iotdb/db/auth/AuthException.java => test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableListTest.java} (55%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableLongTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableRowRecordListTest.java
 rename server/src/{main/java/org/apache/iotdb/db/qp/logical/crud/UpdateOperator.java => test/java/org/apache/iotdb/db/query/udf/datastructure/SerializableTVListTest.java} (62%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Accumulator.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Adder.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Counter.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/Multiplier.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/SlidingSizeWindowConstructorTester0.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/SlidingSizeWindowConstructorTester1.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/query/udf/example/SlidingTimeWindowConstructionTester.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/tools/MLogParserTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/CopyOnReadLinkedListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/EncodingInferenceUtilsTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/MemUtilsTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/SchemaUtilsTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/SerializeUtilsTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/BinaryTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/BooleanTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/DoubleTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/FloatTVListTest.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/utils/datastructure/IntTVListTest.java
 create mode 100644 zeppelin-interpreter/IoTDB-Zeppelin-Demo.zpln
 create mode 100644 zeppelin-interpreter/pom.xml
 create mode 100644 zeppelin-interpreter/src/main/java/org/apache/zeppelin/iotdb/IoTDBInterpreter.java
 create mode 100644 zeppelin-interpreter/src/main/resources/interpreter-setting.json
 create mode 100644 zeppelin-interpreter/src/test/java/org/apache/zeppelin/iotdb/IoTDBInterpreterTest.java