You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by yi...@apache.org on 2022/05/23 04:11:06 UTC

[incubator-doris] branch master updated: Fix some typos in fe/. (#9682)

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

yiguolei 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 77297bb7ee Fix some typos in fe/. (#9682)
77297bb7ee is described below

commit 77297bb7eeb3c3a52c026a78f45c57d0bd0d4ed6
Author: Shuangchi He <34...@users.noreply.github.com>
AuthorDate: Mon May 23 12:11:01 2022 +0800

    Fix some typos in fe/. (#9682)
---
 fe/fe-core/src/main/java/org/apache/doris/analysis/RevokeStmt.java    | 2 +-
 fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java      | 2 +-
 fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java           | 2 +-
 fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java       | 2 +-
 .../src/main/java/org/apache/doris/httpv2/rest/UploadAction.java      | 2 +-
 fe/fe-core/src/main/java/org/apache/doris/load/LoadChecker.java       | 2 +-
 fe/fe-core/src/main/java/org/apache/doris/mysql/MysqlPassword.java    | 2 +-
 .../src/main/java/org/apache/doris/planner/SingleNodePlanner.java     | 2 +-
 fe/fe-core/src/main/java/org/apache/doris/planner/SortNode.java       | 4 ++--
 fe/fe-core/src/test/java/org/apache/doris/utframe/MockedFrontend.java | 2 +-
 .../src/main/java/org/apache/doris/load/loadv2/dpp/SparkDpp.java      | 2 +-
 11 files changed, 12 insertions(+), 12 deletions(-)

diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/RevokeStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/RevokeStmt.java
index 9d2ce60c7c..05e229d1a6 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/RevokeStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/RevokeStmt.java
@@ -100,7 +100,7 @@ public class RevokeStmt extends DdlStmt {
         } else {
             // TODO(wyb): spark-load
             if (!Config.enable_spark_load) {
-                throw new AnalysisException("REVOKE ON RESOURCE is comming soon");
+                throw new AnalysisException("REVOKE ON RESOURCE is coming soon");
             }
             resourcePattern.analyze();
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java
index f64af5449f..af8463e95d 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java
@@ -260,7 +260,7 @@ public class TableRef implements ParseNode, Writable {
     }
 
     /**
-     * Return the list of of materialized tuple ids from the TableRef.
+     * Return the list of materialized tuple ids from the TableRef.
      * This method should only be called after the TableRef has been analyzed.
      */
     public List<TupleId> getMaterializedTupleIds() {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java
index 758e65e8d4..2a522baa3a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java
@@ -660,7 +660,7 @@ public abstract class Type {
      * For datetime types this is the length in characters of the String representation
      * (assuming the maximum allowed precision of the fractional seconds component).
      * For binary data this is the length in bytes.
-     * Null is returned for for data types where the column size is not applicable.
+     * Null is returned for data types where the column size is not applicable.
      */
     public Integer getColumnSize() {
         if (!isScalarType()) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java b/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java
index d3ffad3760..39b705fa64 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java
@@ -947,7 +947,7 @@ public enum ErrorCode {
             "past and ON COMPLETION NOT PRESERVE is set. The event was dropped immediately after creation."),
     ERR_EVENT_CANNOT_ALTER_IN_THE_PAST(1589, new byte[]{'H', 'Y', '0', '0', '0'}, "Event execution time is in the " +
             "past and ON COMPLETION NOT PRESERVE is set. The event was dropped immediately after creation."),
-    ERR_SLAVE_INCIDENT(1590, new byte[]{'H', 'Y', '0', '0', '0'}, "The incident %s occured on the master. Message: %s"),
+    ERR_SLAVE_INCIDENT(1590, new byte[]{'H', 'Y', '0', '0', '0'}, "The incident %s occurred on the master. Message: %s"),
     ERR_NO_PARTITION_FOR_GIVEN_VALUE_SILENT(1591, new byte[]{'H', 'Y', '0', '0', '0'}, "Table has no partition for " +
             "some existing values"),
     ERR_BINLOG_UNSAFE_STATEMENT(1592, new byte[]{'H', 'Y', '0', '0', '0'}, "Unsafe statement written to the binary " +
diff --git a/fe/fe-core/src/main/java/org/apache/doris/httpv2/rest/UploadAction.java b/fe/fe-core/src/main/java/org/apache/doris/httpv2/rest/UploadAction.java
index b2aa3bf934..adb9d7d9d3 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/httpv2/rest/UploadAction.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/httpv2/rest/UploadAction.java
@@ -165,7 +165,7 @@ public class UploadAction extends RestBaseController {
 
     /**
      * Get all uploaded file or specified file
-     * If preview is true, also return the the preview of the file
+     * If preview is true, also return the preview of the file
      * @param ns
      * @param dbName
      * @param tblName
diff --git a/fe/fe-core/src/main/java/org/apache/doris/load/LoadChecker.java b/fe/fe-core/src/main/java/org/apache/doris/load/LoadChecker.java
index 4f14b63365..3e79763ce9 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/load/LoadChecker.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/load/LoadChecker.java
@@ -370,7 +370,7 @@ public class LoadChecker extends MasterDaemon {
             OlapTable table = (OlapTable) db.getTableNullable(tableId);
             if (table == null) {
                 LOG.warn("table does not exist. id: {}", tableId);
-                // if table is dropped during load, the the job is failed
+                // if table is dropped during load, the job is failed
                 return null;
             }
             TableLoadInfo tableLoadInfo = tableEntry.getValue();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/mysql/MysqlPassword.java b/fe/fe-core/src/main/java/org/apache/doris/mysql/MysqlPassword.java
index 5d2f277ae7..64f1a026a2 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/mysql/MysqlPassword.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/mysql/MysqlPassword.java
@@ -110,7 +110,7 @@ public class MysqlPassword {
     }
 
     // Check that scrambled message corresponds to the password; the function
-    // is used by server to check that recieved reply is authentic.
+    // is used by server to check that received reply is authentic.
     // This function does not check lengths of given strings: message must be
     // null-terminated, reply and hash_stage2 must be at least SHA1_HASH_SIZE
     // long (if not, something fishy is going on).
diff --git a/fe/fe-core/src/main/java/org/apache/doris/planner/SingleNodePlanner.java b/fe/fe-core/src/main/java/org/apache/doris/planner/SingleNodePlanner.java
index b8ac8e7d7b..b6aec38c8e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/planner/SingleNodePlanner.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/planner/SingleNodePlanner.java
@@ -1378,7 +1378,7 @@ public class SingleNodePlanner {
             rootNode.setWithoutTupleIsNullOutputSmap(outputSmap);
             // Exprs against non-matched rows of an outer join should always return NULL.
             // Make the rhs exprs of the output smap nullable, if necessary. This expr wrapping
-            // must be performed on the composed smap, and not on the the inline view's smap,
+            // must be performed on the composed smap, and not on the inline view's smap,
             // because the rhs exprs must first be resolved against the physical output of
             // 'planRoot' to correctly determine whether wrapping is necessary.
             List<Expr> nullableRhs = TupleIsNullPredicate.wrapExprs(
diff --git a/fe/fe-core/src/main/java/org/apache/doris/planner/SortNode.java b/fe/fe-core/src/main/java/org/apache/doris/planner/SortNode.java
index 4da0fff5b1..3fb3800a05 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/planner/SortNode.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/planner/SortNode.java
@@ -254,8 +254,8 @@ public class SortNode extends PlanNode {
 
         // Remap the ordering exprs to the tuple materialized by this sort node. The mapping
         // is a composition of the childSmap and the outputSmap_ because the child node may
-        // have also remapped its input (e.g., as in a a series of (sort->analytic)* nodes).
-        // Parent nodes have have to do the same so set the composition as the outputSmap_.
+        // have also remapped its input (e.g., as in a series of (sort->analytic)* nodes).
+        // Parent nodes have to do the same so set the composition as the outputSmap_.
         outputSmap = ExprSubstitutionMap.compose(childSmap, outputSmap, analyzer);
         info.substituteOrderingExprs(outputSmap, analyzer);
 
diff --git a/fe/fe-core/src/test/java/org/apache/doris/utframe/MockedFrontend.java b/fe/fe-core/src/test/java/org/apache/doris/utframe/MockedFrontend.java
index 67820328e8..37346b2b15 100644
--- a/fe/fe-core/src/test/java/org/apache/doris/utframe/MockedFrontend.java
+++ b/fe/fe-core/src/test/java/org/apache/doris/utframe/MockedFrontend.java
@@ -99,7 +99,7 @@ public class MockedFrontend {
     private boolean isInit = false;
 
     // init the fe process. This must be called before starting the frontend process.
-    // 1. check if all neccessary environment variables are set.
+    // 1. check if all necessary environment variables are set.
     // 2. clear and create 3 dirs: runningDir/log/, runningDir/palo-meta/, runningDir/conf/
     // 3. init fe.conf
     //      The content of "fe.conf" is a merge set of input `feConf` and MIN_FE_CONF
diff --git a/fe/spark-dpp/src/main/java/org/apache/doris/load/loadv2/dpp/SparkDpp.java b/fe/spark-dpp/src/main/java/org/apache/doris/load/loadv2/dpp/SparkDpp.java
index ae5efc93af..f5f14039a0 100644
--- a/fe/spark-dpp/src/main/java/org/apache/doris/load/loadv2/dpp/SparkDpp.java
+++ b/fe/spark-dpp/src/main/java/org/apache/doris/load/loadv2/dpp/SparkDpp.java
@@ -991,7 +991,7 @@ public final class SparkDpp implements java.io.Serializable {
                     }
                 }
 
-                // get key column names and value column names seperately
+                // get key column names and value column names separately
                 List<String> keyColumnNames = new ArrayList<>();
                 List<String> valueColumnNames = new ArrayList<>();
                 for (EtlJobConfig.EtlColumn etlColumn : baseIndex.columns) {


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