You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by ne...@apache.org on 2021/02/26 06:59:55 UTC

[iotdb] branch change_rpc_port updated (1a986e6 -> 2cc3601)

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

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


    from 1a986e6  modify the content of the code comment of the seed_nodes
     add bc64896  Add new committer (#2720)
     add c84771b  [IOTDB-1152] optimize regular data size in traversing (#2667)
     add ca40856  move sonar and coverall as seperate actions; merge Linux and Mac actions into one file (#2713)
     add cb24696  Remove unexpected exception thrown when all CreateTimeseries opeartions are successful for CreateMultiTimeseries (#2718)
     add de69352  Update ASF copyright year on website (#2723)
     add 3aed578  [IOTDB-1024] Support multiple aggregated measurements for group by level statement (#2714)
     add 6770dba  New distribution structure for v0.12 (#2646)
     add b4544d8  [IOTDB-1163]optimize the insertRecords session interface for cluster version (#2698)
     add 0cf96a5  [IOTDB-1169] Clean up for redundant throw clause (#2721)
     add 56ffbcf  [ISSUE-2484] Fix creating timeseries error by using "create" or "insert" statement (#2468)
     add 7c5356b  fix IoTDBAutoCreateSchemaIT compile error (#2728)
     add a2b704d  bug fix - skip illegal path when delete multi timeseries  (#2567)
     add 2245ea5  [IOTDB-1144]support the show devices plan in distributed version (#2619)
     add bb62a88  filter slots in current data group member only when do  snapshot in cluster version (#2724)
     add fe0913c  Update system.properties change list (#2735)
     add f8056df  [IOTDB-1176] jar package normalization - remove common-lang and remain common-lang3 (#2737)
     add a818453  fix alter integration test suffix (#2736)
     add 103e07f  [IOTDB-1173] auto-create schema improvement for createMultiTimeSeriesPlan (#2731)
     new 51c7178  Merge branch 'apache_master' into change_rpc_port
     new 2cc3601  change some user doc

The 2 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                       |   4 +-
 .github/workflows/{main-mac.yml => main-unix.yml}  |  10 +-
 .github/workflows/main-win.yml                     |   2 +-
 .../{main-linux.yml => sonar-coveralls.yml}        |  20 +-
 README.md                                          |   2 +
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |   2 +-
 .../org/apache/iotdb/cli/StartClientScriptIT.java  |   4 +-
 client-cpp/pom.xml                                 | 156 ++++----
 client-cpp/src/assembly/client-cpp.xml             |   1 +
 cluster/src/assembly/cluster.xml                   |   8 +-
 cluster/src/assembly/resources/sbin/start-node.sh  |  38 +-
 .../java/org/apache/iotdb/cluster/ClusterMain.java |   2 +-
 .../cluster/client/sync/SyncClientAdaptor.java     |  21 +
 .../iotdb/cluster/config/ClusterDescriptor.java    |   1 -
 .../iotdb/cluster/coordinator/Coordinator.java     |  33 +-
 .../cluster/log/applier/AsyncDataLogApplier.java   |   8 +
 .../iotdb/cluster/log/applier/BaseApplier.java     |   3 +
 .../iotdb/cluster/log/applier/DataLogApplier.java  |  11 +
 .../manage/FilePartitionedSnapshotLogManager.java  |  18 +-
 .../log/manage/PartitionedSnapshotLogManager.java  |  18 +-
 .../cluster/log/snapshot/MetaSimpleSnapshot.java   |   3 +-
 .../apache/iotdb/cluster/metadata/CMManager.java   | 372 ++++++++++++++----
 .../iotdb/cluster/query/ClusterPlanRouter.java     |  35 +-
 .../iotdb/cluster/query/LocalQueryExecutor.java    |  18 +
 .../iotdb/cluster/server/DataClusterServer.java    |  13 +
 ...esSchemaHandler.java => GetDevicesHandler.java} |   9 +-
 .../cluster/server/member/DataGroupMember.java     |  12 +-
 .../cluster/server/service/DataAsyncService.java   |  10 +
 .../cluster/server/service/DataSyncService.java    |   9 +
 .../iotdb/cluster/common/TestLogManager.java       |   4 +-
 .../iotdb/cluster/log/CommitLogCallbackTest.java   |   4 +-
 .../cluster/log/applier/MetaLogApplierTest.java    |  11 +-
 .../cluster/log/manage/RaftLogManagerTest.java     |   3 +-
 .../cluster/log/snapshot/DataSnapshotTest.java     |   2 +-
 .../iotdb/cluster/query/LoadConfigurationTest.java |   4 +-
 .../query/reader/RemoteSimpleSeriesReaderTest.java |   2 +-
 .../caller/AppendGroupEntryHandlerTest.java        |   3 +-
 .../handlers/caller/ElectionHandlerTest.java       |   2 +-
 compile-tools/thrift/pom.xml                       | 432 +++++++--------------
 compile-tools/thrift/src/assembly/compiler.xml     |  37 --
 compile-tools/thrift/src/assembly/cpp.xml          |  51 ---
 compile-tools/thrift/src/assembly/python.xml       |  38 --
 distribution/pom.xml                               |  31 +-
 .../src/assembly/{distribution.xml => all.xml}     |  57 +--
 {cli => distribution}/src/assembly/cli.xml         |  24 +-
 .../src/assembly/client-cpp.xml                    |  14 +-
 .../src/assembly/{distribution.xml => cluster.xml} |  64 ++-
 distribution/src/assembly/common-files.xml         |  48 +++
 .../src/assembly/grafana.xml                       |  26 +-
 .../src/assembly/{distribution.xml => server.xml}  |  49 +--
 docker/src/main/Dockerfile                         |   2 +-
 .../DML Data Manipulation Language.md              |  38 +-
 docs/UserGuide/Server/Cluster Setup.md             |  67 ++--
 .../DML Data Manipulation Language.md              |  36 +-
 docs/zh/UserGuide/Server/Cluster Setup.md          |  67 ++--
 example/client-cpp-example/pom.xml                 | 214 +++++-----
 .../iotdb/flink/FlinkTsFileStreamSource.java       |   3 +-
 .../iotdb/hadoop/tsfile/TSFMRReadExample.java      |   3 +-
 .../iotdb/hadoop/tsfile/TSMRWriteExample.java      |   3 +-
 .../java/org/apache/iotdb/flink/IoTDBSink.java     |   2 +-
 .../iotdb/flink/IoTDBSinkBatchInsertTest.java      |   2 +-
 .../iotdb/flink/IoTDBSinkBatchTimerTest.java       |   4 +-
 .../iotdb/flink/tsfile/RowTSRecordConverter.java   |   7 +-
 .../flink/tsfile/RowTsFileConnectorTestBase.java   |   2 +-
 .../flink/tsfile/RowTsFileInputFormatITCase.java   |   2 +-
 .../web/grafana/dao/impl/BasicDaoImplTest.java     |   4 +-
 .../apache/iotdb/hadoop/fileSystem/HDFSFile.java   |   7 +-
 .../apache/iotdb/hadoop/fileSystem/HDFSInput.java  |  10 +-
 .../apache/iotdb/hadoop/fileSystem/HDFSOutput.java |   4 +-
 .../iotdb/hadoop/tsfile/TSFRecordReader.java       |   4 +-
 .../iotdb/hadoop/tsfile/TSFRecordWriter.java       |   2 +-
 .../apache/iotdb/hadoop/tsfile/TSFHadoopTest.java  |   4 +-
 .../iotdb/hadoop/tsfile/TSFInputSplitTest.java     |   2 +-
 .../org/apache/iotdb/hive/TSFHiveOutputFormat.java |   2 +-
 .../org/apache/iotdb/hive/TSFHiveRecordReader.java |   2 +-
 .../java/org/apache/iotdb/hive/TsFileSerDe.java    |   4 +-
 .../org/apache/iotdb/jdbc/IoTDBConnection.java     |   2 +-
 .../org/apache/iotdb/jdbc/IoTDBDataSource.java     |  17 +-
 .../apache/iotdb/jdbc/IoTDBDataSourceFactory.java  |  10 +-
 .../apache/iotdb/jdbc/IoTDBDatabaseMetadata.java   |   8 +-
 .../java/org/apache/iotdb/jdbc/IoTDBDriver.java    |   4 +-
 .../apache/iotdb/jdbc/IoTDBPreparedStatement.java  |  24 +-
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |   2 +-
 .../test/java/org/apache/iotdb/jdbc/BatchTest.java |   2 +-
 .../org/apache/iotdb/jdbc/IoTDBConnectionTest.java |   6 +-
 .../apache/iotdb/jdbc/IoTDBResultMetadataTest.java |   4 +-
 .../org/apache/iotdb/jdbc/IoTDBStatementTest.java  |   2 +-
 .../test/java/org/apache/iotdb/jdbc/UtilsTest.java |   4 +-
 pom.xml                                            |  35 +-
 .../system.properties-changelist.md                |   8 +-
 server/pom.xml                                     |   4 -
 .../iotdb/db/auth/authorizer/OpenIdAuthorizer.java |   6 +-
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  |   2 +-
 .../org/apache/iotdb/db/engine/StorageEngine.java  |   5 +-
 .../engine/storagegroup/StorageGroupProcessor.java |  11 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  62 ++-
 .../java/org/apache/iotdb/db/metadata/MTree.java   |  31 +-
 .../org/apache/iotdb/db/metadata/MetaUtils.java    |  37 ++
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |  49 ++-
 .../apache/iotdb/db/metrics/server/JettyUtil.java  |   6 +-
 .../iotdb/db/metrics/server/QueryServlet.java      |   7 +-
 .../apache/iotdb/db/mqtt/BrokerAuthenticator.java  |   2 +-
 .../apache/iotdb/db/qp/executor/IPlanExecutor.java |   8 +
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  |  73 ++--
 .../org/apache/iotdb/db/qp/logical/Operator.java   |   3 +-
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |  14 +-
 .../iotdb/db/qp/physical/crud/AggregationPlan.java |  35 ++
 .../db/qp/physical/crud/InsertMultiTabletPlan.java |  16 +-
 .../iotdb/db/qp/physical/crud/InsertRowPlan.java   |  10 +-
 .../physical/crud/InsertRowsOfOneDevicePlan.java   |   4 +-
 .../iotdb/db/qp/physical/crud/InsertRowsPlan.java  | 219 +++++++++++
 .../qp/physical/sys/CreateMultiTimeSeriesPlan.java |  14 +
 .../db/qp/physical/sys/DeleteTimeSeriesPlan.java   |  22 ++
 .../iotdb/db/qp/physical/sys/ShowDevicesPlan.java  |  26 ++
 .../db/qp/physical/sys/ShowTimeSeriesPlan.java     |   2 +-
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    |   2 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |  11 +
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |  11 -
 .../db/query/aggregation/impl/AvgAggrResult.java   |  17 +
 .../db/query/aggregation/impl/CountAggrResult.java |   2 +-
 .../query/aggregation/impl/MaxValueAggrResult.java |   4 +-
 .../query/aggregation/impl/MinValueAggrResult.java |   7 +-
 .../iotdb/db/query/dataset/ShowDevicesResult.java  |  44 +++
 .../iotdb/db/query/dataset/SingleDataSet.java      |   5 +-
 .../db/query/dataset/UDTFNonAlignDataSet.java      |   2 +-
 .../query/dataset/groupby/GroupByTimeDataSet.java  |   8 +-
 .../db/query/executor/AggregationExecutor.java     |  12 +-
 .../db/query/reader/chunk/DiskChunkLoader.java     |   2 +-
 .../db/query/reader/chunk/MemChunkLoader.java      |   4 +-
 .../db/query/reader/chunk/MemChunkReader.java      |   2 +-
 .../chunk/metadata/MemChunkMetadataLoader.java     |   3 +-
 .../query/reader/series/SeriesAggregateReader.java |   2 +-
 .../org/apache/iotdb/db/service/JMXService.java    |   3 +-
 .../org/apache/iotdb/db/service/MQTTService.java   |   3 +-
 .../apache/iotdb/db/service/MetricsService.java    |   4 +-
 .../org/apache/iotdb/db/service/RPCService.java    |   3 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  95 +++--
 .../org/apache/iotdb/db/service/UpgradeSevice.java |   3 +-
 .../iotdb/db/sync/receiver/SyncServerManager.java  |   3 +-
 .../db/sync/receiver/transfer/SyncServiceImpl.java |   9 +-
 .../db/tools/watermark/WatermarkDetector.java      |   2 +-
 .../org/apache/iotdb/db/utils/FilePathUtils.java   | 155 ++++----
 .../java/org/apache/iotdb/db/utils/FileUtils.java  |   3 +-
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |   2 +-
 .../org/apache/iotdb/db/utils/SerializeUtils.java  |   2 +-
 .../db/auth/authorizer/OpenIdAuthorizerTest.java   |   2 +-
 .../db/auth/role/LocalFileRoleAccessorTest.java    |   2 +-
 .../db/auth/role/LocalFileRoleManagerTest.java     |   2 +-
 .../db/auth/user/LocalFileUserAccessorTest.java    |   2 +-
 .../IoTDBDefaultThreadExceptionHandlerTest.java    |   4 +-
 .../db/concurrent/IoTDBThreadPoolFactoryTest.java  |   8 +-
 .../db/engine/memtable/MemTableFlushTaskTest.java  |   3 +-
 .../db/engine/memtable/MemtableBenchmark.java      |   3 +-
 .../engine/modification/DeletionFileNodeTest.java  |   3 +-
 .../io/LocalTextModificationAccessorTest.java      |   2 +-
 .../iotdb/db/engine/storagegroup/TTLTest.java      |   4 +-
 .../engine/storagegroup/TsFileProcessorTest.java   |   2 +-
 .../virtualSg/HashVirtualPartitionerTest.java      |   2 +-
 .../db/integration/IoTDBAutoCreateSchemaIT.java    | 106 +++++
 .../iotdb/db/integration/IoTDBCheckConfigIT.java   |   2 +-
 .../iotdb/db/integration/IoTDBClearCacheIT.java    |   3 +-
 .../apache/iotdb/db/integration/IoTDBCloseIT.java  |   3 +-
 .../iotdb/db/integration/IoTDBCompleteIT.java      |  20 +-
 .../iotdb/db/integration/IoTDBCompressTypeIT.java  |   2 +-
 .../db/integration/IoTDBCreateSnapshotIT.java      |   2 +-
 .../db/integration/IoTDBCreateTimeseriesIT.java    | 157 ++++++++
 .../apache/iotdb/db/integration/IoTDBDaemonIT.java |  14 +-
 .../db/integration/IoTDBDeleteStorageGroupIT.java  |   2 +-
 .../db/integration/IoTDBDeleteTimeseriesIT.java    |   2 +-
 .../db/integration/IoTDBEngineTimeGeneratorIT.java |   3 +-
 .../apache/iotdb/db/integration/IoTDBFillIT.java   |  21 +-
 .../db/integration/IoTDBFloatPrecisionIT.java      |   5 +-
 ...TDBKillQueryTest.java => IoTDBKillQueryIT.java} |   2 +-
 .../iotdb/db/integration/IoTDBLargeDataIT.java     |  12 +-
 .../apache/iotdb/db/integration/IoTDBLastIT.java   |   4 +-
 .../iotdb/db/integration/IoTDBLimitSlimitIT.java   |  11 +-
 .../iotdb/db/integration/IoTDBMetadataFetchIT.java |   2 +-
 .../iotdb/db/integration/IoTDBMultiDeviceIT.java   |   3 +-
 .../iotdb/db/integration/IoTDBMultiSeriesIT.java   |   8 +-
 .../db/integration/IoTDBMultiStatementsIT.java     |   3 +-
 .../iotdb/db/integration/IoTDBNumberPathIT.java    |  21 +-
 .../iotdb/db/integration/IoTDBQueryDemoIT.java     |   2 +-
 ...ryTimeoutTest.java => IoTDBQueryTimeoutIT.java} |   2 +-
 .../iotdb/db/integration/IoTDBQuotedPathIT.java    |   2 +-
 .../iotdb/db/integration/IoTDBRecoverIT.java       |   4 +-
 .../db/integration/IoTDBRecoverUnclosedIT.java     |   4 +-
 .../db/integration/IoTDBRemovePartitionIT.java     |   7 +-
 .../IoTDBSameMeasurementsDifferentTypesIT.java     |   3 +-
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   |   2 +-
 .../iotdb/db/integration/IoTDBTagAlterIT.java      |   2 +-
 .../apache/iotdb/db/integration/IoTDBTagIT.java    |   2 +-
 .../{IoTDBTracingTest.java => IoTDBTracingIT.java} |   2 +-
 .../iotdb/db/integration/IoTDBVersionIT.java       |   2 +-
 .../aggregation/IoTDBAggregationByLevelIT.java     |  86 ++--
 .../aggregation/IoTDBAggregationIT.java            |  10 +-
 .../aggregation/IoTDBAggregationLargeDataIT.java   |   7 +-
 .../db/integration/auth/IoTDBAuthorizationIT.java  |   2 +-
 .../iotdb/db/metadata/MManagerBasicTest.java       |   2 +-
 .../org/apache/iotdb/db/metadata/MTreeTest.java    |  29 +-
 .../apache/iotdb/db/metadata/MetaUtilsTest.java    |  35 ++
 .../apache/iotdb/db/metadata/PartialPathTest.java  |   2 +-
 .../apache/iotdb/db/metadata/mnode/MNodeTest.java  |  71 ++++
 .../iotdb/db/qp/logical/IndexLogicalPlanTest.java  |   5 +-
 .../iotdb/db/qp/sql/IoTDBsqlVisitorTest.java       |   4 +-
 .../iotdb/db/query/control/TracingManagerTest.java |   5 +-
 .../db/query/dataset/ShowDevicesResultTest.java}   |  22 +-
 .../reader/series/SeriesAggregateReaderTest.java   |   6 +-
 .../reader/series/SeriesReaderByTimestampTest.java |   6 +-
 .../db/query/reader/series/SeriesReaderTest.java   |   6 +-
 .../query/reader/series/SeriesReaderTestUtil.java  |   6 +-
 .../org/apache/iotdb/db/script/EnvScriptIT.java    |   6 +-
 .../db/sync/receiver/load/FileLoaderTest.java      |   8 +-
 .../recover/SyncReceiverLogAnalyzerTest.java       |   7 +-
 .../receiver/recover/SyncReceiverLoggerTest.java   |   6 +-
 .../db/sync/sender/manage/SyncFileManagerTest.java |   6 +-
 .../db/sync/sender/transfer/SyncClientTest.java    |   6 +-
 .../apache/iotdb/db/tools/IoTDBWatermarkTest.java  |   7 +-
 .../org/apache/iotdb/db/tools/MLogParserTest.java  |   2 +-
 .../apache/iotdb/db/utils/FilePathUtilsTest.java   |   3 +-
 .../org/apache/iotdb/db/utils/SchemaUtilsTest.java |   2 +-
 .../db/utils/datastructure/BinaryTVListTest.java   |   2 +-
 .../db/utils/datastructure/BooleanTVListTest.java  |   2 +-
 .../db/utils/datastructure/DoubleTVListTest.java   |   2 +-
 .../db/utils/datastructure/FloatTVListTest.java    |   2 +-
 .../db/utils/datastructure/IntTVListTest.java      |   2 +-
 .../db/utils/datastructure/LongTVListTest.java     |   2 +-
 .../db/utils/datastructure/PrecisionTest.java      |   9 +-
 .../apache/iotdb/db/writelog/PerformanceTest.java  |   5 +-
 .../iotdb/db/writelog/WriteLogNodeManagerTest.java |   2 +-
 .../apache/iotdb/db/writelog/WriteLogNodeTest.java |   2 +-
 .../iotdb/db/writelog/recover/LogReplayerTest.java |   3 +-
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |   2 +-
 session/pom.xml                                    |   4 -
 .../apache/iotdb/session/IoTDBSessionSimpleIT.java |  20 +
 .../apache/iotdb/session/SessionCacheLeaderUT.java |  33 +-
 .../public/img/contributor-avatar/xww.jpg          | Bin 0 -> 64538 bytes
 .../public/img/contributor-avatar/yrzh.jpg         | Bin 0 -> 99556 bytes
 site/src/main/.vuepress/theme/components/Page.vue  |  35 +-
 .../theme/global-components/Contributor.vue        |  14 +
 .../apache/iotdb/spark/db/EnvironmentUtils.java    |   2 +-
 .../spark/tsfile/qp/common/BasicOperator.java      |   4 +-
 .../tsfile/qp/optimizer/RemoveNotOptimizer.java    |  20 +-
 thrift/src/main/thrift/cluster.thrift              |   5 +
 .../apache/iotdb/tsfile/compress/ICompressor.java  |   6 +-
 .../iotdb/tsfile/compress/IUnCompressor.java       |   6 +-
 .../tsfile/encoding/decoder/BitmapDecoder.java     |  21 +-
 .../tsfile/encoding/decoder/LongRleDecoder.java    |   3 +-
 .../tsfile/encoding/decoder/PlainDecoder.java      |   3 +-
 .../encoding/encoder/RegularDataEncoder.java       |   8 +-
 .../encoding/encoder/SinglePrecisionEncoderV1.java |   3 +-
 .../iotdb/tsfile/read/UnClosedTsFileReader.java    |   4 +-
 .../tsfile/read/reader/BatchDataIterator.java      |   4 +-
 .../iotdb/tsfile/read/reader/LocalTsFileInput.java |   2 +-
 .../tsfile/write/chunk/ChunkGroupWriterImpl.java   |   6 +-
 .../write/record/datapoint/BooleanDataPoint.java   |   4 +-
 .../write/record/datapoint/DoubleDataPoint.java    |   4 +-
 .../write/record/datapoint/FloatDataPoint.java     |   4 +-
 .../write/record/datapoint/IntDataPoint.java       |   4 +-
 .../write/record/datapoint/LongDataPoint.java      |   4 +-
 .../write/record/datapoint/StringDataPoint.java    |   4 +-
 .../iotdb/tsfile/encoding/SDTEncoderTest.java      |  12 +-
 .../tsfile/encoding/decoder/BitmapDecoderTest.java |   4 +-
 .../tsfile/encoding/decoder/FloatDecoderTest.java  |   4 +-
 .../encoding/decoder/GorillaDecoderV1Test.java     |   4 +-
 .../tsfile/encoding/decoder/IntRleDecoderTest.java |   4 +-
 .../encoding/decoder/LongRleDecoderTest.java       |   4 +-
 .../delta/DeltaBinaryEncoderIntegerTest.java       |   2 +-
 .../decoder/delta/DeltaBinaryEncoderLongTest.java  |   2 +-
 .../regular/RegularDataEncoderIntegerTest.java     |  15 +-
 .../regular/RegularDataEncoderLongTest.java        |  15 +-
 .../file/metadata/TimeSeriesMetadataTest.java      |   2 +-
 .../tsfile/file/metadata/TsFileMetadataTest.java   |   2 +-
 .../iotdb/tsfile/read/TimePlainEncodeReadTest.java |   3 +-
 .../tsfile/read/TimeSeriesMetadataReadTest.java    |   2 +-
 .../tsfile/read/filter/GroupByFilterTest.java      |   2 +-
 .../read/query/executor/QueryExecutorTest.java     |   3 +-
 .../query/timegenerator/ReaderByTimestampTest.java |   3 +-
 .../TsFileGeneratorForSeriesReaderByTimestamp.java |   8 +-
 .../tsfile/read/reader/FakedMultiBatchReader.java  |   4 +-
 .../apache/iotdb/tsfile/utils/BytesUtilsTest.java  |   8 +-
 .../tsfile/utils/ReadWriteStreamUtilsTest.java     |   4 +-
 .../tsfile/utils/ReadWriteToBytesUtilsTest.java    |   2 +-
 .../apache/iotdb/tsfile/utils/RecordUtilsTest.java |   3 +-
 .../org/apache/iotdb/tsfile/write/PerfTest.java    |   2 +-
 .../iotdb/tsfile/write/ReadPageInMemTest.java      |   2 +-
 .../iotdb/tsfile/write/TsFileReadWriteTest.java    |   4 +-
 .../iotdb/tsfile/write/TsFileWriterTest.java       |   2 +-
 .../org/apache/iotdb/tsfile/write/WriteTest.java   |   2 +-
 288 files changed, 2843 insertions(+), 1848 deletions(-)
 rename .github/workflows/{main-mac.yml => main-unix.yml} (79%)
 rename .github/workflows/{main-linux.yml => sonar-coveralls.yml} (73%)
 copy cluster/src/main/java/org/apache/iotdb/cluster/server/handlers/caller/{GetTimeseriesSchemaHandler.java => GetDevicesHandler.java} (84%)
 delete mode 100644 compile-tools/thrift/src/assembly/compiler.xml
 delete mode 100644 compile-tools/thrift/src/assembly/cpp.xml
 delete mode 100644 compile-tools/thrift/src/assembly/python.xml
 copy distribution/src/assembly/{distribution.xml => all.xml} (66%)
 copy {cli => distribution}/src/assembly/cli.xml (57%)
 copy server/src/assembly/server.xml => distribution/src/assembly/client-cpp.xml (73%)
 copy distribution/src/assembly/{distribution.xml => cluster.xml} (57%)
 create mode 100644 distribution/src/assembly/common-files.xml
 copy server/src/assembly/server.xml => distribution/src/assembly/grafana.xml (61%)
 rename distribution/src/assembly/{distribution.xml => server.xml} (65%)
 create mode 100644 server/src/main/java/org/apache/iotdb/db/qp/physical/crud/InsertRowsPlan.java
 create mode 100644 server/src/test/java/org/apache/iotdb/db/integration/IoTDBCreateTimeseriesIT.java
 rename server/src/test/java/org/apache/iotdb/db/integration/{IoTDBKillQueryTest.java => IoTDBKillQueryIT.java} (98%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{IoTDBQueryTimeoutTest.java => IoTDBQueryTimeoutIT.java} (99%)
 rename server/src/test/java/org/apache/iotdb/db/integration/{IoTDBTracingTest.java => IoTDBTracingIT.java} (98%)
 create mode 100644 server/src/test/java/org/apache/iotdb/db/metadata/mnode/MNodeTest.java
 copy server/src/{main/java/org/apache/iotdb/db/query/dataset/UDFInputDataSet.java => test/java/org/apache/iotdb/db/query/dataset/ShowDevicesResultTest.java} (56%)
 create mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/xww.jpg
 create mode 100644 site/src/main/.vuepress/public/img/contributor-avatar/yrzh.jpg


[iotdb] 01/02: Merge branch 'apache_master' into change_rpc_port

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

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

commit 51c71786c2dbad57424c20057b961a176fdc5a74
Merge: 1a986e6 103e07f
Author: HouliangQi <ne...@163.com>
AuthorDate: Fri Feb 26 09:51:51 2021 +0800

    Merge branch 'apache_master' into change_rpc_port

 .github/workflows/client.yml                       |   4 +-
 .github/workflows/{main-mac.yml => main-unix.yml}  |  10 +-
 .github/workflows/main-win.yml                     |   2 +-
 .../{main-linux.yml => sonar-coveralls.yml}        |  20 +-
 README.md                                          |   2 +
 .../java/org/apache/iotdb/cli/AbstractCliIT.java   |   2 +-
 .../org/apache/iotdb/cli/StartClientScriptIT.java  |   4 +-
 client-cpp/pom.xml                                 | 156 ++++----
 client-cpp/src/assembly/client-cpp.xml             |   1 +
 cluster/src/assembly/cluster.xml                   |   8 +-
 .../cluster/client/sync/SyncClientAdaptor.java     |  21 +
 .../iotdb/cluster/coordinator/Coordinator.java     |  33 +-
 .../cluster/log/applier/AsyncDataLogApplier.java   |   8 +
 .../iotdb/cluster/log/applier/BaseApplier.java     |   3 +
 .../iotdb/cluster/log/applier/DataLogApplier.java  |  11 +
 .../manage/FilePartitionedSnapshotLogManager.java  |  18 +-
 .../log/manage/PartitionedSnapshotLogManager.java  |  18 +-
 .../cluster/log/snapshot/MetaSimpleSnapshot.java   |   3 +-
 .../apache/iotdb/cluster/metadata/CMManager.java   | 372 ++++++++++++++----
 .../iotdb/cluster/query/ClusterPlanRouter.java     |  35 +-
 .../iotdb/cluster/query/LocalQueryExecutor.java    |  18 +
 .../iotdb/cluster/server/DataClusterServer.java    |  13 +
 .../server/handlers/caller/GetDevicesHandler.java  |  60 +++
 .../cluster/server/member/DataGroupMember.java     |  12 +-
 .../cluster/server/service/DataAsyncService.java   |  10 +
 .../cluster/server/service/DataSyncService.java    |   9 +
 .../iotdb/cluster/common/TestLogManager.java       |   4 +-
 .../iotdb/cluster/log/CommitLogCallbackTest.java   |   4 +-
 .../cluster/log/applier/MetaLogApplierTest.java    |  11 +-
 .../cluster/log/manage/RaftLogManagerTest.java     |   3 +-
 .../cluster/log/snapshot/DataSnapshotTest.java     |   2 +-
 .../iotdb/cluster/query/LoadConfigurationTest.java |   4 +-
 .../query/reader/RemoteSimpleSeriesReaderTest.java |   2 +-
 .../caller/AppendGroupEntryHandlerTest.java        |   3 +-
 .../handlers/caller/ElectionHandlerTest.java       |   2 +-
 compile-tools/thrift/pom.xml                       | 432 +++++++--------------
 compile-tools/thrift/src/assembly/compiler.xml     |  37 --
 compile-tools/thrift/src/assembly/cpp.xml          |  51 ---
 compile-tools/thrift/src/assembly/python.xml       |  38 --
 distribution/pom.xml                               |  31 +-
 .../src/assembly/{distribution.xml => all.xml}     |  57 +--
 distribution/src/assembly/cli.xml                  |  54 +++
 .../src/assembly/client-cpp.xml                    |  39 +-
 .../src/assembly/{distribution.xml => cluster.xml} |  64 ++-
 distribution/src/assembly/common-files.xml         |  48 +++
 distribution/src/assembly/grafana.xml              |  48 +++
 .../src/assembly/{distribution.xml => server.xml}  |  49 +--
 docker/src/main/Dockerfile                         |   2 +-
 .../DML Data Manipulation Language.md              |  38 +-
 .../DML Data Manipulation Language.md              |  36 +-
 example/client-cpp-example/pom.xml                 | 214 +++++-----
 .../iotdb/flink/FlinkTsFileStreamSource.java       |   3 +-
 .../iotdb/hadoop/tsfile/TSFMRReadExample.java      |   3 +-
 .../iotdb/hadoop/tsfile/TSMRWriteExample.java      |   3 +-
 .../java/org/apache/iotdb/flink/IoTDBSink.java     |   2 +-
 .../iotdb/flink/IoTDBSinkBatchInsertTest.java      |   2 +-
 .../iotdb/flink/IoTDBSinkBatchTimerTest.java       |   4 +-
 .../iotdb/flink/tsfile/RowTSRecordConverter.java   |   7 +-
 .../flink/tsfile/RowTsFileConnectorTestBase.java   |   2 +-
 .../flink/tsfile/RowTsFileInputFormatITCase.java   |   2 +-
 .../web/grafana/dao/impl/BasicDaoImplTest.java     |   4 +-
 .../apache/iotdb/hadoop/fileSystem/HDFSFile.java   |   7 +-
 .../apache/iotdb/hadoop/fileSystem/HDFSInput.java  |  10 +-
 .../apache/iotdb/hadoop/fileSystem/HDFSOutput.java |   4 +-
 .../iotdb/hadoop/tsfile/TSFRecordReader.java       |   4 +-
 .../iotdb/hadoop/tsfile/TSFRecordWriter.java       |   2 +-
 .../apache/iotdb/hadoop/tsfile/TSFHadoopTest.java  |   4 +-
 .../iotdb/hadoop/tsfile/TSFInputSplitTest.java     |   2 +-
 .../org/apache/iotdb/hive/TSFHiveOutputFormat.java |   2 +-
 .../org/apache/iotdb/hive/TSFHiveRecordReader.java |   2 +-
 .../java/org/apache/iotdb/hive/TsFileSerDe.java    |   4 +-
 .../org/apache/iotdb/jdbc/IoTDBConnection.java     |   2 +-
 .../org/apache/iotdb/jdbc/IoTDBDataSource.java     |  17 +-
 .../apache/iotdb/jdbc/IoTDBDataSourceFactory.java  |  10 +-
 .../apache/iotdb/jdbc/IoTDBDatabaseMetadata.java   |   8 +-
 .../java/org/apache/iotdb/jdbc/IoTDBDriver.java    |   4 +-
 .../apache/iotdb/jdbc/IoTDBPreparedStatement.java  |  24 +-
 .../java/org/apache/iotdb/jdbc/IoTDBStatement.java |   2 +-
 .../test/java/org/apache/iotdb/jdbc/BatchTest.java |   2 +-
 .../org/apache/iotdb/jdbc/IoTDBConnectionTest.java |   6 +-
 .../apache/iotdb/jdbc/IoTDBResultMetadataTest.java |   4 +-
 .../org/apache/iotdb/jdbc/IoTDBStatementTest.java  |   2 +-
 .../test/java/org/apache/iotdb/jdbc/UtilsTest.java |   4 +-
 pom.xml                                            |  35 +-
 .../system.properties-changelist.md                |   8 +-
 server/pom.xml                                     |   4 -
 .../iotdb/db/auth/authorizer/OpenIdAuthorizer.java |   6 +-
 .../org/apache/iotdb/db/conf/IoTDBDescriptor.java  |   2 +-
 .../org/apache/iotdb/db/engine/StorageEngine.java  |   5 +-
 .../engine/storagegroup/StorageGroupProcessor.java |  11 +-
 .../org/apache/iotdb/db/metadata/MManager.java     |  62 ++-
 .../java/org/apache/iotdb/db/metadata/MTree.java   |  31 +-
 .../org/apache/iotdb/db/metadata/MetaUtils.java    |  37 ++
 .../org/apache/iotdb/db/metadata/mnode/MNode.java  |  49 ++-
 .../apache/iotdb/db/metrics/server/JettyUtil.java  |   6 +-
 .../iotdb/db/metrics/server/QueryServlet.java      |   7 +-
 .../apache/iotdb/db/mqtt/BrokerAuthenticator.java  |   2 +-
 .../apache/iotdb/db/qp/executor/IPlanExecutor.java |   8 +
 .../apache/iotdb/db/qp/executor/PlanExecutor.java  |  73 ++--
 .../org/apache/iotdb/db/qp/logical/Operator.java   |   3 +-
 .../apache/iotdb/db/qp/physical/PhysicalPlan.java  |  14 +-
 .../iotdb/db/qp/physical/crud/AggregationPlan.java |  35 ++
 .../db/qp/physical/crud/InsertMultiTabletPlan.java |  16 +-
 .../iotdb/db/qp/physical/crud/InsertRowPlan.java   |  10 +-
 .../physical/crud/InsertRowsOfOneDevicePlan.java   |   4 +-
 .../iotdb/db/qp/physical/crud/InsertRowsPlan.java  | 219 +++++++++++
 .../qp/physical/sys/CreateMultiTimeSeriesPlan.java |  14 +
 .../db/qp/physical/sys/DeleteTimeSeriesPlan.java   |  22 ++
 .../iotdb/db/qp/physical/sys/ShowDevicesPlan.java  |  26 ++
 .../db/qp/physical/sys/ShowTimeSeriesPlan.java     |   2 +-
 .../apache/iotdb/db/qp/sql/IoTDBSqlVisitor.java    |   2 +-
 .../iotdb/db/qp/strategy/PhysicalGenerator.java    |  11 +
 .../qp/strategy/optimizer/ConcatPathOptimizer.java |  11 -
 .../db/query/aggregation/impl/AvgAggrResult.java   |  17 +
 .../db/query/aggregation/impl/CountAggrResult.java |   2 +-
 .../query/aggregation/impl/MaxValueAggrResult.java |   4 +-
 .../query/aggregation/impl/MinValueAggrResult.java |   7 +-
 .../iotdb/db/query/dataset/ShowDevicesResult.java  |  44 +++
 .../iotdb/db/query/dataset/SingleDataSet.java      |   5 +-
 .../db/query/dataset/UDTFNonAlignDataSet.java      |   2 +-
 .../query/dataset/groupby/GroupByTimeDataSet.java  |   8 +-
 .../db/query/executor/AggregationExecutor.java     |  12 +-
 .../db/query/reader/chunk/DiskChunkLoader.java     |   2 +-
 .../db/query/reader/chunk/MemChunkLoader.java      |   4 +-
 .../db/query/reader/chunk/MemChunkReader.java      |   2 +-
 .../chunk/metadata/MemChunkMetadataLoader.java     |   3 +-
 .../query/reader/series/SeriesAggregateReader.java |   2 +-
 .../org/apache/iotdb/db/service/JMXService.java    |   3 +-
 .../org/apache/iotdb/db/service/MQTTService.java   |   3 +-
 .../apache/iotdb/db/service/MetricsService.java    |   4 +-
 .../org/apache/iotdb/db/service/RPCService.java    |   3 +-
 .../org/apache/iotdb/db/service/TSServiceImpl.java |  95 +++--
 .../org/apache/iotdb/db/service/UpgradeSevice.java |   3 +-
 .../iotdb/db/sync/receiver/SyncServerManager.java  |   3 +-
 .../db/sync/receiver/transfer/SyncServiceImpl.java |   9 +-
 .../db/tools/watermark/WatermarkDetector.java      |   2 +-
 .../org/apache/iotdb/db/utils/FilePathUtils.java   | 155 ++++----
 .../java/org/apache/iotdb/db/utils/FileUtils.java  |   3 +-
 .../org/apache/iotdb/db/utils/SchemaUtils.java     |   2 +-
 .../db/auth/authorizer/OpenIdAuthorizerTest.java   |   2 +-
 .../db/auth/role/LocalFileRoleAccessorTest.java    |   2 +-
 .../db/auth/role/LocalFileRoleManagerTest.java     |   2 +-
 .../db/auth/user/LocalFileUserAccessorTest.java    |   2 +-
 .../IoTDBDefaultThreadExceptionHandlerTest.java    |   4 +-
 .../db/concurrent/IoTDBThreadPoolFactoryTest.java  |   8 +-
 .../db/engine/memtable/MemTableFlushTaskTest.java  |   3 +-
 .../db/engine/memtable/MemtableBenchmark.java      |   3 +-
 .../engine/modification/DeletionFileNodeTest.java  |   3 +-
 .../io/LocalTextModificationAccessorTest.java      |   2 +-
 .../iotdb/db/engine/storagegroup/TTLTest.java      |   4 +-
 .../engine/storagegroup/TsFileProcessorTest.java   |   2 +-
 .../virtualSg/HashVirtualPartitionerTest.java      |   2 +-
 .../db/integration/IoTDBAutoCreateSchemaIT.java    | 106 +++++
 .../iotdb/db/integration/IoTDBCheckConfigIT.java   |   2 +-
 .../iotdb/db/integration/IoTDBClearCacheIT.java    |   3 +-
 .../apache/iotdb/db/integration/IoTDBCloseIT.java  |   3 +-
 .../iotdb/db/integration/IoTDBCompleteIT.java      |  20 +-
 .../iotdb/db/integration/IoTDBCompressTypeIT.java  |   2 +-
 .../db/integration/IoTDBCreateSnapshotIT.java      |   2 +-
 .../db/integration/IoTDBCreateTimeseriesIT.java    | 157 ++++++++
 .../apache/iotdb/db/integration/IoTDBDaemonIT.java |  14 +-
 .../db/integration/IoTDBDeleteStorageGroupIT.java  |   2 +-
 .../db/integration/IoTDBDeleteTimeseriesIT.java    |   2 +-
 .../db/integration/IoTDBEngineTimeGeneratorIT.java |   3 +-
 .../apache/iotdb/db/integration/IoTDBFillIT.java   |  21 +-
 .../db/integration/IoTDBFloatPrecisionIT.java      |   5 +-
 ...TDBKillQueryTest.java => IoTDBKillQueryIT.java} |   2 +-
 .../iotdb/db/integration/IoTDBLargeDataIT.java     |  12 +-
 .../apache/iotdb/db/integration/IoTDBLastIT.java   |   4 +-
 .../iotdb/db/integration/IoTDBLimitSlimitIT.java   |  11 +-
 .../iotdb/db/integration/IoTDBMetadataFetchIT.java |   2 +-
 .../iotdb/db/integration/IoTDBMultiDeviceIT.java   |   3 +-
 .../iotdb/db/integration/IoTDBMultiSeriesIT.java   |   8 +-
 .../db/integration/IoTDBMultiStatementsIT.java     |   3 +-
 .../iotdb/db/integration/IoTDBNumberPathIT.java    |  21 +-
 .../iotdb/db/integration/IoTDBQueryDemoIT.java     |   2 +-
 ...ryTimeoutTest.java => IoTDBQueryTimeoutIT.java} |   2 +-
 .../iotdb/db/integration/IoTDBQuotedPathIT.java    |   2 +-
 .../iotdb/db/integration/IoTDBRecoverIT.java       |   4 +-
 .../db/integration/IoTDBRecoverUnclosedIT.java     |   4 +-
 .../db/integration/IoTDBRemovePartitionIT.java     |   7 +-
 .../IoTDBSameMeasurementsDifferentTypesIT.java     |   3 +-
 .../iotdb/db/integration/IoTDBSimpleQueryIT.java   |   2 +-
 .../iotdb/db/integration/IoTDBTagAlterIT.java      |   2 +-
 .../apache/iotdb/db/integration/IoTDBTagIT.java    |   2 +-
 .../{IoTDBTracingTest.java => IoTDBTracingIT.java} |   2 +-
 .../iotdb/db/integration/IoTDBVersionIT.java       |   2 +-
 .../aggregation/IoTDBAggregationByLevelIT.java     |  86 ++--
 .../aggregation/IoTDBAggregationIT.java            |  10 +-
 .../aggregation/IoTDBAggregationLargeDataIT.java   |   7 +-
 .../db/integration/auth/IoTDBAuthorizationIT.java  |   2 +-
 .../iotdb/db/metadata/MManagerBasicTest.java       |   2 +-
 .../org/apache/iotdb/db/metadata/MTreeTest.java    |  29 +-
 .../apache/iotdb/db/metadata/MetaUtilsTest.java    |  35 ++
 .../apache/iotdb/db/metadata/PartialPathTest.java  |   2 +-
 .../apache/iotdb/db/metadata/mnode/MNodeTest.java  |  71 ++++
 .../iotdb/db/qp/logical/IndexLogicalPlanTest.java  |   5 +-
 .../iotdb/db/qp/sql/IoTDBsqlVisitorTest.java       |   4 +-
 .../iotdb/db/query/control/TracingManagerTest.java |   5 +-
 .../db/query/dataset/ShowDevicesResultTest.java    |  31 +-
 .../reader/series/SeriesAggregateReaderTest.java   |   6 +-
 .../reader/series/SeriesReaderByTimestampTest.java |   6 +-
 .../db/query/reader/series/SeriesReaderTest.java   |   6 +-
 .../query/reader/series/SeriesReaderTestUtil.java  |   6 +-
 .../org/apache/iotdb/db/script/EnvScriptIT.java    |   6 +-
 .../db/sync/receiver/load/FileLoaderTest.java      |   8 +-
 .../recover/SyncReceiverLogAnalyzerTest.java       |   7 +-
 .../receiver/recover/SyncReceiverLoggerTest.java   |   6 +-
 .../db/sync/sender/manage/SyncFileManagerTest.java |   6 +-
 .../db/sync/sender/transfer/SyncClientTest.java    |   6 +-
 .../apache/iotdb/db/tools/IoTDBWatermarkTest.java  |   7 +-
 .../org/apache/iotdb/db/tools/MLogParserTest.java  |   2 +-
 .../apache/iotdb/db/utils/FilePathUtilsTest.java   |   3 +-
 .../org/apache/iotdb/db/utils/SchemaUtilsTest.java |   2 +-
 .../db/utils/datastructure/BinaryTVListTest.java   |   2 +-
 .../db/utils/datastructure/BooleanTVListTest.java  |   2 +-
 .../db/utils/datastructure/DoubleTVListTest.java   |   2 +-
 .../db/utils/datastructure/FloatTVListTest.java    |   2 +-
 .../db/utils/datastructure/IntTVListTest.java      |   2 +-
 .../db/utils/datastructure/LongTVListTest.java     |   2 +-
 .../db/utils/datastructure/PrecisionTest.java      |   9 +-
 .../apache/iotdb/db/writelog/PerformanceTest.java  |   5 +-
 .../iotdb/db/writelog/WriteLogNodeManagerTest.java |   2 +-
 .../apache/iotdb/db/writelog/WriteLogNodeTest.java |   2 +-
 .../iotdb/db/writelog/recover/LogReplayerTest.java |   3 +-
 .../java/org/apache/iotdb/rpc/IoTDBRpcDataSet.java |   2 +-
 session/pom.xml                                    |   4 -
 .../apache/iotdb/session/IoTDBSessionSimpleIT.java |  20 +
 .../apache/iotdb/session/SessionCacheLeaderUT.java |  33 +-
 .../public/img/contributor-avatar/xww.jpg          | Bin 0 -> 64538 bytes
 .../public/img/contributor-avatar/yrzh.jpg         | Bin 0 -> 99556 bytes
 site/src/main/.vuepress/theme/components/Page.vue  |  35 +-
 .../theme/global-components/Contributor.vue        |  14 +
 .../apache/iotdb/spark/db/EnvironmentUtils.java    |   2 +-
 .../spark/tsfile/qp/common/BasicOperator.java      |   4 +-
 .../tsfile/qp/optimizer/RemoveNotOptimizer.java    |  20 +-
 thrift/src/main/thrift/cluster.thrift              |   5 +
 .../apache/iotdb/tsfile/compress/ICompressor.java  |   6 +-
 .../iotdb/tsfile/compress/IUnCompressor.java       |   6 +-
 .../tsfile/encoding/decoder/BitmapDecoder.java     |  21 +-
 .../tsfile/encoding/decoder/LongRleDecoder.java    |   3 +-
 .../tsfile/encoding/decoder/PlainDecoder.java      |   3 +-
 .../encoding/encoder/RegularDataEncoder.java       |   8 +-
 .../encoding/encoder/SinglePrecisionEncoderV1.java |   3 +-
 .../iotdb/tsfile/read/UnClosedTsFileReader.java    |   4 +-
 .../tsfile/read/reader/BatchDataIterator.java      |   4 +-
 .../iotdb/tsfile/read/reader/LocalTsFileInput.java |   2 +-
 .../tsfile/write/chunk/ChunkGroupWriterImpl.java   |   6 +-
 .../write/record/datapoint/BooleanDataPoint.java   |   4 +-
 .../write/record/datapoint/DoubleDataPoint.java    |   4 +-
 .../write/record/datapoint/FloatDataPoint.java     |   4 +-
 .../write/record/datapoint/IntDataPoint.java       |   4 +-
 .../write/record/datapoint/LongDataPoint.java      |   4 +-
 .../write/record/datapoint/StringDataPoint.java    |   4 +-
 .../iotdb/tsfile/encoding/SDTEncoderTest.java      |  12 +-
 .../tsfile/encoding/decoder/BitmapDecoderTest.java |   4 +-
 .../tsfile/encoding/decoder/FloatDecoderTest.java  |   4 +-
 .../encoding/decoder/GorillaDecoderV1Test.java     |   4 +-
 .../tsfile/encoding/decoder/IntRleDecoderTest.java |   4 +-
 .../encoding/decoder/LongRleDecoderTest.java       |   4 +-
 .../delta/DeltaBinaryEncoderIntegerTest.java       |   2 +-
 .../decoder/delta/DeltaBinaryEncoderLongTest.java  |   2 +-
 .../regular/RegularDataEncoderIntegerTest.java     |  15 +-
 .../regular/RegularDataEncoderLongTest.java        |  15 +-
 .../file/metadata/TimeSeriesMetadataTest.java      |   2 +-
 .../tsfile/file/metadata/TsFileMetadataTest.java   |   2 +-
 .../iotdb/tsfile/read/TimePlainEncodeReadTest.java |   3 +-
 .../tsfile/read/TimeSeriesMetadataReadTest.java    |   2 +-
 .../tsfile/read/filter/GroupByFilterTest.java      |   2 +-
 .../read/query/executor/QueryExecutorTest.java     |   3 +-
 .../query/timegenerator/ReaderByTimestampTest.java |   3 +-
 .../TsFileGeneratorForSeriesReaderByTimestamp.java |   8 +-
 .../tsfile/read/reader/FakedMultiBatchReader.java  |   4 +-
 .../apache/iotdb/tsfile/utils/BytesUtilsTest.java  |   8 +-
 .../tsfile/utils/ReadWriteStreamUtilsTest.java     |   4 +-
 .../tsfile/utils/ReadWriteToBytesUtilsTest.java    |   2 +-
 .../apache/iotdb/tsfile/utils/RecordUtilsTest.java |   3 +-
 .../org/apache/iotdb/tsfile/write/PerfTest.java    |   2 +-
 .../iotdb/tsfile/write/ReadPageInMemTest.java      |   2 +-
 .../iotdb/tsfile/write/TsFileReadWriteTest.java    |   4 +-
 .../iotdb/tsfile/write/TsFileWriterTest.java       |   2 +-
 .../org/apache/iotdb/tsfile/write/WriteTest.java   |   2 +-
 282 files changed, 2901 insertions(+), 1750 deletions(-)

diff --cc cluster/src/test/java/org/apache/iotdb/cluster/log/applier/MetaLogApplierTest.java
index dcfec31,8f526a3..701c1a4
--- a/cluster/src/test/java/org/apache/iotdb/cluster/log/applier/MetaLogApplierTest.java
+++ b/cluster/src/test/java/org/apache/iotdb/cluster/log/applier/MetaLogApplierTest.java
@@@ -26,11 -26,8 +26,9 @@@ import org.apache.iotdb.cluster.log.log
  import org.apache.iotdb.cluster.log.logtypes.PhysicalPlanLog;
  import org.apache.iotdb.cluster.log.logtypes.RemoveNodeLog;
  import org.apache.iotdb.cluster.rpc.thrift.Node;
 +import org.apache.iotdb.cluster.utils.Constants;
  import org.apache.iotdb.db.exception.StorageEngineException;
  import org.apache.iotdb.db.exception.metadata.MetadataException;
- import org.apache.iotdb.db.exception.metadata.StorageGroupNotSetException;
- import org.apache.iotdb.db.exception.query.QueryProcessException;
  import org.apache.iotdb.db.metadata.PartialPath;
  import org.apache.iotdb.db.qp.physical.sys.CreateTimeSeriesPlan;
  import org.apache.iotdb.db.qp.physical.sys.SetStorageGroupPlan;
@@@ -79,11 -76,10 +77,10 @@@ public class MetaLogApplierTest extend
    }
  
    @Test
-   public void testApplyAddNode()
-       throws QueryProcessException, StorageGroupNotSetException, StorageEngineException {
+   public void testApplyAddNode() {
      nodes.clear();
 -
 -    Node node = new Node("localhost", 1111, 0, 2222, 55560);
 +    // TODO hxd:
 +    Node node = new Node("localhost", 1111, 0, 2222, Constants.RPC_PORT, "localhost");
      AddNodeLog log = new AddNodeLog();
      log.setNewNode(node);
      applier.apply(log);


[iotdb] 02/02: change some user doc

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

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

commit 2cc36014f32c6f76e2e181de8dd9e23fcf27dd6d
Author: HouliangQi <ne...@163.com>
AuthorDate: Fri Feb 26 14:59:26 2021 +0800

    change some user doc
---
 cluster/src/assembly/resources/sbin/start-node.sh  | 38 ++++++------
 .../java/org/apache/iotdb/cluster/ClusterMain.java |  2 +-
 .../iotdb/cluster/config/ClusterDescriptor.java    |  1 -
 docs/UserGuide/Server/Cluster Setup.md             | 67 ++++++++++------------
 docs/zh/UserGuide/Server/Cluster Setup.md          | 67 ++++++++++------------
 .../org/apache/iotdb/db/utils/SerializeUtils.java  |  2 +-
 6 files changed, 78 insertions(+), 99 deletions(-)

diff --git a/cluster/src/assembly/resources/sbin/start-node.sh b/cluster/src/assembly/resources/sbin/start-node.sh
index 5f84110..d64956f 100755
--- a/cluster/src/assembly/resources/sbin/start-node.sh
+++ b/cluster/src/assembly/resources/sbin/start-node.sh
@@ -27,36 +27,33 @@ if [ -z "${IOTDB_HOME}" ]; then
   export IOTDB_HOME="`dirname "$0"`/.."
 fi
 
-IOTDB_CONF=${IOTDB_HOME}/conf
-# IOTDB_LOGS=${IOTDB_HOME}/logs
+enable_printgc=false
+if [ "$#" -ge "1" -a "$1" == "printgc" ]; then
+  enable_printgc=true;
+  shift
+fi
+
+IOTDB_CONF=$1
+if [ -z "${IOTDB_CONF}" ]; then
+  export IOTDB_CONF=${IOTDB_HOME}/conf
+fi
 
 if [ -f "$IOTDB_CONF/iotdb-env.sh" ]; then
-    if [ "$#" -ge "1" -a "$1" == "printgc" ]; then
+    if [ $enable_printgc == "true" ]; then
       . "$IOTDB_CONF/iotdb-env.sh" "printgc"
-      shift
     else
         . "$IOTDB_CONF/iotdb-env.sh"
     fi
+elif [ -f "${IOTDB_HOME}/conf/iotdb-env.sh" ]; then
+    if [ $enable_printgc == "true" ]; then
+      . "${IOTDB_HOME}/conf/iotdb-env.sh" "printgc"
+    else
+      . "${IOTDB_HOME}/conf/iotdb-env.sh"
+    fi
 else
     echo "can't find $IOTDB_CONF/iotdb-env.sh"
 fi
 
-is_conf_path=false
-for arg do
-    shift
-    if [ "$arg" == "-c" ]; then
-        is_conf_path=true
-        continue
-    fi
-
-    if [ $is_conf_path == true ]; then
-        IOTDB_CONF=$arg
-        is_conf_path=false
-        continue
-    fi
-    set -- "$@" "$arg"
-done
-
 CONF_PARAMS="-s "$*
 
 if [ -n "$JAVA_HOME" ]; then
@@ -89,6 +86,7 @@ launch_service()
 	iotdb_parms="$iotdb_parms -DTSFILE_HOME=${IOTDB_HOME}"
 	iotdb_parms="$iotdb_parms -DIOTDB_CONF=${IOTDB_CONF}"
 	iotdb_parms="$iotdb_parms -DCLUSTER_CONF=${IOTDB_CONF}"
+	iotdb_parms="$iotdb_parms -DTSFILE_CONF=${IOTDB_CONF}"
 	iotdb_parms="$iotdb_parms -Dname=iotdb\.IoTDB"
 	exec "$JAVA" $iotdb_parms $IOTDB_JMX_OPTS -cp "$CLASSPATH" "$class" $CONF_PARAMS
 	return $?
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java b/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
index 4332d3c..fd424f5 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/ClusterMain.java
@@ -66,7 +66,7 @@ public class ClusterMain {
     if (args.length < 1) {
       logger.error(
           "Usage: <-s|-a|-r> "
-              + "[-D{} <configure folder>] "
+              + "[-D{} <configure folder>] \n"
               + "-s: start the node as a seed\n"
               + "-a: start the node as a new node\n"
               + "-r: remove the node out of the cluster\n",
diff --git a/cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterDescriptor.java b/cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterDescriptor.java
index 16a181f..2c20c7e 100644
--- a/cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterDescriptor.java
+++ b/cluster/src/main/java/org/apache/iotdb/cluster/config/ClusterDescriptor.java
@@ -123,7 +123,6 @@ public class ClusterDescriptor {
 
   /** load an property file and set TsfileDBConfig variables. */
   private void loadProps() {
-
     String url = getPropsUrl();
     Properties properties = System.getProperties();
     if (url != null) {
diff --git a/docs/UserGuide/Server/Cluster Setup.md b/docs/UserGuide/Server/Cluster Setup.md
index 936c1de..6166fdf 100644
--- a/docs/UserGuide/Server/Cluster Setup.md	
+++ b/docs/UserGuide/Server/Cluster Setup.md	
@@ -35,45 +35,27 @@ To start the service of one of the nodes, you need to execute the following comm
 
 ```bash
 # Unix/OS X
-> nohup sbin/start-node.sh >/dev/null 2>&1 &
-or
-> nohup sbin/start-node.sh -c <conf_path> -internal_meta_port 9003 >/dev/null 2>&1 &
+> nohup sbin/start-node.sh [printgc] [<conf_path>] >/dev/null 2>&1 &
 
 # Windows
 > sbin\start-node.bat
 or
-> sbin\start-node.bat -c <conf_path> -internal_meta_port 9003
+> sbin\start-node.bat <conf_path>
 ```
+`printgc` means whether enable the gc and print gc logs when start the node,  
+`<conf_path>` use the configuration file in the `conf_path` folder to override the default configuration file.
 
-`-c <conf_path>` use the configuration file in the `conf_path` folder to override the default configuration file; 
-`-internal_meta_port 9003` overrides the specific configuration item `internal_meta_port`.
-The currently supported items to overwrite the original configurations when starting IoTDB are the followings :
-`internal_meta_port, internal_data_port, cluster_rpc_port, seed_nodes`. 
-When both exist, the specified configuration item will overwrite the configurations in the configuration file.
-
-## Example of pseudo-distributed scaffolding for 3 nodes and 2 replicas
+## Example of pseudo-distributed scaffolding for 3 nodes and 3 replicas
 ```bash
-# First step (Note that this path is not suitable for Windows MinGW)
 > mvn clean package -pl cluster -am -Dmaven.test.skip=true
-> cp -rf ./cluster/target/cluster-0.11.0-SNAPSHOT ./cluster/target/cluster-0.11.0-SNAPSHOT1
-> cp -rf ./cluster/target/cluster-0.11.0-SNAPSHOT ./cluster/target/cluster-0.11.0-SNAPSHOT2
-> sed -i -e 's/6667/6668/g' ./cluster/target/cluster-0.11.0-SNAPSHOT1/conf/iotdb-engine.properties
-> sed -i -e 's/6667/6669/g' ./cluster/target/cluster-0.11.0-SNAPSHOT2/conf/iotdb-engine.properties
-
-# Second step: Unix/OS X/Windows (git bash or WSL)
-> sed -i -e 's/31999/32000/g' ./cluster/target/cluster-0.11.0-SNAPSHOT1/conf/iotdb-env.sh
-> sed -i -e 's/31999/32001/g' ./cluster/target/cluster-0.11.0-SNAPSHOT2/conf/iotdb-env.sh
+> cp -rf ./cluster/target/cluster-0.12.0-SNAPSHOT ./cluster/target/cluster-0.12.0-SNAPSHOT1
+> cp -rf ./cluster/target/cluster-0.12.0-SNAPSHOT ./cluster/target/cluster-0.12.0-SNAPSHOT2
+
 > chmod -R 777 ./cluster/target/
-> nohup ./cluster/target/cluster-0.11.0-SNAPSHOT/sbin/start-node.sh >/dev/null 2>&1 &
-> nohup ./cluster/target/cluster-0.11.0-SNAPSHOT1/sbin/start-node.sh -internal_meta_port 9005 -internal_data_port 40012 -cluster_rpc_port 6668 >/dev/null 2>&1 &
-> nohup ./cluster/target/cluster-0.11.0-SNAPSHOT2/sbin/start-node.sh -internal_meta_port 9007 -internal_data_port 40014 -cluster_rpc_port 6669 >/dev/null 2>&1 &
-
-# Second step: Windows (MinGW)
-> sed -i -e 's/31999/32000/g'  cluster\target\cluster-0.11.0-SNAPSHOT\conf\iotdb-env.bat
-> sed -i -e 's/31999/32001/g'  cluster\target\cluster-0.11.0-SNAPSHOT\conf\iotdb-env.bat
-> nohup cluster\target\cluster-0.11.0-SNAPSHOT\sbin\start-node.bat 
-> nohup cluster\target\cluster-0.11.0-SNAPSHOT1\sbin\start-node.bat  -internal_meta_port 9005 -internal_data_port 40012 -cluster_rpc_port 6668
-> nohup cluster\target\cluster-0.11.0-SNAPSHOT2\sbin\start-node.bat  -internal_meta_port 9007 -internal_data_port 40014 -cluster_rpc_port 6669
+
+> nohup ./cluster/target/cluster-0.12.0-SNAPSHOT/sbin/start-node.sh  ./cluster/target/test-classes/node1conf/ >/dev/null 2>&1 &
+> nohup ./cluster/target/cluster-0.12.0-SNAPSHOT1/sbin/start-node.sh ./cluster/target/test-classes/node2conf/ >/dev/null 2>&1 &
+> nohup ./cluster/target/cluster-0.12.0-SNAPSHOT2/sbin/start-node.sh ./cluster/target/test-classes/node3conf/ >/dev/null 2>&1 &
 ```
 
 ## OverWrite the configurations of Stand-alone node
@@ -106,6 +88,15 @@ What's more, Users can configure settings of TsFile (the data files), such as th
 For detailed description of the two configuration files `iotdb-engine.properties`, `iotdb-env.sh`/`iotdb-env.bat`, please refer to [Configuration Manual](Config%20Manual.md). 
 The configuration items described below are in the `iotdb-cluster.properties` file.
 
+* internal\_ip
+
+|Name|internal\_ip|
+|:---:|:---|
+|Description|IP address of internal communication between nodes in IOTDB cluster, such as heartbeat, snapshot, raft log, etc|
+|Type|String|
+|Default|127.0.0.1|
+|Effective| After restart system, shall NOT change after cluster is up|
+
 * internal\_meta\_port
 
 |Name|internal\_meta\_port|
@@ -124,22 +115,22 @@ The configuration items described below are in the `iotdb-cluster.properties` fi
 |Default|40010|
 |Effective| After restart system, shall NOT change after cluster is up|
 
-* cluster\_rpc\_port
+* open\_server\_rpc\_port
 
-|Name|cluster\_rpc\_port|
+|Name|open\_server\_rpc\_port|
 |:---:|:---|
-|Description|The port used to communicate with the clients (JDBC, CLI, Session API...), please confirm that the port is not reserved by the system and is not occupied|
-|Type|Int32|
-|Default|6667|
+|Description|whether open port for server module (for debug purpose), if true, the single's server rpc_port will be changed to `rpc_port (in iotdb-engines.properties) + 1`|
+|Type|Boolean|
+|Default|False|
 |Effective| After restart system|
 
 * seed\_nodes
 
 |Name|seed\_nodes|
 |:---:|:---|
-|Description|The address of the nodes in the cluster, `{IP/DOMAIN}:internal_meta_port:internal_data_port:cluster_rpc_port` format, separated by commas; for the pseudo-distributed mode, you can fill in `localhost`, or `127.0.0.1` or mixed, but the real ip address cannot appear; for the distributed mode, real ip or hostname is supported, but `localhost` or `127.0.0.1` cannot appear. When used by `start-node.sh(.bat)`, this configuration means the nodes that will form the initial cluster, s [...]
+|Description|The address of the nodes in the cluster, `{IP/DOMAIN}:internal_meta_port` format, separated by commas; for the pseudo-distributed mode, you can fill in `localhost`, or `127.0.0.1` or mixed, but the real ip address cannot appear; for the distributed mode, real ip or hostname is supported, but `localhost` or `127.0.0.1` cannot appear. When used by `start-node.sh(.bat)`, this configuration means the nodes that will form the initial cluster, so every node that use `start-node.sh [...]
 |Type|String|
-|Default|127.0.0.1:9003:40010:6667,127.0.0.1:9005:40012:6668,127.0.0.1:9007:40014:6669|
+|Default|127.0.0.1:9003,127.0.0.1:9005,127.0.0.1:9007|
 |Effective| After restart system|
 
 * rpc\_thrift\_compression\_enable
@@ -157,7 +148,7 @@ The configuration items described below are in the `iotdb-cluster.properties` fi
 |:---:|:---|
 |Description|Number of cluster replicas of timeseries schema and data. Storage group info is always fully replicated in all nodes.|
 |Type|Int32|
-|Default|2|
+|Default|3|
 |Effective| After restart system, shall NOT change after cluster is up|
 
 * cluster\_name
diff --git a/docs/zh/UserGuide/Server/Cluster Setup.md b/docs/zh/UserGuide/Server/Cluster Setup.md
index 04c13f4..e8181f7 100644
--- a/docs/zh/UserGuide/Server/Cluster Setup.md	
+++ b/docs/zh/UserGuide/Server/Cluster Setup.md	
@@ -31,43 +31,25 @@ __集群模式目前是测试版!请谨慎在生产环境中使用。__
 
 ```bash
 # Unix/OS X
-> nohup sbin/start-node.sh >/dev/null 2>&1 &
-or
-> nohup sbin/start-node.sh -c <conf_path> -internal_meta_port 9003 >/dev/null 2>&1 &
+> nohup sbin/start-node.sh [printgc] [<conf_path>] >/dev/null 2>&1 &
 
 # Windows
 > sbin\start-node.bat
-or
-> sbin\start-node.bat -c <conf_path> -internal_meta_port 9003
 ```
+`printgc`表示在启动的时候,会开启GC日志。
+`<conf_path>`使用`conf_path`文件夹里面的配置文件覆盖默认配置文件。
 
-`-c <conf_path>`使用`conf_path`文件夹里面的配置文件覆盖默认配置文件; `-internal_meta_port 9003`覆盖特定配置项`internal_meta_port`的配置,
-目前支持的启动覆盖原有配置的配置项有:
-`internal_meta_port、internal_data_port、cluster_rpc_port、seed_nodes`。当配置文件和配置项都被指定的时候,指定配置项的配置会覆盖配置文件中的配置。
-
-## 3节点2副本伪分布式搭建示例
+## 3节点3副本伪分布式搭建示例
 ```bash
-# 第一步 (注意以下路径在 Windows MinGW 中并不适用)
 > mvn clean package -pl cluster -am -Dmaven.test.skip=true
-> cp -rf ./cluster/target/cluster-0.11.0-SNAPSHOT ./cluster/target/cluster-0.11.0-SNAPSHOT1
-> cp -rf ./cluster/target/cluster-0.11.0-SNAPSHOT ./cluster/target/cluster-0.11.0-SNAPSHOT2
-> sed -i -e 's/6667/6668/g' ./cluster/target/cluster-0.11.0-SNAPSHOT1/conf/iotdb-engine.properties
-> sed -i -e 's/6667/6669/g' ./cluster/target/cluster-0.11.0-SNAPSHOT2/conf/iotdb-engine.properties
-
-# 第二步: Unix/OS X/Windows (git bash or WSL)
-> sed -i -e 's/31999/32000/g' ./cluster/target/cluster-0.11.0-SNAPSHOT1/conf/iotdb-env.sh
-> sed -i -e 's/31999/32001/g' ./cluster/target/cluster-0.11.0-SNAPSHOT2/conf/iotdb-env.sh
+> cp -rf ./cluster/target/cluster-0.12.0-SNAPSHOT ./cluster/target/cluster-0.12.0-SNAPSHOT1
+> cp -rf ./cluster/target/cluster-0.12.0-SNAPSHOT ./cluster/target/cluster-0.12.0-SNAPSHOT2
+
 > chmod -R 777 ./cluster/target/
-> nohup ./cluster/target/cluster-0.11.0-SNAPSHOT/sbin/start-node.sh >/dev/null 2>&1 &
-> nohup ./cluster/target/cluster-0.11.0-SNAPSHOT1/sbin/start-node.sh -internal_meta_port 9005 -internal_data_port 40012 -cluster_rpc_port 6668 >/dev/null 2>&1 &
-> nohup ./cluster/target/cluster-0.11.0-SNAPSHOT2/sbin/start-node.sh -internal_meta_port 9007 -internal_data_port 40014 -cluster_rpc_port 6669 >/dev/null 2>&1 &
-
-# 第二步: Windows (MinGW)
-> sed -i -e 's/31999/32000/g'  cluster\target\cluster-0.11.0-SNAPSHOT\conf\iotdb-env.bat
-> sed -i -e 's/31999/32001/g'  cluster\target\cluster-0.11.0-SNAPSHOT\conf\iotdb-env.bat
-> nohup cluster\target\cluster-0.11.0-SNAPSHOT\sbin\start-node.bat 
-> nohup cluster\target\cluster-0.11.0-SNAPSHOT1\sbin\start-node.bat  -internal_meta_port 9005 -internal_data_port 40012 -cluster_rpc_port 6668
-> nohup cluster\target\cluster-0.11.0-SNAPSHOT2\sbin\start-node.bat  -internal_meta_port 9007 -internal_data_port 40014 -cluster_rpc_port 6669
+
+> nohup ./cluster/target/cluster-0.12.0-SNAPSHOT/sbin/start-node.sh  ./cluster/target/test-classes/node1conf/ >/dev/null 2>&1 &
+> nohup ./cluster/target/cluster-0.12.0-SNAPSHOT1/sbin/start-node.sh ./cluster/target/test-classes/node2conf/ >/dev/null 2>&1 &
+> nohup ./cluster/target/cluster-0.12.0-SNAPSHOT2/sbin/start-node.sh ./cluster/target/test-classes/node3conf/ >/dev/null 2>&1 &
 ```
 
 ## 被覆盖的单机版选项
@@ -99,6 +81,15 @@ iotdb-engines.properties配置文件中的部分内容会不再生效:
 
 `iotdb-engine.properties`、`iotdb-env.sh`/`iotdb-env.bat` 两个配置文件详细说明请参考[配置手册](Config%20Manual.md),下面描述的配置项是在`iotdb-cluster.properties`文件中的。
 
+* internal\_ip
+
+|名字|internal\_ip|
+|:---:|:---|
+|描述|IOTDB 集群各个节点之间内部通信的IP地址,比如心跳、snapshot快照、raft log等|
+|类型|String|
+|默认值|127.0.0.1|
+|改后生效方式|重启服务器生效,集群建立后不可再修改|
+
 * internal\_meta\_port
 
 |名字|internal\_meta\_port|
@@ -117,22 +108,22 @@ iotdb-engines.properties配置文件中的部分内容会不再生效:
 |默认值|40010|
 |改后生效方式|重启服务器生效,集群建立后不可再修改|
 
-* cluster\_rpc\_port
+* open\_server\_rpc\_port
 
-|名字|cluster\_rpc\_port|
+|名字|open\_server\_rpc\_port|
 |:---:|:---|
-|描述|与客户端(JDBC,Session API, CLI等)通信的端口,请确认该端口不是系统保留端口并且未被占用|
-|类型|Int32|
-|默认值|6667|
-|改后生效方式|重启服务器生效|
+|描述|是否打开单机模块的rpc port,用于调试模式,如果设置为true,则单机模块的rpc port设置为`rpc_port (in iotdb-engines.properties) + 1`|
+|类型|Boolean|
+|默认值|false|
+|改后生效方式|重启服务器生效,集群建立后不可再修改|
 
 * seed\_nodes
 
 |名字|seed\_nodes|
 |:---:|:---|
-|描述|集群中节点的地址,`{IP/DOMAIN}:internal_meta_port:internal_data_port:cluster_rpc_port`格式,用逗号分割;对于伪分布式模式,可以都填写`localhost`,或是`127.0.0.1` 或是混合填写,但是不能够出现真实的ip地址;对于分布式模式,支持填写real ip 或是hostname,但是不能够出现`localhost`或是`127.0.0.1`。当使用`start-node.sh(.bat)`启动节点时,此配置意味着形成初始群集的节点,每个节点的`seed_nodes`应该一致,否则群集将初始化失败;当使用`add-node.sh(.bat)`添加节点到集群中时,此配置项可以是集群中已经存在的任何节点,不需要是用`start-node.sh(bat)`构建初始集群的节点。|
+|描述|集群中节点的地址,`{IP/DOMAIN}:internal_meta_port`格式,用逗号分割;对于伪分布式模式,可以都填写`localhost`,或是`127.0.0.1` 或是混合填写,但是不能够出现真实的ip地址;对于分布式模式,支持填写real ip 或是hostname,但是不能够出现`localhost`或是`127.0.0.1`。当使用`start-node.sh(.bat)`启动节点时,此配置意味着形成初始群集的节点,每个节点的`seed_nodes`应该一致,否则群集将初始化失败;当使用`add-node.sh(.bat)`添加节点到集群中时,此配置项可以是集群中已经存在的任何节点,不需要是用`start-node.sh(bat)`构建初始集群的节点。|
 |类型|String|
-|默认值|127.0.0.1:9003:40010:6667,127.0.0.1:9005:40012:6668,127.0.0.1:9007:40014:6669|
+|默认值|127.0.0.1:9003,127.0.0.1:9005,127.0.0.1:9007|
 |改后生效方式|重启服务器生效|
 
 * rpc\_thrift\_compression\_enable
@@ -150,7 +141,7 @@ iotdb-engines.properties配置文件中的部分内容会不再生效:
 |:---:|:---|
 |描述|集群副本数|
 |类型|Int32|
-|默认值|2|
+|默认值|3|
 |改后生效方式|重启服务器生效,集群建立后不可更改|
 
 * cluster\_name
diff --git a/server/src/main/java/org/apache/iotdb/db/utils/SerializeUtils.java b/server/src/main/java/org/apache/iotdb/db/utils/SerializeUtils.java
index 829f399..40b49f2 100644
--- a/server/src/main/java/org/apache/iotdb/db/utils/SerializeUtils.java
+++ b/server/src/main/java/org/apache/iotdb/db/utils/SerializeUtils.java
@@ -128,7 +128,7 @@ public class SerializeUtils {
       dataOutputStream.writeInt(node.nodeIdentifier);
       dataOutputStream.writeInt(node.dataPort);
       dataOutputStream.writeInt(node.clientPort);
-      byte[] clientIpBytes = node.ip.getBytes();
+      byte[] clientIpBytes = node.clientIp.getBytes();
       dataOutputStream.writeInt(clientIpBytes.length);
       dataOutputStream.write(clientIpBytes);
     } catch (IOException e) {