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/06/24 11:11:35 UTC

[doris] branch master updated: [TYPO] fix typo 'destory' -> 'destroy' (#10373)

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/doris.git


The following commit(s) were added to refs/heads/master by this push:
     new 476be35961 [TYPO] fix typo 'destory' -> 'destroy' (#10373)
476be35961 is described below

commit 476be35961a0242fea7e75dae319a31c2e6bd4cf
Author: Gabriel <ga...@gmail.com>
AuthorDate: Fri Jun 24 19:11:28 2022 +0800

    [TYPO] fix typo 'destory' -> 'destroy' (#10373)
---
 be/src/vec/exec/vaggregation_node.cpp                          | 10 +++++-----
 be/src/vec/exec/vaggregation_node.h                            |  2 +-
 be/src/vec/exec/vanalytic_eval_node.cpp                        |  4 ++--
 be/src/vec/exec/vanalytic_eval_node.h                          |  2 +-
 .../src/main/java/org/apache/doris/udf/UdafExecutor.java       |  6 +++---
 5 files changed, 12 insertions(+), 12 deletions(-)

diff --git a/be/src/vec/exec/vaggregation_node.cpp b/be/src/vec/exec/vaggregation_node.cpp
index 3f8e210766..8910674467 100644
--- a/be/src/vec/exec/vaggregation_node.cpp
+++ b/be/src/vec/exec/vaggregation_node.cpp
@@ -422,7 +422,7 @@ Status AggregationNode::_create_agg_status(AggregateDataPtr data) {
     return Status::OK();
 }
 
-Status AggregationNode::_destory_agg_status(AggregateDataPtr data) {
+Status AggregationNode::_destroy_agg_status(AggregateDataPtr data) {
     for (int i = 0; i < _aggregate_evaluators.size(); ++i) {
         _aggregate_evaluators[i]->function()->destroy(data + _offsets_of_aggregate_states[i]);
     }
@@ -555,7 +555,7 @@ Status AggregationNode::_merge_without_key(Block* block) {
                         deserialize_buffer.get() + _offsets_of_aggregate_states[i],
                         &_agg_arena_pool);
 
-                _destory_agg_status(deserialize_buffer.get());
+                _destroy_agg_status(deserialize_buffer.get());
             }
         } else {
             _aggregate_evaluators[i]->execute_single_add(
@@ -572,7 +572,7 @@ void AggregationNode::_update_memusage_without_key() {
 }
 
 void AggregationNode::_close_without_key() {
-    _destory_agg_status(_agg_data.without_key);
+    _destroy_agg_status(_agg_data.without_key);
     release_tracker();
 }
 
@@ -1080,7 +1080,7 @@ Status AggregationNode::_merge_with_serialized_key(Block* block) {
                         deserialize_buffer.get() + _offsets_of_aggregate_states[i],
                         &_agg_arena_pool);
 
-                _destory_agg_status(deserialize_buffer.get());
+                _destroy_agg_status(deserialize_buffer.get());
             }
         } else {
             _aggregate_evaluators[i]->execute_batch_add(block, _offsets_of_aggregate_states[i],
@@ -1110,7 +1110,7 @@ void AggregationNode::_close_with_serialized_key() {
                 auto& data = agg_method.data;
                 data.for_each_mapped([&](auto& mapped) {
                     if (mapped) {
-                        _destory_agg_status(mapped);
+                        _destroy_agg_status(mapped);
                         mapped = nullptr;
                     }
                 });
diff --git a/be/src/vec/exec/vaggregation_node.h b/be/src/vec/exec/vaggregation_node.h
index 080bf5a9ca..31b925bbfe 100644
--- a/be/src/vec/exec/vaggregation_node.h
+++ b/be/src/vec/exec/vaggregation_node.h
@@ -466,7 +466,7 @@ private:
     void _make_nullable_output_key(Block* block);
 
     Status _create_agg_status(AggregateDataPtr data);
-    Status _destory_agg_status(AggregateDataPtr data);
+    Status _destroy_agg_status(AggregateDataPtr data);
 
     Status _get_without_key_result(RuntimeState* state, Block* block, bool* eos);
     Status _serialize_without_key(RuntimeState* state, Block* block, bool* eos);
diff --git a/be/src/vec/exec/vanalytic_eval_node.cpp b/be/src/vec/exec/vanalytic_eval_node.cpp
index 8c79be5a92..37b2406e6f 100644
--- a/be/src/vec/exec/vanalytic_eval_node.cpp
+++ b/be/src/vec/exec/vanalytic_eval_node.cpp
@@ -239,7 +239,7 @@ Status VAnalyticEvalNode::close(RuntimeState* state) {
     for (size_t i = 0; i < _agg_functions_size; ++i) VExpr::close(_agg_expr_ctxs[i], state);
     for (auto* agg_function : _agg_functions) agg_function->close(state);
 
-    _destory_agg_status();
+    _destroy_agg_status();
     return ExecNode::close(state);
 }
 
@@ -635,7 +635,7 @@ Status VAnalyticEvalNode::_create_agg_status() {
     return Status::OK();
 }
 
-Status VAnalyticEvalNode::_destory_agg_status() {
+Status VAnalyticEvalNode::_destroy_agg_status() {
     for (size_t i = 0; i < _agg_functions_size; ++i) {
         _agg_functions[i]->destroy(_fn_place_ptr + _offsets_of_aggregate_states[i]);
     }
diff --git a/be/src/vec/exec/vanalytic_eval_node.h b/be/src/vec/exec/vanalytic_eval_node.h
index ca2e355895..60d835a86c 100644
--- a/be/src/vec/exec/vanalytic_eval_node.h
+++ b/be/src/vec/exec/vanalytic_eval_node.h
@@ -64,7 +64,7 @@ private:
     Status _reset_agg_status();
     Status _init_result_columns();
     Status _create_agg_status();
-    Status _destory_agg_status();
+    Status _destroy_agg_status();
     Status _insert_range_column(vectorized::Block* block, VExprContext* expr, IColumn* dst_column,
                                 size_t length);
 
diff --git a/fe/java-udf/src/main/java/org/apache/doris/udf/UdafExecutor.java b/fe/java-udf/src/main/java/org/apache/doris/udf/UdafExecutor.java
index ba59cee308..c3632a15ad 100644
--- a/fe/java-udf/src/main/java/org/apache/doris/udf/UdafExecutor.java
+++ b/fe/java-udf/src/main/java/org/apache/doris/udf/UdafExecutor.java
@@ -51,7 +51,7 @@ import java.util.HashMap;
  */
 public class UdafExecutor {
     public static final String UDAF_CREATE_FUNCTION = "create";
-    public static final String UDAF_DESTORY_FUNCTION = "destroy";
+    public static final String UDAF_DESTROY_FUNCTION = "destroy";
     public static final String UDAF_ADD_FUNCTION = "add";
     public static final String UDAF_SERIALIZE_FUNCTION = "serialize";
     public static final String UDAF_DESERIALIZE_FUNCTION = "deserialize";
@@ -171,7 +171,7 @@ public class UdafExecutor {
      */
     public void destroy() throws UdfRuntimeException {
         try {
-            allMethods.get(UDAF_DESTORY_FUNCTION).invoke(udaf, stateObj);
+            allMethods.get(UDAF_DESTROY_FUNCTION).invoke(udaf, stateObj);
         } catch (Exception e) {
             throw new UdfRuntimeException("UDAF failed to destroy: ", e);
         }
@@ -457,7 +457,7 @@ public class UdafExecutor {
             for (idx = 0; idx < methods.length; ++idx) {
                 signatures.add(methods[idx].toGenericString());
                 switch (methods[idx].getName()) {
-                    case UDAF_DESTORY_FUNCTION:
+                    case UDAF_DESTROY_FUNCTION:
                     case UDAF_CREATE_FUNCTION:
                     case UDAF_MERGE_FUNCTION:
                     case UDAF_SERIALIZE_FUNCTION:


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