You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by "didiaode18 (via GitHub)" <gi...@apache.org> on 2023/06/09 01:28:35 UTC

[GitHub] [doris] didiaode18 opened a new pull request, #20617: [Feature](log)friendly hint for creating table failed

didiaode18 opened a new pull request, #20617:
URL: https://github.com/apache/doris/pull/20617

   ## Proposed changes
   
   Issue Number: close #20533
   
   <!--Describe your changes.-->
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at [dev@doris.apache.org](mailto:dev@doris.apache.org) by explaining why you chose the solution you did and what alternatives you considered, etc...
   
   


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1224175322


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   How shall we figure out that the failure is due to really timeout or BE down by the hint msg then? Maybe we should check out BE status here and make the hint clearer.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225263695


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   > > > if some BEs failed, but the majority of them success, can we treat the create as successful ?
   > > 
   > > 
   > > So the conclusion is no, right?
   > 
   > fe will report regularly according to the full amount of tasks of be, and decide which tasks need to be resent and which tasks need to be discarded, So the conclusion is no.
   
   So the result of executing the table is either success or failure, there will be no unknown results, am I right?



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1584028915

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] github-actions[bot] commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600034565

   PR approved by at least one committer and no changes requested.


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229504649


##########
fe/fe-core/src/main/java/org/apache/doris/httpv2/rest/manager/HttpUtils.java:
##########
@@ -113,7 +113,8 @@ private static String executeRequest(HttpRequestBase request) throws IOException
     }
 
     static String parseResponse(String response) {
-        ResponseBody responseEntity = GsonUtils.GSON.fromJson(response, new TypeToken<ResponseBody>() {}.getType());
+        ResponseBody responseEntity = GsonUtils.GSON.fromJson(response, new TypeToken<ResponseBody>() {
+        }.getType());

Review Comment:
   unnecessary format



##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, including BE down, so it might be unnecessary to check BE status anymore.
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
           } else {
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += "Timeout:" + (timeout / 1000) + " seconds. Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, if we should check BE status may depend on the fail status, maybe cancel or internal_error (just the status corresponding to creating table failed when be shutdown).
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               // check be status if necessary
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1588632076

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229646805


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());

Review Comment:
   style recommended.
   
   ```java
   Set<String> downBESet = countDownLatch.getLeftMarks().stream()
                           .map(item -> infoService.getBackend(item.getKey()))
                           .filter(backend -> !backend.isAlive())
                           .map(Backend::getHost)
                           .collect(Collectors.toSet());
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1602778108

   run p1


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1227851891


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,7 +1817,34 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        String ip = "http://" + backend.getHost() + ":" + backend.getBePort() + "/api/health";
+                        try {
+                            HttpUtils.doGet(ip, null);
+                        } catch (Exception e) {
+                            return true;
+                        }
+                        return false;
+                    }

Review Comment:
   agree



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1590401931

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] JNSimba commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "JNSimba (via GitHub)" <gi...@apache.org>.
JNSimba commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1584041678

   run p1


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225262414


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   > > if some BEs failed, but the majority of them success, can we treat the create as successful ?
   > 
   > So the conclusion is no, right?
   
   Processing logic according to the ReportHandler class, fe will report regularly according to the full amount of tasks of be, and decide which tasks need to be resent and which tasks need to be discarded, So the conclusion is no.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225689351


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   > So the result of executing the table is either success or failure, there will be no unknown results,
   
   @yujun777 may means that if the majority replicas for each tablet is created successfully, may we treat the creation as successful? Just like the criteria for loading.
   
    The current implementation does indicate that creation is successful when all replicas are created successfully, or it failed anyway. Maybe we could modify the implementation to achieve the goal if needed.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225690440


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   It is also okay then if u find it hard or unnecessary to do this optimization. Then just make the hint msg clearer so that we could find out the creation failure is due to real timeout, or some BE error including BE crash.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1588646174

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1599999830

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1598411811

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1596386599

   run buildall
   


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1590539778

   run p0


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1590673475

   run p0


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1601972908

   run clickbench


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1602205115

   run clickbench


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] github-actions[bot] commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600458047

   PR approved by at least one committer and no changes requested.


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1595970462

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1584304637

   From the logic of the createPartitionWithIndices method, to traverse the creation tasks of each replica be, either all succeed or all fail. Therefore, the user should be prompted to check the status of be. Or how do I reproduce this operation if I have a doris cluster now?


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] hello-stephen commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "hello-stephen (via GitHub)" <gi...@apache.org>.
hello-stephen commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1602470213

   TeamCity pipeline, clickbench performance test result:
    the sum of best hot time: 36.82 seconds
    stream load tsv:          455 seconds loaded 74807831229 Bytes, about 156 MB/s
    stream load json:         24 seconds loaded 2358488459 Bytes, about 93 MB/s
    stream load orc:          57 seconds loaded 1101869774 Bytes, about 18 MB/s
    stream load parquet:          28 seconds loaded 861443392 Bytes, about 29 MB/s
    insert into select:          70.3 seconds inserted 10000000 Rows, about 142K ops/s
    https://doris-community-test-1308700295.cos.ap-hongkong.myqcloud.com/tmp/20230622112403_clickbench_pr_166585.html


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1591281147

   Actually there are too many unnecessary format change, especially in InternalCatalog, which make it hard to locate changes. Would u mind reverting these unrelated format change?


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, including BE down.
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               // check be status if necessary
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225262414


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   > > if some BEs failed, but the majority of them success, can we treat the create as successful ?
   > 
   > So the conclusion is no, right?
   
   fe will report regularly according to the full amount of tasks of be, and decide which tasks need to be resent and which tasks need to be discarded, So the conclusion is no.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1584201140

   cc @TangSiyang2001 


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1593205667

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1605796969

   run p1


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1584105623

   run p1


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, including BE down, so it might be unnecessary to check BE status anymore.
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
           } else {
                errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, including BE down, so it might be unnecessary to check BE status anymore.
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229646805


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());

Review Comment:
   style recommended.
   
   ```java
   Set<String> downBESet = 
                           countDownLatch.getLeftMarks().stream()
                                   .map(item -> infoService.getBackend(item.getKey()))
                                   .filter(backend -> !backend.isAlive()).map(Backend::getHost)
                                   .collect(Collectors.toSet());
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1593225486

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1596426072

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] github-actions[bot] commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600027752

   PR approved by at least one committer and no changes requested.


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600027324

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, whether we should check BE status may depend on the fail status, maybe cancel or internal_error (just the status corresponding to creating table failed when be shutdown).
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               if (countDownLatch.getStatus() == XX) {
                   // check be status only when necessary.
                   
               }
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] JNSimba commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "JNSimba (via GitHub)" <gi...@apache.org>.
JNSimba commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600027486

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1602436785

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] JNSimba commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "JNSimba (via GitHub)" <gi...@apache.org>.
JNSimba commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1583816340

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225259145


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   Yes I agree with you that we should give users a more explicit be status.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1584227713

   >  if some BEs failed, but the majority of them success, can we treat the create as successful ?
   
   So the conclusion is no, right?


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] github-actions[bot] commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1596388699

   PR approved by anyone and no changes requested.


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1596036367

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] github-actions[bot] commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1596447797

   PR approved by at least one committer and no changes requested.


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1227785595


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,7 +1817,34 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        String ip = "http://" + backend.getHost() + ":" + backend.getBePort() + "/api/health";
+                        try {
+                            HttpUtils.doGet(ip, null);
+                        } catch (Exception e) {
+                            return true;
+                        }
+                        return false;
+                    }

Review Comment:
   Maybe we could make use of `backend.isAlive()` to check alive BE and no need to ping here.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, whether we should check BE status may depend on the fail status, maybe cancel or internal_error (just the status corresponding to creating table failed when be shutdown).
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch. No need to check timeout by BE status here.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               if (countDownLatch.getStatus() == XX) {
                   // check be status only when necessary.
                   
               }
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, if we should check BE status may depend on the fail status, maybe cancel or internal_error (just the status corresponding to creating table failed when be shutdown).
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               if (countDownLatch.getStatus() == XX) {
                   // check be status only when necessary.
                   
               }
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, if we should check BE status may depend on the fail status, maybe cancel or internal_error (just the status corresponding to creating table failed when be shutdown).
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               // check be status if necessary, and just print down BE list.
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229646805


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());

Review Comment:
   style recommended.
   
   ```java
   Set<String> downBeSet = countDownLatch.getLeftMarks().stream()
                           .map(item -> infoService.getBackend(item.getKey()))
                           .filter(backend -> !backend.isAlive())
                           .map(Backend::getHost)
                           .collect(Collectors.toSet());
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229599579


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());
+
+                if (null != allBEHost || allBEHost.size() != 0) {
+                    if (null != downBEList || downBEList.size() != 0) {
+                        allBEHost.removeAll(downBEList);
+                    }
+                    String timeoutBE = StringUtils.join(allBEHost, ",");
+                    errMsg += "Failed to create partition[" + partitionName + "] in " + timeoutBE + ". Timeout:" + (
+                            timeout / 1000) + " seconds.";
+                }

Review Comment:
   Can be implemented more concisely.
   
   `!countDownLatch.getStatus().ok()` means agent task failed, and the correct error msg in detailed will be set, including BE down, so it might be unnecessary to check BE status anymore.
   
   `!ok` can be treated as real timeout. So just move the Timeout related msg to that branch.
   
   Something like that:
   
   ```java
   if (!ok || !countDownLatch.getStatus().ok()) {
           errMsg = "Failed to create partition[" + partitionName + "].";
           // clear tasks
           AgentTaskQueue.removeBatchTask(batchTask, TTaskType.CREATE);
   
           if (!countDownLatch.getStatus().ok()) {
               errMsg += " Error: " + countDownLatch.getStatus().getErrorMsg();
               // check be status if necessary
           } else {
               errMsg += "Timeout:" + (timeout / 1000) + " seconds."
               List<Entry<Long, Long>> unfinishedMarks = countDownLatch.getLeftMarks();
               // only show at most 3 results
               List<Entry<Long, Long>> subList = unfinishedMarks.subList(0, Math.min(unfinishedMarks.size(), 3));
               if (!subList.isEmpty()) {
                   errMsg += " Unfinished mark: "
                           + Joiner.on(", ").join(subList);
               }
           }
           LOG.warn(errMsg);
           throw new DdlException(errMsg);
   }
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] JNSimba merged pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "JNSimba (via GitHub)" <gi...@apache.org>.
JNSimba merged PR #20617:
URL: https://github.com/apache/doris/pull/20617


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1605240569

   run p1


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1602010141

   run clickbench


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1591591637

   > Actually there are too many unnecessary format change, especially in InternalCatalog, which make it hard to locate changes for reviewers. Would u mind reverting these unrelated format change?
   
   Thank you for your suggestion, I will re-edit the code and submit it when I have time


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225689351


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   > So the result of executing the table is either success or failure, there will be no unknown results,
   
   @yujun777 may mean that if the majority replicas for each tablet is created successfully, may we treat the creation as successful? Just like the criteria for loading.
   
    The current implementation does indicate that creation is successful when all replicas are created successfully, or it failed anyway. Maybe we could modify the implementation to achieve the goal if needed.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1229646805


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,11 +1816,35 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        return !backend.isAlive();
+                    }
+                }).map(Backend::getHost).collect(Collectors.toList());

Review Comment:
   style recommended.
   
   ```java
   Set<String> downBESet = countDownLatch.getLeftMarks().stream()
                           .map(item -> infoService.getBackend(item.getKey()))
                           .filter(backend -> !backend.isAlive()).map(Backend::getHost)
                           .collect(Collectors.toSet());
   ```



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1227806977


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,7 +1817,34 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";

Review Comment:
   Moreover, I think we could treat `!ok` as timeout, and `!countDownLatch.getStatus().ok()` as BE down.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1227785595


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,7 +1817,34 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        String ip = "http://" + backend.getHost() + ":" + backend.getBePort() + "/api/health";
+                        try {
+                            HttpUtils.doGet(ip, null);
+                        } catch (Exception e) {
+                            return true;
+                        }
+                        return false;
+                    }

Review Comment:
   Maybe we could make use of https://github.com/apache/doris/blob/2dddab03a1a0c73325159c31f5c23653ad63f69c/fe/fe-core/src/main/java/org/apache/doris/system/SystemInfoService.java#L368-L383 
   to check alive BE and no need to ping here.



##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,7 +1817,34 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";

Review Comment:
   Moreover, I think we could treat `!ok` as timeout, and `!countDownLatch.getStatus().ok()` as BE down.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] TangSiyang2001 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "TangSiyang2001 (via GitHub)" <gi...@apache.org>.
TangSiyang2001 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1227785595


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1815,7 +1817,34 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                SystemInfoService infoService = Env.getCurrentSystemInfo();
+                List<String> allBEHost = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey()).getHost();
+                }).distinct().collect(Collectors.toList());
+                List<String> downBEList = countDownLatch.getLeftMarks().stream().map(item -> {
+                    return infoService.getBackend(item.getKey());
+                }).distinct().filter(new Predicate<Backend>() {
+                    @Override
+                    public boolean test(Backend backend) {
+                        String ip = "http://" + backend.getHost() + ":" + backend.getBePort() + "/api/health";
+                        try {
+                            HttpUtils.doGet(ip, null);
+                        } catch (Exception e) {
+                            return true;
+                        }
+                        return false;
+                    }

Review Comment:
   Maybe we could make use of `backend.isAlive()`
   to check alive BE and no need to ping here.



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1597959248

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1603607587

   run p1


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] github-actions[bot] commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600245846

   PR approved by at least one committer and no changes requested.


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600462915

   run buildall


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1600744193

   run clickbench


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on PR #20617:
URL: https://github.com/apache/doris/pull/20617#issuecomment-1601958299

   run clickbench


-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org


[GitHub] [doris] didiaode18 commented on a diff in pull request #20617: [Feature](log)friendly hint for creating table failed

Posted by "didiaode18 (via GitHub)" <gi...@apache.org>.
didiaode18 commented on code in PR #20617:
URL: https://github.com/apache/doris/pull/20617#discussion_r1225263695


##########
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalCatalog.java:
##########
@@ -1799,7 +1799,7 @@ private Partition createPartitionWithIndices(String clusterName, long dbId, long
             }
 
             if (!ok || !countDownLatch.getStatus().ok()) {
-                errMsg = "Failed to create partition[" + partitionName + "]. Timeout:" + (timeout / 1000) + " seconds.";
+                errMsg = "The BE is not available,please check BE status!";

Review Comment:
   > > > if some BEs failed, but the majority of them success, can we treat the create as successful ?
   > > 
   > > 
   > > So the conclusion is no, right?
   > 
   > fe will report regularly according to the full amount of tasks of be, and decide which tasks need to be resent and which tasks need to be discarded, So the conclusion is no.
   
   So the result of executing the table is either success or failure, there will be no unknown results, 



-- 
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: commits-unsubscribe@doris.apache.org

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


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org