You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@iotdb.apache.org by GitBox <gi...@apache.org> on 2022/11/27 06:03:49 UTC

[GitHub] [iotdb] qiaojialin commented on a diff in pull request #8199: [IOTDB-5058] Add custom RegionGroup extension policy

qiaojialin commented on code in PR #8199:
URL: https://github.com/apache/iotdb/pull/8199#discussion_r1032871933


##########
confignode/src/main/java/org/apache/iotdb/confignode/conf/ConfigNodeConfig.java:
##########
@@ -56,38 +57,51 @@ public class ConfigNodeConfig {
   /** Schema region consensus protocol */
   private String schemaRegionConsensusProtocolClass = ConsensusFactory.RATIS_CONSENSUS;
 
-  /** The maximum number of SchemaRegion expected to be managed by each DataNode. */
-  private double schemaRegionPerDataNode = 1.0;
+  /** Default number of SchemaRegion replicas */
+  private int schemaReplicationFactor = 1;
 
   /** Data region consensus protocol */
   private String dataRegionConsensusProtocolClass = ConsensusFactory.IOT_CONSENSUS;
 
-  /** The maximum number of DataRegion expected to be managed by each DataNode. */
-  private double dataRegionPerProcessor = 0.5;
+  /** Default number of DataRegion replicas */
+  private int dataReplicationFactor = 1;
+
+  /** Number of SeriesPartitionSlots per StorageGroup */
+  private int seriesPartitionSlotNum = 10000;

Review Comment:
   seriesSlotNum



##########
node-commons/src/assembly/resources/conf/iotdb-common.properties:
##########
@@ -73,20 +73,35 @@
 # 4. SDBMHashExecutor
 # Also, if you want to implement your own SeriesPartition executor, you can inherit the SeriesPartitionExecutor class and
 # modify this parameter to correspond to your Java class
-# Datatype: string
+# Datatype: String
 # series_partition_executor_class=org.apache.iotdb.commons.partition.executor.hash.BKDRHashExecutor
 
-# The maximum number of SchemaRegion expected to be managed by each DataNode.
-# Notice: Since each StorageGroup requires at least one SchemaRegion to manage its schema,
-# this parameter doesn't limit the number of SchemaRegions when there are too many StorageGroups.
-# Datatype: double
-# schema_region_per_data_node=1.0
 
-# The maximum number of DataRegion expected to be managed by each processor.
-# Notice: Since each StorageGroup requires at least two DataRegions to manage its data,
-# this parameter doesn't limit the number of DataRegions when there are too many StorageGroups.
-# Datatype: double
-# data_region_per_processor=0.5
+# The maximum number of SchemaRegions expected to be managed by each DataNode.
+# Notice: Since each Database requires at least one SchemaRegionGroup to manage its schema,
+# this parameter doesn't limit the number of SchemaRegions when there are too many Databases.
+# Default is equal to the schema_replication_factor.
+# Datatype: Double
+# schema_region_per_data_node=
+
+# The policy of extension DataRegionGroup for each Database.
+# These policies are currently supported:
+# 1. CUSTOM(Each Database will allocate data_region_group_per_database DataRegionGroups as soon as created)
+# 2. AUTO(Each Database will automatically extend DataRegionGroups based on the data it has)
+# Datatype: String
+# data_region_group_extension_policy=AUTO
+
+# The number of DataRegionGroups for each Database when using CUSTOM data_region_group_extension_policy.
+# Notice: Each Database will allocate data_region_group_per_database DataRegionGroups as soon as created.
+# Datatype: Integer
+# data_region_group_per_database=10

Review Comment:
   change to  1



##########
confignode/src/main/java/org/apache/iotdb/confignode/conf/ConfigNodeConfig.java:
##########
@@ -56,38 +57,51 @@ public class ConfigNodeConfig {
   /** Schema region consensus protocol */
   private String schemaRegionConsensusProtocolClass = ConsensusFactory.RATIS_CONSENSUS;
 
-  /** The maximum number of SchemaRegion expected to be managed by each DataNode. */
-  private double schemaRegionPerDataNode = 1.0;
+  /** Default number of SchemaRegion replicas */
+  private int schemaReplicationFactor = 1;
 
   /** Data region consensus protocol */
   private String dataRegionConsensusProtocolClass = ConsensusFactory.IOT_CONSENSUS;
 
-  /** The maximum number of DataRegion expected to be managed by each DataNode. */
-  private double dataRegionPerProcessor = 0.5;
+  /** Default number of DataRegion replicas */
+  private int dataReplicationFactor = 1;
+
+  /** Number of SeriesPartitionSlots per StorageGroup */
+  private int seriesPartitionSlotNum = 10000;
+
+  /** SeriesPartitionSlot executor class */
+  private String seriesPartitionExecutorClass =
+      "org.apache.iotdb.commons.partition.executor.hash.BKDRHashExecutor";
+
+  /** The maximum number of SchemaRegions expected to be managed by each DataNode. */
+  private double schemaRegionPerDataNode = schemaReplicationFactor;
+
+  /** The policy of extension DataRegionGroup for each Database. */
+  private DataRegionGroupExtensionPolicy dataRegionGroupExtensionPolicy =
+      DataRegionGroupExtensionPolicy.AUTO;
+
+  /** The number of DataRegionGroups for each Database */
+  private int dataRegionGroupPerDatabase = 10;

Review Comment:
   change to 1



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscribe@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org