You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by mo...@apache.org on 2021/12/07 02:03:37 UTC

[incubator-doris] branch master updated: [community][typo](github) modify PR template (#7310)

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

morningman pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-doris.git


The following commit(s) were added to refs/heads/master by this push:
     new 3b10002  [community][typo](github) modify PR template (#7310)
3b10002 is described below

commit 3b10002536c321852b2842e4e3e46130a82fae2a
Author: jakevin <30...@users.noreply.github.com>
AuthorDate: Tue Dec 7 10:03:28 2021 +0800

    [community][typo](github) modify PR template (#7310)
    
    I found some small problems when I read code. So I add some small enhancement.
    
    1. modify PR template.  Now the template of PR isn't simple and clear. It's useful to refactor it.
    2. some small change (typo, format .....)
---
 .github/PULL_REQUEST_TEMPLATE.md                             |  4 +++-
 fe/fe-core/src/main/java/org/apache/doris/PaloFe.java        |  4 ++--
 .../src/main/java/org/apache/doris/qe/ConnectScheduler.java  | 12 ++++++------
 .../src/main/java/org/apache/doris/qe/SimpleScheduler.java   |  2 +-
 .../src/main/java/org/apache/doris/qe/StmtExecutor.java      | 10 +++++-----
 5 files changed, 17 insertions(+), 15 deletions(-)

diff --git a/.github/PULL_REQUEST_TEMPLATE.md b/.github/PULL_REQUEST_TEMPLATE.md
index d7bc7cc..fa4e084 100644
--- a/.github/PULL_REQUEST_TEMPLATE.md
+++ b/.github/PULL_REQUEST_TEMPLATE.md
@@ -1,6 +1,8 @@
 ## Proposed changes
 
-Describe the big picture of your changes here to communicate to the maintainers why we should accept this pull request. If it fixes a bug or resolves a feature request, be sure to link to that issue.
+Close related #issue (replace it with issue number if it exists).
+
+Describe the overview of changes, and introduce why we need it.
 
 ## Types of changes
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java b/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java
index 2578247..6877820 100755
--- a/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java
@@ -126,9 +126,9 @@ public class PaloFe {
             Catalog.getCurrentCatalog().waitForReady();
 
             // init and start:
-            // 1. QeService for MySQL Server
+            // 1. HttpServer for HTTP Server
             // 2. FeServer for Thrift Server
-            // 3. HttpServer for HTTP Server
+            // 3. QeService for MySQL Server
             QeService qeService = new QeService(Config.query_port, Config.mysql_service_nio_enabled, ExecuteEnv.getInstance().getScheduler());
             FeServer feServer = new FeServer(Config.rpc_port);
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/qe/ConnectScheduler.java b/fe/fe-core/src/main/java/org/apache/doris/qe/ConnectScheduler.java
index 08039da..505cf00 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/qe/ConnectScheduler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/qe/ConnectScheduler.java
@@ -40,9 +40,9 @@ import java.util.concurrent.ScheduledExecutorService;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicInteger;
 
-// 查询请求的调度器
-// 当前的策略比较简单,有请求过来,就为其单独申请一个线程进行服务。
-// TODO(zhaochun): 应当后面考虑本地文件的连接是否可以超过最大连接数
+// The scheduler of query requests
+// Now the strategy is simple, we allocate a thread for it when a request comes.
+// TODO(zhaochun): We should consider if the number of local file connection can >= maximum connections later.
 public class ConnectScheduler {
     private static final Logger LOG = LogManager.getLogger(ConnectScheduler.class);
     private int maxConnections;
@@ -88,7 +88,7 @@ public class ConnectScheduler {
 
         context.setConnectionId(nextConnectionId.getAndAdd(1));
         // no necessary for nio.
-        if(context instanceof NConnectContext){
+        if (context instanceof NConnectContext) {
             return true;
         }
         executor.submit(new LoopHandler(context));
@@ -144,10 +144,10 @@ public class ConnectScheduler {
             // Check auth
             if (!ctx.getQualifiedUser().equals(user) &&
                     !Catalog.getCurrentCatalog().getAuth().checkGlobalPriv(ConnectContext.get(),
-                                                                           PrivPredicate.GRANT)) {
+                            PrivPredicate.GRANT)) {
                 continue;
             }
-            
+
             infos.add(ctx.toThreadInfo());
         }
         return infos;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/qe/SimpleScheduler.java b/fe/fe-core/src/main/java/org/apache/doris/qe/SimpleScheduler.java
index 428b7b1..1031a55 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/qe/SimpleScheduler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/qe/SimpleScheduler.java
@@ -49,7 +49,7 @@ public class SimpleScheduler {
     // backend id -> (try time, reason)
     // There will be multi threads to read and modify this map.
     // But only one thread (UpdateBlacklistThread) will modify the `Pair`.
-    // So using concurrenty map is enough
+    // So using concurrent map is enough
     private static Map<Long, Pair<Integer, String>> blacklistBackends = Maps.newConcurrentMap();
     private static UpdateBlacklistThread updateBlacklistThread;
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/qe/StmtExecutor.java b/fe/fe-core/src/main/java/org/apache/doris/qe/StmtExecutor.java
index 5fc6993..1309016 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/qe/StmtExecutor.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/qe/StmtExecutor.java
@@ -301,10 +301,10 @@ public class StmtExecutor implements ProfileWriter {
 
     // Execute one statement with queryId
     // The queryId will be set in ConnectContext
-    // This queryId will also be send to master FE for exec master only query.
+    // This queryId will also be sent to master FE for exec master only query.
     // query id in ConnectContext will be changed when retry exec a query or master FE return a different one.
     // Exception:
-    //  IOException: talk with client failed.
+    // IOException: talk with client failed.
     public void execute(TUniqueId queryId) throws Exception {
         context.setStartTime();
 
@@ -442,8 +442,8 @@ public class StmtExecutor implements ProfileWriter {
             }
             if (!context.isTxnModel() && parsedStmt instanceof InsertStmt) {
                 InsertStmt insertStmt = (InsertStmt) parsedStmt;
-                // The transaction of a insert operation begin at analyze phase.
-                // So we should abort the transaction at this finally block if it encounter exception.
+                // The transaction of an insert operation begin at analyze phase.
+                // So we should abort the transaction at this finally block if it encounters exception.
                 if (insertStmt.isTransactionBegin() && context.getState().getStateType() == MysqlStateType.ERR) {
                     try {
                         String errMsg = Strings.emptyToNull(context.getState().getErrorMessage());
@@ -1466,7 +1466,7 @@ public class StmtExecutor implements ProfileWriter {
         }
     }
 
-    // process enter cluster
+    // Process enter cluster
     private void handleEnterStmt() {
         final EnterStmt enterStmt = (EnterStmt) parsedStmt;
         try {

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