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 2022/10/26 10:02:20 UTC

[doris] branch branch-1.2-unstable updated (6f18726f01 -> e23c7eb85e)

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

morningman pushed a change to branch branch-1.2-unstable
in repository https://gitbox.apache.org/repos/asf/doris.git


    omit 6f18726f01 [improvement](test) add sync for test_agg_keys_schema_change_datev2 (#13643)
    omit 17ba40f947 [feature-wip](CN Node)Support compute node (#13231)
    omit cb39671a73 [fix](policy) Add readlock for show policy (#13497)
    omit 4db18c139c [fix](thirdparty) g++-11: error: unrecognized command-line option '-m… (#13607)
    omit d6c3470c8d [feature](Nereids) support materialized index selection (#13416)
    omit bd884d3298 [Chore](build) add a environment variable DISABLE_JAVA_UDF (#13588)
    omit 2c70b17a47 [Del](vec) Support in predicate in delete condition of or and (#13587)
    omit 1741a20689 [opt](planer) remove unless cast of avg function (#13593)
    omit f209b7ab6e [fix](Nereids) add exchange node check between local and global agg in plan translator (#12913)
    omit e103531e69 [fix](sort)order by constant expr bug (#13613)
    omit b85c78ee00 [fix](regression) add 'if not exists' to 'create table' to support parallel test (#13576) (#13578)
    omit 78278f5943 [chore](be version) Check BE version by script (#13594)
    omit 235c105554 [feature-array](array-type) Add array function array_enumerate (#13612)
     new e23c7eb85e [improvement](regression-test) avoid query empty result after loading finished

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (6f18726f01)
            \
             N -- N -- N   refs/heads/branch-1.2-unstable (e23c7eb85e)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 be/src/agent/heartbeat_server.cpp                  |    1 -
 be/src/common/config.h                             |    4 -
 be/src/olap/column_predicate.h                     |    1 -
 be/src/olap/in_list_predicate.h                    |  109 +--
 be/src/vec/CMakeLists.txt                          |    1 -
 .../functions/array/function_array_enumerate.cpp   |   98 --
 .../functions/array/function_array_register.cpp    |    2 -
 bin/check_be_version.sh                            |   93 --
 build.sh                                           |   26 +-
 .../array-functions/array_enumerate.md             |   60 --
 .../sql-reference/Show-Statements/SHOW-BACKENDS.md |    2 -
 .../array-functions/array_enumerate.md             |   59 --
 .../sql-reference/Show-Statements/SHOW-BACKENDS.md |    2 -
 .../org/apache/doris/analysis/AlterPolicyStmt.java |    6 +-
 .../java/org/apache/doris/analysis/SelectStmt.java |    8 -
 .../java/org/apache/doris/catalog/FunctionSet.java |   81 +-
 .../java/org/apache/doris/catalog/OlapTable.java   |    4 +-
 .../java/org/apache/doris/catalog/S3Resource.java  |    2 +-
 .../main/java/org/apache/doris/catalog/Tablet.java |    2 +-
 .../apache/doris/clone/ClusterLoadStatistic.java   |    4 -
 .../clone/ColocateTableCheckerAndBalancer.java     |    2 -
 .../org/apache/doris/clone/TabletScheduler.java    |    5 +-
 .../main/java/org/apache/doris/common/Config.java  |    8 -
 .../apache/doris/common/proc/BackendsProcDir.java  |    5 +-
 .../doris/common/proc/ClusterLoadStatByTag.java    |    2 +-
 .../glue/translator/PhysicalPlanTranslator.java    |   20 +-
 .../jobs/batch/NereidsRewriteJobExecutor.java      |    8 +-
 .../org/apache/doris/nereids/rules/RuleType.java   |   16 +-
 .../mv/AbstractSelectMaterializedIndexRule.java    |  273 ------
 .../SelectMaterializedIndexWithoutAggregate.java   |  147 ---
 ...gregate.java => SelectRollupWithAggregate.java} |  323 ++++--
 .../rules/mv/SelectRollupWithoutAggregate.java     |   60 ++
 .../trees/plans/logical/LogicalOlapScan.java       |   34 +-
 .../org/apache/doris/planner/BrokerScanNode.java   |   10 +-
 .../org/apache/doris/planner/OlapScanNode.java     |    8 -
 .../doris/planner/external/BackendPolicy.java      |   13 +-
 .../java/org/apache/doris/policy/PolicyMgr.java    |  120 +--
 .../main/java/org/apache/doris/resource/Tag.java   |   11 +-
 .../apache/doris/service/FrontendServiceImpl.java  |    2 +-
 .../main/java/org/apache/doris/system/Backend.java |   25 -
 .../org/apache/doris/system/BackendHbResponse.java |   20 -
 .../org/apache/doris/system/BeSelectionPolicy.java |   60 +-
 .../java/org/apache/doris/system/HeartbeatMgr.java |    7 +-
 .../org/apache/doris/system/SystemInfoService.java |   12 +-
 .../doris/transaction/DatabaseTransactionMgr.java  |    5 +
 .../apache/doris/transaction/TransactionState.java |   17 +-
 .../doris/clone/ClusterLoadStatisticsTest.java     |   18 -
 .../clone/ColocateTableCheckerAndBalancerTest.java |   53 +-
 .../rules/mv/BaseMaterializedIndexSelectTest.java  |   51 -
 .../doris/nereids/rules/mv/SelectMvIndexTest.java  | 1035 --------------------
 ...tRollupIndexTest.java => SelectRollupTest.java} |  191 ++--
 .../apache/doris/system/SystemInfoServiceTest.java |   63 --
 .../doris/utframe/DemoMultiBackendsTest.java       |    8 +-
 .../apache/doris/utframe/TestWithFeService.java    |   53 +-
 gensrc/script/doris_builtins_functions.py          |   17 -
 gensrc/thrift/HeartbeatService.thrift              |    1 -
 regression-test/common/table/bitmap_basic_agg.sql  |    2 +-
 regression-test/common/table/hll_basic_agg.sql     |    2 +-
 regression-test/common/table/test_basic_agg.sql    |    2 +-
 .../data/nereids_syntax_p0/function.out            |    5 -
 .../array_functions/test_array_functions.out       |   36 -
 .../bitmap_functions/test_bitmap_intersect.groovy  |    2 +-
 .../bloom_filter_p0/test_bloom_filter.groovy       |    4 +-
 .../test_bloom_filter_is_not_null.groovy           |    2 +-
 .../test_create_table_with_bloom_filter.groovy     |    2 +-
 .../create_table_use_partition_policy.groovy       |    8 +-
 .../use_policy/create_table_use_policy.groovy      |    2 +-
 .../use_policy/use_default_storage_policy.groovy   |    4 +-
 .../compaction/test_compaction_agg_keys.groovy     |    2 +-
 .../compaction/test_compaction_dup_keys.groovy     |    2 +-
 .../compaction/test_compaction_uniq_keys.groovy    |    2 +-
 ...st_constant_push_down_through_outer_join.groovy |    4 +-
 .../test_crossjoin_inlineview_slot.groovy          |   10 +-
 .../test_lateral_view_in_subquery.groovy           |    4 +-
 .../test_outer_join_with_subquery.groovy           |    4 +-
 .../correctness/test_pushdown_pred_to_view.groovy  |    2 +-
 .../correctness/test_union_with_subquery.groovy    |    2 +-
 .../correctness/test_view_varchar_length.groovy    |    2 +-
 .../suites/correctness_p0/test_bitmap_count.groovy |    2 +-
 .../correctness_p0/test_bitmap_intersect.groovy    |    2 +-
 .../correctness_p0/test_bitmap_serialize.groovy    |    2 +-
 .../test_bucket_join_with_colocate_table.groovy    |    4 +-
 .../correctness_p0/test_current_timestamp.groovy   |    2 +-
 .../test_dict_range_predicate.groovy               |    2 +-
 .../correctness_p0/test_first_value_window.groovy  |    2 +-
 .../correctness_p0/test_group_by_constant.groovy   |   11 +-
 .../test_join_should_not_reorder.groovy            |    6 +-
 .../test_join_with_projection.groovy               |    4 +-
 .../correctness_p0/test_lag_lead_window.groovy     |    2 +-
 .../correctness_p0/test_last_value_window.groovy   |    2 +-
 .../test_like_predicate_with_nullable.groovy       |    2 +-
 .../correctness_p0/test_min_max_window.groovy      |    2 +-
 .../correctness_p0/test_no_grouping_window.groovy  |    2 +-
 .../correctness_p0/test_null_predicate.groovy      |    2 +-
 .../correctness_p0/test_outer_join_sort.groovy     |    6 +-
 .../test_outer_join_with_cross_join.groovy         |    8 +-
 .../test_outer_join_with_empty_node.groovy         |    4 +-
 .../test_outer_join_with_grouping.groovy           |    4 +-
 .../test_outer_join_with_order_by.groovy           |    6 +-
 .../test_outer_join_with_window_function.groovy    |    8 +-
 ...t_outer_join_with_window_function_datev2.groovy |    8 +-
 .../correctness_p0/test_pushdown_constant.groovy   |    2 +-
 .../test_select_stddev_variance_window.groovy      |    2 +-
 .../correctness_p0/test_select_variance_agg.groovy |    2 +-
 .../suites/correctness_p0/test_sort.groovy         |    2 +-
 .../correctness_p0/test_string_pad_function.groovy |    2 +-
 .../correctness_p0/test_subquery_with_agg.groovy   |    2 +-
 .../csv_header_p0/test_csv_with_header.groovy      |    2 +-
 .../storage/test_dup_tab_basic_int.groovy          |    2 +-
 .../storage/test_dup_tab_basic_int_nullable.groovy |    2 +-
 .../storage/test_dup_tab_basic_varchar.groovy      |    2 +-
 .../test_dup_tab_basic_varchar_nullable.groovy     |    2 +-
 .../duplicate/storage/test_dup_tab_char.groovy     |    2 +-
 .../storage/test_dup_tab_char_nullable.groovy      |    2 +-
 .../duplicate/storage/test_dup_tab_date.groovy     |    2 +-
 .../storage/test_dup_tab_date_nullable.groovy      |    2 +-
 .../duplicate/storage/test_dup_tab_datetime.groovy |    2 +-
 .../storage/test_dup_tab_datetime_nullable.groovy  |    2 +-
 .../duplicate/storage/test_dup_tab_decimal.groovy  |    2 +-
 .../storage/test_dup_tab_decimal_nullable.groovy   |    2 +-
 .../storage/test_dup_tab_mixed_type.groovy         |    2 +-
 .../test_dup_tab_mixed_type_nullable.groovy        |    2 +-
 .../datatype_p0/bitmap/test_bitmap_int.groovy      |    4 +-
 .../suites/datatype_p0/hll/test_hll_int.groovy     |    2 +-
 .../datatype_p0/string/test_string_basic.groovy    |    8 +-
 regression-test/suites/ddl_p0/test_ctas.groovy     |    4 +-
 regression-test/suites/ddl_p0/test_ctl.groovy      |    2 +-
 .../delete_p0/test_array_column_delete.groovy      |    2 +-
 .../suites/delete_p0/test_delete.groovy            |    4 +-
 .../suites/delete_p0/test_delete_sign_mow.sql      |    2 +-
 .../suites/delete_p0/test_delete_sign_unique.sql   |    2 +-
 .../delete_p0/test_multi_columns_delete.groovy     |    2 +-
 .../delete_p0/test_segment_iterator_delete.groovy  |    6 +-
 regression-test/suites/demo_p0/event_action.groovy |    2 +-
 .../suites/export_p0/test_outfile.groovy           |    5 +-
 .../suites/export_p0/test_outfile_expr.groovy      |    3 +-
 .../suites/export_p0/test_outfile_parquet.groovy   |    3 +-
 .../suites/export_p0/test_outfile_separator.groovy |    3 +-
 .../suites/github_events_p2/ddl/github_events.sql  |    2 +-
 .../http_rest_api/post/test_query_stmt.groovy      |    4 +-
 regression-test/suites/index_p0/load.groovy        |    2 +-
 regression-test/suites/insert_p0/ddl/datatype.sql  |    2 +-
 .../suites/insert_p0/ddl/mutable_datatype.sql      |    2 +-
 .../load/insert/test_insert_nested_array.groovy    |    4 +-
 .../broker_load/ddl/parquet_s3_case1_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case2_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case3_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case4_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case5_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case6_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case7_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case8_create.sql    |    2 +-
 .../broker_load/ddl/parquet_s3_case9_create.sql    |    2 +-
 .../load_p0/stream_load/test_stream_load.groovy    |   18 +-
 .../suites/nereids_syntax_p0/agg_with_const.groovy |    3 +-
 .../suites/nereids_syntax_p0/function.groovy       |    4 -
 .../suites/nereids_syntax_p0/having.groovy         |    2 +-
 .../suites/nereids_syntax_p0/rollup.groovy         |    2 +-
 .../nereids_syntax_p0/sub_query_correlated.groovy  |    8 +-
 regression-test/suites/opensky_p2/ddl/opensky.sql  |   28 +-
 .../test_dynamic_partition.groovy                  |    8 +-
 .../list_partition/test_list_partition.groovy      |    2 +-
 .../performance_p0/redundant_conjuncts.groovy      |    2 +-
 .../test_primary_key_simple_case.groovy            |    2 +-
 .../suites/query/aggregate/aggregate_count1.groovy |    2 +-
 .../aggregate_group_by_metric_type.groovy          |    4 +-
 .../aggregate/aggregate_grouping_function.groovy   |    2 +-
 .../aggregate/aggregate_having_grouping.groovy     |    2 +-
 regression-test/suites/query/join/test_join.groovy |   14 +-
 .../suites/query/join/test_join3.groovy            |    6 +-
 .../suites/query/join/test_join4.groovy            |    4 +-
 .../suites/query/join/test_join5.groovy            |   18 +-
 .../query/show/test_array_show_create.groovy       |   10 +-
 .../json_function/test_query_json_object.groovy    |    2 +-
 .../suites/query/sql_functions/test_in_expr.groovy |    4 +-
 .../query/system/test_query_sys_data_type.groovy   |    2 +-
 .../aggregate/aggregate_output_null.groovy         |    4 +-
 .../suites/query_p0/empty_table/ddl/empty.sql      |    2 +-
 .../suites/query_p0/join/ddl/full_join_table.sql   |    2 +-
 .../suites/query_p0/join/ddl/left_table.sql        |    2 +-
 .../suites/query_p0/join/ddl/right_table.sql       |    2 +-
 regression-test/suites/query_p0/join/ddl/table.sql |    2 +-
 .../suites/query_p0/join/ddl/table_1.sql           |    2 +-
 .../suites/query_p0/join/ddl/table_2.sql           |    2 +-
 .../suites/query_p0/join/ddl/table_3.sql           |    2 +-
 .../query_p0/join/ddl/test_bucket_shuffle_join.sql |    2 +-
 .../suites/query_p0/join/ddl/test_join.sql         |    2 +-
 .../query_p0/lateral_view/test_issue_8850.sql      |    2 +-
 regression-test/suites/query_p0/load.groovy        |    8 +-
 .../test_aggregate_all_functions.groovy            |    4 +-
 .../test_aggregate_retention.sql                   |    2 +-
 .../sql_functions/array_functions/sql/q01.sql      |    8 +-
 .../sql_functions/array_functions/sql/q03.sql      |    2 +-
 .../array_functions/test_array_functions.groovy    |    4 -
 .../bitmap_functions/test_bitmap_function.groovy   |    6 +-
 .../table_function/explode_json_array.groovy       |    2 +-
 .../table_function/explode_split.groovy            |    2 +-
 .../window_functions/test_ntile_function.groovy    |    2 +-
 .../test_select_stddev_variance_window.groovy      |    2 +-
 .../window_functions/test_window_fn.groovy         |    4 +-
 .../window_functions/test_window_function.groovy   |    8 +-
 .../window_functions/window_funnel.sql             |    2 +-
 .../suites/query_p0/union/test_union.groovy        |    2 +-
 .../suites/query_p0/wide_table/sql/wide_table.sql  |    2 +-
 .../lateral_view/load_from_big_lateral_view.groovy |    2 +-
 .../rollup/test_materialized_view_bitmap.groovy    |    2 +-
 .../rollup/test_materialized_view_date.groovy      |    2 +-
 .../rollup/test_materialized_view_hll.groovy       |    2 +-
 ...test_materialized_view_hll_with_light_sc.groovy |    2 +-
 .../suites/rollup_p0/test_materialized_view.groovy |    4 +-
 .../schema_change/test_number_overflow.groovy      |    2 +-
 .../test_agg_keys_schema_change_datev2.groovy      |   12 -
 .../test_agg_keys_schema_change.groovy             |    2 +-
 .../test_agg_mv_schema_change.groovy               |    2 +-
 .../test_agg_rollup_schema_change.groovy           |    2 +-
 .../test_agg_vals_schema_change.groovy             |    2 +-
 .../test_alter_table_column.groovy                 |    2 +-
 .../test_alter_table_column_nullable.groovy        |    8 +-
 .../schema_change_p0/test_delete_schema_change.sql |    2 +-
 .../test_dup_keys_schema_change.groovy             |    2 +-
 .../test_dup_mv_schema_change.groovy               |    2 +-
 .../test_dup_rollup_schema_change.groovy           |    2 +-
 .../test_dup_vals_schema_change.groovy             |    2 +-
 .../test_partition_schema_change.sql               |    2 +-
 .../schema_change_p0/test_rename_column.groovy     |    8 +-
 .../test_uniq_keys_schema_change.groovy            |    2 +-
 .../test_uniq_mv_schema_change.groovy              |    2 +-
 .../test_uniq_rollup_schema_change.groovy          |    2 +-
 .../test_uniq_vals_schema_change.groovy            |    2 +-
 .../test_update_schema_change.groovy               |    2 +-
 .../load_one_step/load.groovy                      |    2 +
 .../suites/tpcds_sf1_unique_p1/load.groovy         |    4 +-
 regression-test/suites/trino_p0/ddl/nation.sql     |    2 +-
 regression-test/suites/trino_p0/ddl/orders.sql     |    2 +-
 regression-test/suites/trino_p0/ddl/part.sql       |    2 +-
 regression-test/suites/trino_p0/ddl/region.sql     |    2 +-
 regression-test/suites/trino_p0/ddl/workers.sql    |    2 +-
 .../suites/yandex_metrica_p2/ddl/hits.sql          |    2 +-
 .../suites/yandex_metrica_p2/ddl/visits.sql        |    2 +-
 thirdparty/build-thirdparty.sh                     |    7 +-
 240 files changed, 879 insertions(+), 3055 deletions(-)
 delete mode 100644 be/src/vec/functions/array/function_array_enumerate.cpp
 delete mode 100755 bin/check_be_version.sh
 delete mode 100644 docs/en/docs/sql-manual/sql-functions/array-functions/array_enumerate.md
 delete mode 100644 docs/zh-CN/docs/sql-manual/sql-functions/array-functions/array_enumerate.md
 delete mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/AbstractSelectMaterializedIndexRule.java
 delete mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/SelectMaterializedIndexWithoutAggregate.java
 rename fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/{SelectMaterializedIndexWithAggregate.java => SelectRollupWithAggregate.java} (61%)
 create mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/SelectRollupWithoutAggregate.java
 delete mode 100644 fe/fe-core/src/test/java/org/apache/doris/nereids/rules/mv/BaseMaterializedIndexSelectTest.java
 delete mode 100644 fe/fe-core/src/test/java/org/apache/doris/nereids/rules/mv/SelectMvIndexTest.java
 rename fe/fe-core/src/test/java/org/apache/doris/nereids/rules/mv/{SelectRollupIndexTest.java => SelectRollupTest.java} (59%)


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


[doris] 01/01: [improvement](regression-test) avoid query empty result after loading finished

Posted by mo...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit e23c7eb85e8387f129a40b7bba43085e99ebb28a
Author: morningman <mo...@163.com>
AuthorDate: Wed Oct 26 15:17:34 2022 +0800

    [improvement](regression-test) avoid query empty result after loading finished
---
 .../doris/transaction/DatabaseTransactionMgr.java       |  5 +++++
 .../org/apache/doris/transaction/TransactionState.java  | 17 +++++++++++------
 .../ssb_unique_load_zstd_p0/load_one_step/load.groovy   |  2 ++
 3 files changed, 18 insertions(+), 6 deletions(-)

diff --git a/fe/fe-core/src/main/java/org/apache/doris/transaction/DatabaseTransactionMgr.java b/fe/fe-core/src/main/java/org/apache/doris/transaction/DatabaseTransactionMgr.java
index 843df334ee..321a1c3d72 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/transaction/DatabaseTransactionMgr.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/transaction/DatabaseTransactionMgr.java
@@ -944,6 +944,11 @@ public class DatabaseTransactionMgr {
         } finally {
             MetaLockUtils.writeUnlockTables(tableList);
         }
+        // The visible latch should only be counted down after all things are done
+        // (finish transaction, write edit log, etc).
+        // Otherwise, there is no way for stream load to query the result right after loading finished,
+        // even if we call "sync" before querying.
+        transactionState.countdownVisibleLatch();
         LOG.info("finish transaction {} successfully", transactionState);
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/transaction/TransactionState.java b/fe/fe-core/src/main/java/org/apache/doris/transaction/TransactionState.java
index 3a59fac9d9..c6a22c2a24 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/transaction/TransactionState.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/transaction/TransactionState.java
@@ -188,9 +188,10 @@ public class TransactionState implements Writable {
     private String reason = "";
     // error replica ids
     private Set<Long> errorReplicas;
-    private CountDownLatch latch;
+    // this latch will be counted down when txn status change to VISIBLE
+    private CountDownLatch visibleLatch;
 
-    // this state need not to be serialized
+    // this state need not be serialized
     private Map<Long, PublishVersionTask> publishVersionTasks;
     private boolean hasSendTask;
     private long publishVersionTime = -1;
@@ -246,7 +247,7 @@ public class TransactionState implements Writable {
         this.errorReplicas = Sets.newHashSet();
         this.publishVersionTasks = Maps.newHashMap();
         this.hasSendTask = false;
-        this.latch = new CountDownLatch(1);
+        this.visibleLatch = new CountDownLatch(1);
         this.authCode = UUID.randomUUID().toString();
     }
 
@@ -269,7 +270,7 @@ public class TransactionState implements Writable {
         this.errorReplicas = Sets.newHashSet();
         this.publishVersionTasks = Maps.newHashMap();
         this.hasSendTask = false;
-        this.latch = new CountDownLatch(1);
+        this.visibleLatch = new CountDownLatch(1);
         this.callbackId = callbackId;
         this.timeoutMs = timeoutMs;
         this.authCode = UUID.randomUUID().toString();
@@ -379,7 +380,7 @@ public class TransactionState implements Writable {
 
         // after status changed
         if (transactionStatus == TransactionStatus.VISIBLE) {
-            this.latch.countDown();
+            this.visibleLatch.countDown();
             if (MetricRepo.isInit) {
                 MetricRepo.COUNTER_TXN_SUCCESS.increase(1L);
             }
@@ -457,8 +458,12 @@ public class TransactionState implements Writable {
         }
     }
 
+    public void countdownVisibleLatch() {
+        this.visibleLatch.countDown();
+    }
+
     public void waitTransactionVisible(long timeoutMillis) throws InterruptedException {
-        this.latch.await(timeoutMillis, TimeUnit.MILLISECONDS);
+        this.visibleLatch.await(timeoutMillis, TimeUnit.MILLISECONDS);
     }
 
     public void setPrepareTime(long prepareTime) {
diff --git a/regression-test/suites/ssb_unique_load_zstd_p0/load_one_step/load.groovy b/regression-test/suites/ssb_unique_load_zstd_p0/load_one_step/load.groovy
index dfe107a0bf..621315c9b6 100644
--- a/regression-test/suites/ssb_unique_load_zstd_p0/load_one_step/load.groovy
+++ b/regression-test/suites/ssb_unique_load_zstd_p0/load_one_step/load.groovy
@@ -28,6 +28,8 @@ suite("load_one_step") {
         sql new File("""${context.file.parentFile.parent}/ddl/${tableName}_create.sql""").text
         streamLoad {
             table tableName
+            def label = "load_one_step_${tableName}_" + UUID.randomUUID().toString() 
+            set 'label', label
             set 'column_separator', '|'
             set 'compress_type', 'GZ'
             set 'columns', rows[0]


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