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/09 03:15:53 UTC

[GitHub] [iotdb] CRZbulabula opened a new pull request, #7944: [IOTDB-4881] Add feature least data region group num

CRZbulabula opened a new pull request, #7944:
URL: https://github.com/apache/iotdb/pull/7944

   In order to improve the efficiency of concurrency write in cluster StorageGroup, we should create some DataRegionGroup after the specified StorageGroup was activated. i.e. Create a DataRegionGroup for each newborn SeriesPartitionSlot for the newly created StorageGroup. The number of this operation is equal to the parameter `least_data_region_group_num` in iotdb-common.properties file.


-- 
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


[GitHub] [iotdb] CRZbulabula commented on pull request #7944: [IOTDB-4881] Add feature least data region group num

Posted by GitBox <gi...@apache.org>.
CRZbulabula commented on PR #7944:
URL: https://github.com/apache/iotdb/pull/7944#issuecomment-1316189190

   The IT will be fixed after [IOTDB-4912](https://issues.apache.org/jira/browse/IOTDB-4912) is merged


-- 
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


[GitHub] [iotdb] Caideyipi commented on a diff in pull request #7944: [IOTDB-4881] Add feature StorageGroup fast activation

Posted by GitBox <gi...@apache.org>.
Caideyipi commented on code in PR #7944:
URL: https://github.com/apache/iotdb/pull/7944#discussion_r1030036934


##########
confignode/src/main/java/org/apache/iotdb/confignode/manager/ClusterSchemaManager.java:
##########
@@ -306,64 +308,73 @@ public TSStatus setTimePartitionInterval(
   }
 
   /**
-   * Only leader use this interface. Adjust the maxSchemaRegionGroupCount and
-   * maxDataRegionGroupCount of each StorageGroup bases on existing cluster resources
+   * Only leader use this interface. Adjust the maxSchemaRegionGroupNum and maxDataRegionGroupNum of
+   * each StorageGroup bases on existing cluster resources
    */
-  public synchronized void adjustMaxRegionGroupCount() {
+  public synchronized void adjustMaxRegionGroupNum() {
     // Get all StorageGroupSchemas
     Map<String, TStorageGroupSchema> storageGroupSchemaMap =
         getMatchedStorageGroupSchemasByName(getStorageGroupNames());
     int dataNodeNum = getNodeManager().getRegisteredDataNodeCount();
     int totalCpuCoreNum = getNodeManager().getTotalCpuCoreCount();
     int storageGroupNum = storageGroupSchemaMap.size();
 
-    AdjustMaxRegionGroupCountPlan adjustMaxRegionGroupCountPlan =
-        new AdjustMaxRegionGroupCountPlan();
+    AdjustMaxRegionGroupNumPlan adjustMaxRegionGroupNumPlan = new AdjustMaxRegionGroupNumPlan();
     for (TStorageGroupSchema storageGroupSchema : storageGroupSchemaMap.values()) {
       try {
-        // Adjust maxSchemaRegionGroupCount.
+        // Adjust maxSchemaRegionGroupNum for each StorageGroup.
         // All StorageGroups share the DataNodes equally.
         // Allocated SchemaRegionGroups are not shrunk.
         int allocatedSchemaRegionGroupCount =
             getPartitionManager()
                 .getRegionCount(storageGroupSchema.getName(), TConsensusGroupType.SchemaRegion);
-        int maxSchemaRegionGroupCount =
+        int maxSchemaRegionGroupNum =
             Math.max(
-                1,
+                // The least number of DataRegionGroup of each StorageGroup is specified
+                // by parameter least_data_region_group_num, which is currently unconfigurable.

Review Comment:
   ```suggestion
                   // by parameter least_schema_region_group_num, which is currently unconfigurable.
   ```



##########
confignode/src/main/java/org/apache/iotdb/confignode/manager/partition/PartitionManager.java:
##########
@@ -492,7 +501,7 @@ public List<TRegionReplicaSet> getAllReplicaSets(String storageGroup) {
    */
   public int getRegionCount(String storageGroup, TConsensusGroupType type)

Review Comment:
   ```suggestion
     public int getRegionGroupCount(String storageGroup, TConsensusGroupType type)
   ```



##########
confignode/src/main/java/org/apache/iotdb/confignode/manager/ClusterSchemaManager.java:
##########
@@ -306,64 +308,73 @@ public TSStatus setTimePartitionInterval(
   }
 
   /**
-   * Only leader use this interface. Adjust the maxSchemaRegionGroupCount and
-   * maxDataRegionGroupCount of each StorageGroup bases on existing cluster resources
+   * Only leader use this interface. Adjust the maxSchemaRegionGroupNum and maxDataRegionGroupNum of
+   * each StorageGroup bases on existing cluster resources
    */
-  public synchronized void adjustMaxRegionGroupCount() {
+  public synchronized void adjustMaxRegionGroupNum() {
     // Get all StorageGroupSchemas
     Map<String, TStorageGroupSchema> storageGroupSchemaMap =
         getMatchedStorageGroupSchemasByName(getStorageGroupNames());
     int dataNodeNum = getNodeManager().getRegisteredDataNodeCount();
     int totalCpuCoreNum = getNodeManager().getTotalCpuCoreCount();
     int storageGroupNum = storageGroupSchemaMap.size();
 
-    AdjustMaxRegionGroupCountPlan adjustMaxRegionGroupCountPlan =
-        new AdjustMaxRegionGroupCountPlan();
+    AdjustMaxRegionGroupNumPlan adjustMaxRegionGroupNumPlan = new AdjustMaxRegionGroupNumPlan();
     for (TStorageGroupSchema storageGroupSchema : storageGroupSchemaMap.values()) {
       try {
-        // Adjust maxSchemaRegionGroupCount.
+        // Adjust maxSchemaRegionGroupNum for each StorageGroup.
         // All StorageGroups share the DataNodes equally.
         // Allocated SchemaRegionGroups are not shrunk.
         int allocatedSchemaRegionGroupCount =
             getPartitionManager()
                 .getRegionCount(storageGroupSchema.getName(), TConsensusGroupType.SchemaRegion);
-        int maxSchemaRegionGroupCount =
+        int maxSchemaRegionGroupNum =
             Math.max(
-                1,
+                // The least number of DataRegionGroup of each StorageGroup is specified

Review Comment:
   ```suggestion
                   // The least number of SchemaRegionGroup of each StorageGroup is specified
   ```



-- 
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


[GitHub] [iotdb] qiaojialin merged pull request #7944: [IOTDB-4881] Add feature StorageGroup fast activation

Posted by GitBox <gi...@apache.org>.
qiaojialin merged PR #7944:
URL: https://github.com/apache/iotdb/pull/7944


-- 
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