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 2021/07/12 08:32:20 UTC

[GitHub] [iotdb] LebronAl opened a new pull request #3538: [IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

LebronAl opened a new pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538


   see [jira1488](https://issues.apache.org/jira/browse/IOTDB-1488) and it's parent [jira1487](https://issues.apache.org/jira/browse/IOTDB-1487)


-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668362261



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       >this method can only refresh one client, the other 4 clients can not be refreshed.
   No. Normal `getClient` will get a client from deque's tail and then push back to the tail, so the client in deque's tail is most likely to be used a lot but the client in deque's head is mostly likely to be not used for a long time, so `refreshClientOnce` will get a client from deque's head and then push back to deque's tail.




-- 
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] sonarcloud[bot] commented on pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
sonarcloud[bot] commented on pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#issuecomment-878119318






-- 
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] wangchao316 commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
wangchao316 commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r667840027



##########
File path: thrift-cluster/src/main/thrift/cluster.thrift
##########
@@ -336,7 +338,9 @@ service RaftService {
   * When a follower finds that it already has a file in a snapshot locally, it calls this
   * interface to notify the leader to remove the associated hardlink.
   **/
-  void removeHardLink(1: string hardLinkPath)
+  void removeHardLink(1:string hardLinkPath)
+
+  void RefreshConnection(1:RefreshReuqest request)

Review comment:
       hi , I have a little question,  what does  RefreshConnection() do?    which is an empty implementation in MetaClusterServer and DataClusterServer.   if have a use, we can use refreshConnection. generate, Method Name Camel Command Format. 

##########
File path: thrift-cluster/src/main/thrift/cluster.thrift
##########
@@ -336,7 +338,9 @@ service RaftService {
   * When a follower finds that it already has a file in a snapshot locally, it calls this
   * interface to notify the leader to remove the associated hardlink.
   **/
-  void removeHardLink(1: string hardLinkPath)
+  void removeHardLink(1:string hardLinkPath)
+
+  void RefreshConnection(1:RefreshReuqest request)

Review comment:
       Thanks. I get it.

##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::RefreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void RefreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          RefreshClientOnceAsync(receiver);
+        } else {
+          RefreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }
+
+  private void RefreshClientOnceSync(Node receiver) {
+    RaftService.Client client;
+    try {
+      client =
+          getClientProvider()
+              .getSyncDataClientForRefresh(receiver, RaftServer.getWriteOperationTimeoutMS());
+    } catch (TException e) {
+      return;
+    }
+    try {
+      RefreshReuqest req = new RefreshReuqest();
+      client.refreshConnection(req);
+    } catch (TException e) {
+      logger.warn("encounter refreshing client timeout, throw broken connection", e);
+      // the connection may be broken, close it to avoid it being reused
+      client.getInputProtocol().getTransport().close();
+    } finally {
+      ClientUtils.putBackSyncClient(client);
+    }
+  }
+
+  private void RefreshClientOnceAsync(Node receiver) {

Review comment:
       the same..




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668368806



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       You are right. I have checked the source code in `ArrayDeque`. I should use `pollLast` rather than `poll`. I'll go back to the oven and make myself again




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668362261



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       >this method can only refresh one client, the other 4 clients can not be refreshed.
   Normal `getClient` will get a client from deque's tail and then push back to the tail, so the client in deque's tail is most likely to be used a lot but the client in deque's head isn't mostly likely to be used for a long time, so `refreshClientOnce` will get a client from deque's head and then push back to deque's tail.




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668364564



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       It looks like I might have misunderstood `pop` and `poll` in deque, I will check this :)




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r667864510



##########
File path: thrift-cluster/src/main/thrift/cluster.thrift
##########
@@ -336,7 +338,9 @@ service RaftService {
   * When a follower finds that it already has a file in a snapshot locally, it calls this
   * interface to notify the leader to remove the associated hardlink.
   **/
-  void removeHardLink(1: string hardLinkPath)
+  void removeHardLink(1:string hardLinkPath)
+
+  void RefreshConnection(1:RefreshReuqest request)

Review comment:
       For the `refreshConnection` rpc, It's just a simple implementation of application layer heartbeat preservation mechanism for long TCP connections.  For the detailed reason, you can refer to [jira1487](https://issues.apache.org/jira/browse/IOTDB-1487).
   
   For the Camel Command Format, It's my fault and I will fix this. thanks for your reminding!

##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::RefreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void RefreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          RefreshClientOnceAsync(receiver);
+        } else {
+          RefreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }
+
+  private void RefreshClientOnceSync(Node receiver) {
+    RaftService.Client client;
+    try {
+      client =
+          getClientProvider()
+              .getSyncDataClientForRefresh(receiver, RaftServer.getWriteOperationTimeoutMS());
+    } catch (TException e) {
+      return;
+    }
+    try {
+      RefreshReuqest req = new RefreshReuqest();
+      client.refreshConnection(req);
+    } catch (TException e) {
+      logger.warn("encounter refreshing client timeout, throw broken connection", e);
+      // the connection may be broken, close it to avoid it being reused
+      client.getInputProtocol().getTransport().close();
+    } finally {
+      ClientUtils.putBackSyncClient(client);
+    }
+  }
+
+  private void RefreshClientOnceAsync(Node receiver) {

Review comment:
       fixed




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668362261



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       >this method can only refresh one client, the other 4 clients can not be refreshed.
   
   No. Normal `getClient` will get a client from deque's tail and then push back to the tail, so the client in deque's tail is most likely to be used a lot but the client in deque's head is mostly likely to be not used for a long time, so `refreshClientOnce` will get a client from deque's head and then push back to deque's tail.




-- 
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] mychaow commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
mychaow commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r667746123



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -163,6 +165,12 @@
    */
   private static final int REPORT_INTERVAL_SEC = 10;
 
+  /**
+   * every "REFRESH_CLIENT_SEC" seconds, a dataClientRefresher thread will try to refresh one thrift
+   * connection for each nodes other than itself.
+   */
+  private static final int REFRESH_CLIENT_SEC = 1;

Review comment:
       Why do you set default value to one? It seems too frequent.




-- 
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] mychaow commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
mychaow commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r667748080



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -163,6 +165,12 @@
    */
   private static final int REPORT_INTERVAL_SEC = 10;
 
+  /**
+   * every "REFRESH_CLIENT_SEC" seconds, a dataClientRefresher thread will try to refresh one thrift
+   * connection for each nodes other than itself.
+   */
+  private static final int REFRESH_CLIENT_SEC = 1;

Review comment:
       And could you please add some descriptions in jira 1488?




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668362261



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       >this method can only refresh one client, the other 4 clients can not be refreshed.
   
   Normal `getClient` will get a client from deque's tail and then push back to the tail, so the client in deque's tail is most likely to be used a lot but the client in deque's head isn't mostly likely to be used for a long time, so `refreshClientOnce` will get a client from deque's head and then push back to deque's tail.




-- 
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] LebronAl commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
LebronAl commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668362261



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       >this method can only refresh one client, the other 4 clients can not be refreshed.
   
   No. Normal `getClient` will get a client from deque's tail and then push back to the tail, so the client in deque's tail is most likely to be used a lot but the client in deque's head isn't mostly likely to be used for a long time, so `refreshClientOnce` will get a client from deque's head and then push back to deque's tail.




-- 
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] neuyilan commented on a change in pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
neuyilan commented on a change in pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#discussion_r668356202



##########
File path: cluster/src/main/java/org/apache/iotdb/cluster/server/member/MetaGroupMember.java
##########
@@ -460,6 +481,57 @@ private void threadTaskInit() {
         CLEAN_HARDLINK_INTERVAL_SEC,
         CLEAN_HARDLINK_INTERVAL_SEC,
         TimeUnit.SECONDS);
+    dataClientRefresher.scheduleAtFixedRate(
+        this::refreshClientOnce, REFRESH_CLIENT_SEC, REFRESH_CLIENT_SEC, TimeUnit.SECONDS);
+  }
+
+  private void refreshClientOnce() {
+    for (Node receiver : allNodes) {
+      if (!receiver.equals(thisNode)) {
+        if (ClusterDescriptor.getInstance().getConfig().isUseAsyncServer()) {
+          refreshClientOnceAsync(receiver);
+        } else {
+          refreshClientOnceSync(receiver);
+        }
+      }
+    }
+  }

Review comment:
       Good job.
   But I have some issues,  I think the `refreshClientOnce` can not **refresh** all clients in the client pool, because for one node receiver, there will be some clients, so this method can just fresh one client for one receiver node? for example, if the receiver node1 has 5 clients in the client pool, this method can only refresh one client, the other 4 clients can not be refreshed.




-- 
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] HTHou merged pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
HTHou merged pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538


   


-- 
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] sonarcloud[bot] removed a comment on pull request #3538: [To rel/0.12][IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module

Posted by GitBox <gi...@apache.org>.
sonarcloud[bot] removed a comment on pull request #3538:
URL: https://github.com/apache/iotdb/pull/3538#issuecomment-878119318






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