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/25 14:30:27 UTC

[doris] branch branch-1.2-lts updated (c08568e13e -> 6f18726f01)

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

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


    omit c08568e13e [fix](mem) failure of allocating memory (#13414)
     add f0dbbe5b46 [Bug](funciton) fix repeat coredump when step is to long (#13408)
     add 18f2db6064 [feature](nereids) let minValue and maxValue in stats support for Date, CHAR and VARCHAR type (#13311)
     add cd3450bd9d [Improvement](join) optimize join probing phase (#13357)
     add 3f964ad5a8 [Regression](javaudf) add regression test for javaudf (#13266)
     add 125def5102 [enhancement](macOS M1) Support building from source on macOS (M1) (#13195)
     add 21f233d7e7 [feature-wip](multi-catalog) use apache orc reader to read orc file (#13404)
     add 6d322f85ac [improvement](compaction) delete num based compaction policy (#13409)
     add d8e53da764 [feature-wip](statistics) collect statistics by sampling sql-tasks (#13399)
     add 174054e32d [fix](conf) aggressive_memory_decommit and chunk_reserve_limits can not be changed when running (#13427)
     add a8fd76fe32 [Fix](docs) fix error description of `LDAP_ADMIN_PASSWORD` in the document (#13405)
     add 971eb9172f [fix](mem) failure of allocating memory (#13414)
     add ac037e57f5 [fix](sort)the sort expr's nullability property may not be right (#13328)
     add 755a946516 [feature](jsonb) jsonb functions (#13366)
     add 248ca14df7 [fix](test) let each case uses its own table name (#13419)
     add 8a068c8c92 [function](string_function) add new string function 'not_null_or_empty' (#13418)
     add c449028a5f [fix](year) fix `year()` results are not as expected (#13426)
     add 2745a88814 [enhancement](memtracker) Fix brpc causing query mem tracker to be inaccurate #13401
     add 1e42598fe6 [memory](podarray) revert not allocate too much memory in podarray change (#13457)
     add 5423de68dd [refactor](new-scan) remove old file scan node (#13433)
     add 0b368fbbfa [Bugfix](vec) Fix all create mv using to_bitmap() on negative value columns when enable_vectorized_alter_table is true (#13448)
     add 29b4d8dcad [typo](docs) fix some problem #13462
     add eeb2b0acdb [doc][fix](multi-catalog) Add multi-catalog es doc (#13429)
     add e65a4a9f9f [Improvement](multi-catalog)Support refresh external catalog. (#13363)
     add c4b5ba2a4f [Regression](java-udf) Move source code used by Java UDF test case (#13476)
     add 9ac4cfc9bb [bugfix](array-type) ColumnDate lost is_date_type after cloned (#13420)
     add 410e36ef5b [enhancement](macOS) Refine the build scripts for macOS (#13473)
     add 3a2d5db914 [fix](String) fix string type length set to -1 when load stirng data (#13475)
     add 697fa5f586 [Enhancement](profile) support configure the number of query profile (#13421)
     add 4fa3b14bf0 [Fix](multi-catalog)Fix NPE caused by GsonUtils created objects. #13489
     add 50e2d0fd3e [opt](storage) opt the read by column decimal (#13488)
     add 3821f8420d [opt](tpch) after change the config to speed up q21 (#13460)
     add f329d33666 [chore](fix) Fix some spell errors in be's comments. #13452
     add bc08854a35 [doc](storage policy) add cold and hot separation docs (#13096)
     add 60d5e4dfce [improvement](spark-load) support parquet and orc file (#13438)
     add 4996eafe74 [bugfix](VecDateTimeValue) eat the value of microsecond in function from_date_format_str (#13446)
     add 8637ac1ca3 [regression](framework)set random parallel_fragment_exec_instance_num… (#13383)
     add f7c69ade18 [feature-wip](multi-catalog) implement predicate pushdown in native OrcReader (#13453)
     add b5cd167713 [fix](hashjoin) fix coredump of hash join in ubsan build (#13479)
     add 2b328eafbb  [function](string_function) add new string function 'extract_url_parameter' (#13323)
     add 3c837a9bdd [regression](load) modify variable definition (#13506)
     add 1892e8f66e [Enhancement](scanner) support split avg key range (#13166)
     add 32b1456b28 [feature-wip](array) remove array config and check array nested depth (#13428)
     add 1e774036f1 [fix](function)fix be coredump when using json_object function (#13443)
     add 7109cbfe6f [feature-wip](unique-key-merge-on-write) fix that delete the bitmap of stale rowset (#13393)
     add 4ae777bfc5 [fix](Nereids) NPE caused by GroupExpression has null owner group when choosing best plan (#13252)
     add 483a46d17c [feature](Nereids) generate ExprId from 0 for each statement (#13382)
     add 95f437c506 [fix] Fix potential unhandled exception cause data inconsistency (#11029)
     add d624ff0580 [chore](macOS) Avoid using binutils from Homebrew to build third parties (#13512)
     add 736d113700 [fix](memtracker) Fix transmit_tracker null pointer because phamp is not thread safe #13528
     add d2be5096d6 [Revert](mem) revert the mem config cause perfermace degradation (#13526)
     add 3dd00df24b [fix](jsonreader) release memory of both value and parse allocator (#13513)
     add e62d3dd8e5 [opt](function) refactor extract_url to use StringValue (#13508)
     add 1b0dafcaa1 [Enhancement](load) consider memtable in flush while reducing load me… (#13480)
     add 27d84eafc5 [feature](alter) support rename column for table with unique column id (#13410)
     add 1f7829e099 [Fix](array-type) bugfix for array column with delete condition (#13361)
     add d3f65aa746 [Improvement](join) remove unnecessary state for join (#13472)
     add 9a3c1f0867 [Improvement](decimal) print decimal according to the real precision and scale (#13437)
     add 3e168c87c6 [improvement](regression-test) wait for publish timeout of stream load (#13531)
     add 3ca8bfaf30 [Function](array) support array_difference function (#13440)
     add b861b66bef [improve](Nereids): verify the join reorder search space; (#13498)
     add 9dc5dd382a [enhancement](memtracker) Fix Brpc mem count and refactored thread context macro  (#13469)
     add 88ceace855 [Bug](predicate) fix core dump on bool type runtime filter (#13417)
     add 5dde13fb7d [fix](scan)extend_scan_key should not change the range parameter (#13530)
     add ccc04210d6 [feature](jsonb type) functions for cast from and to jsonb datatype (#13379)
     add 847b80ebfa [test](jdbc) add jdbc and hive regression test (#13143)
     add 3e92f742bf [Bugfix](MV) Fix insert negative value to table with bitmap_union MV will cause count distinct result incorrect (#13507)
     add ddc08ee690 [enhancement](Nereids) turn on stream pre aggregate for nereids (#13538)
     add a555f45834 [fix](array-type) fix the wrong result of array_join function (#13477)
     add 3006b258b0 [Improvement](bloomfilter) allocate memory for BF in open phase (#13494)
     add 02598931e6 [fix](ddl) check view name by table name regex when create (#13240)
     add a5db1be44f [enhancement](publish) add metic publish version cost (#13522)
     add f0b608018b [config](tpch) Disable jemalloc and change the hint of tpch q22 (#13555)
     add c1cce29b20 [chore](regression) modify duplicate table name for regression cases (#13527)
     add 122f36e5be [RuntimeFilter] (vec) support runtime filter in indeed slot id (#13556)
     add 8e19b13f18 [Improvement](runtimefilter) don nott allocate memory if all targets are local (#13557)
     add 038ccab3c4 [benchmark](rewrite) add hints for q20 (#13561)
     add 6ff6a4f8b2 [fix]  The special library name table name problem (#13519)
     add 60e9fe2b3a [fix](plugin) bugfix for dirty uninstallation of dynamic plugin (#13540) (#13543)
     add 20ade4ae96 [chore](macOS) Disable JAVA UDF temporarily (#13563)
     add 413d2332ce [improvement](heartbeat) Add some relaxation strategies to reduce the failure probability of regression testing (#13568)
     add a7c221d04e [Bug](sort) Fix bug in string sorter (#13548)
     add 3a3def447d [fix](csv-reader) fix bug that csv reader can not read text format hms table (#13515)
     add 6ef891870f improve the outfile doc (#13569)
     add 4b5a2c1a65 [fix](export)(outfile) fix bug that export may fail when writing SUCCESS file (#13574)
     add b042ef9765 [chore](macOS) Fix the issues with protoc and protoc-gen-grpc-java on M1 (#13571)
     add 87864e40bf [doc](random_sink) Add some doc content about random sink (#13577)
     add 477b28efac [deps](fe)upgrade commons-text to 1.10.0 (#13562)
     add d266b8fb50 [fix](restore) fix wrong replica allcation after restore (#13575)
     add 4754ccf16b [refactor](Nereids) remove useless explaration job in cascades framework (#13545)
     add 9a47e2dab4 [improvement](profile) Change some profile warning log to debug log (#13539)
     add e17c2416f0 [fix](join) fix be core dump when using right join with other join predicates (#13511)
     add e53baeea17 [Improvement](Audit): Remove default_cluster for audit log db #13499
     add e5b0ca4e8c [fix](streamload) report exactly error message when be does not receive heartbeat from fe (#13518)
     add 54545c6446 [improvement](config) enlarge default value of create_table_timeout and remove disable_stream_load_2pc (#13520)
     add 177e82bdab [Enhancement](array-type) Add type derivation for array functions (#13534)
     add 40e122e5ef [fix](join)the build and probe expr should be calculated before converting input block to nullable (#13436)
     add 7faad9f004 [FIX](agg)fix group by constant child expr bug (#13485)
     add 409bd76999 [improve](Nereids): ReorderJoin eliminate this recursion (#13505)
     add 2cf89c55c2 [chore](macOS) Fix issues found on macOS x86_64 (#13583)
     add 57e248e09b [feature-wip](unique-key-merge-on-write) check whether the partition column is a key column when create table for MOW table (#13490)
     add 7fe7c01125 [Bug](decimal) Fix incorrect result for decimal multiply (#13591)
     add c24e5585c3 [fix](load) clear and notify when an error happens in flushing (#13589)
     add 57f479d9d2 [fix](test) let cases use their own table name (#13602)
     add f802fc37ff add date function 'last_day' (#13609)
     add de5bc6a8a5 [fix](regression-test) set label for stream load (#13620)
     add 235c105554 [feature-array](array-type) Add array function array_enumerate (#13612)
     add 78278f5943 [chore](be version) Check BE version by script (#13594)
     add b85c78ee00 [fix](regression) add 'if not exists' to 'create table' to support parallel test (#13576) (#13578)
     add e103531e69 [fix](sort)order by constant expr bug (#13613)
     add f209b7ab6e [fix](Nereids) add exchange node check between local and global agg in plan translator (#12913)
     add 1741a20689 [opt](planer) remove unless cast of avg function (#13593)
     add 2c70b17a47 [Del](vec) Support in predicate in delete condition of or and (#13587)
     add bd884d3298 [Chore](build) add a environment variable DISABLE_JAVA_UDF (#13588)
     add d6c3470c8d [feature](Nereids) support materialized index selection (#13416)
     add 4db18c139c [fix](thirdparty) g++-11: error: unrecognized command-line option '-m… (#13607)
     add cb39671a73 [fix](policy) Add readlock for show policy (#13497)
     add 17ba40f947 [feature-wip](CN Node)Support compute node (#13231)
     add 6f18726f01 [improvement](test) add sync for test_agg_keys_schema_change_datev2 (#13643)

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   (c08568e13e)
            \
             N -- N -- N   refs/heads/branch-1.2-lts (6f18726f01)

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.

No new revisions were added by this update.

Summary of changes:
 .gitignore                                         |     1 +
 .licenserc.yaml                                    |     2 +
 be/CMakeLists.txt                                  |   152 +-
 be/src/agent/CMakeLists.txt                        |    13 +-
 be/src/agent/agent_server.cpp                      |     2 +-
 be/src/agent/cgroups_mgr.cpp                       |     2 +-
 be/src/agent/cgroups_mgr.h                         |     2 +-
 .../src/agent/cgroups_mgr_mac.cpp                  |    27 +-
 be/src/agent/heartbeat_server.cpp                  |     1 +
 be/src/common/config.h                             |    42 +-
 be/src/env/env_posix.cpp                           |    10 +
 be/src/exec/analytic_eval_node.cpp                 |     5 +-
 be/src/exec/arrow/arrow_reader.cpp                 |     4 +-
 be/src/exec/arrow/parquet_reader.cpp               |    23 +-
 be/src/exec/broker_scanner.cpp                     |     2 +-
 be/src/exec/exec_node.cpp                          |     7 +-
 be/src/exec/hash_join_node.cpp                     |    36 +-
 be/src/exec/hash_join_node.h                       |     6 +-
 be/src/exec/json_scanner.cpp                       |    15 +-
 be/src/exec/olap_common.cpp                        |    31 -
 be/src/exec/olap_common.h                          |   110 +-
 be/src/exec/olap_scan_node.cpp                     |     3 +
 be/src/exec/orc_scanner.cpp                        |     4 +-
 be/src/exec/table_connector.cpp                    |     2 +
 be/src/exec/tablet_sink.cpp                        |     4 +-
 be/src/exec/tablet_sink.h                          |     4 +-
 be/src/exec/text_converter.hpp                     |     2 +-
 be/src/exprs/bitmap_function.cpp                   |    24 +
 be/src/exprs/bitmap_function.h                     |     1 +
 be/src/exprs/bloomfilter_predicate.h               |    49 +-
 be/src/exprs/json_functions.cpp                    |     2 +-
 be/src/exprs/runtime_filter.cpp                    |    31 +-
 be/src/exprs/runtime_filter.h                      |     2 +-
 be/src/exprs/string_functions.cpp                  |     8 +
 be/src/exprs/string_functions.h                    |     2 +
 be/src/exprs/table_function/explode_json_array.cpp |    10 +-
 be/src/exprs/timestamp_functions.cpp               |    31 +
 be/src/exprs/timestamp_functions.h                 |     2 +
 be/src/geo/CMakeLists.txt                          |     4 +-
 be/src/gutil/port.h                                |    17 +-
 be/src/gutil/strings/split_internal.h              |     8 +-
 be/src/gutil/sysinfo.cc                            |     8 +-
 be/src/gutil/type_traits.h                         |     2 +-
 be/src/http/action/compaction_action.cpp           |    23 +-
 be/src/http/action/compaction_action.h             |     2 -
 be/src/http/action/stream_load.cpp                 |     4 -
 be/src/http/action/stream_load_2pc.cpp             |     7 -
 be/src/io/fs/local_file_writer.cpp                 |    12 +
 be/src/olap/CMakeLists.txt                         |     4 +
 be/src/olap/base_compaction.cpp                    |     2 +
 be/src/olap/block_column_predicate.h               |     2 +-
 be/src/olap/column_predicate.h                     |     3 +-
 be/src/olap/cumulative_compaction_policy.cpp       |   142 +-
 be/src/olap/cumulative_compaction_policy.h         |    65 +-
 be/src/olap/data_dir.cpp                           |     7 +-
 be/src/olap/decimal12.h                            |     6 +-
 be/src/olap/delta_writer.cpp                       |     9 +-
 be/src/olap/delta_writer.h                         |     7 +-
 be/src/olap/file_helper.cpp                        |     6 +
 be/src/olap/file_helper.h                          |     5 +-
 be/src/olap/generic_iterators.cpp                  |     2 +-
 be/src/olap/in_list_predicate.h                    |   115 +-
 be/src/olap/memtable.cpp                           |     2 +-
 be/src/olap/memtable.h                             |     2 +-
 be/src/olap/memtable_flush_executor.h              |     2 +-
 be/src/olap/olap_server.cpp                        |    21 +-
 be/src/olap/options.cpp                            |     2 +-
 be/src/olap/predicate_creator.h                    |     5 -
 .../segment_v2/bloom_filter_index_writer.cpp       |     2 +-
 be/src/olap/rowset/segment_v2/segment_iterator.cpp |    10 +-
 be/src/olap/rowset/segment_v2/segment_iterator.h   |     4 +-
 be/src/olap/schema.cpp                             |    11 +-
 be/src/olap/schema.h                               |     3 +-
 be/src/olap/schema_change.cpp                      |    38 +-
 be/src/olap/storage_engine.cpp                     |    32 +-
 be/src/olap/storage_engine.h                       |     1 -
 be/src/olap/tablet.cpp                             |    12 +-
 be/src/olap/tablet_meta.cpp                        |     7 +-
 be/src/olap/tablet_schema.cpp                      |     6 +-
 be/src/olap/task/engine_publish_version_task.cpp   |     3 +-
 be/src/olap/task/engine_task.h                     |     4 -
 be/src/olap/tuple.h                                |     8 +-
 be/src/olap/types.h                                |    40 +-
 be/src/olap/uint24.h                               |     2 +-
 be/src/olap/utils.h                                |     4 +-
 be/src/runtime/buffer_control_block.cpp            |    16 +-
 be/src/runtime/client_cache.h                      |     4 +-
 be/src/runtime/data_stream_recvr.cc                |    22 +-
 be/src/runtime/data_stream_sender.cpp              |     9 +-
 be/src/runtime/datetime_value.cpp                  |     4 +-
 be/src/runtime/datetime_value.h                    |    19 +-
 be/src/runtime/decimalv2_value.cpp                 |     1 -
 be/src/runtime/exec_env.h                          |     9 +-
 be/src/runtime/exec_env_init.cpp                   |    16 +-
 be/src/runtime/file_result_writer.cpp              |     2 +-
 be/src/runtime/fragment_mgr.cpp                    |    39 -
 be/src/runtime/jsonb_value.cpp                     |    13 +-
 be/src/runtime/jsonb_value.h                       |     2 +-
 be/src/runtime/load_channel.h                      |     5 +-
 be/src/runtime/load_path_mgr.cpp                   |     2 +-
 be/src/runtime/mem_pool.cpp                        |    17 +-
 be/src/runtime/mem_pool.h                          |    13 +-
 be/src/runtime/memory/chunk_allocator.cpp          |    57 +-
 be/src/runtime/memory/jemalloc_hook.cpp            |    58 +
 be/src/runtime/memory/mem_tracker.cpp              |    10 +-
 be/src/runtime/memory/mem_tracker.h                |     6 +
 be/src/runtime/memory/mem_tracker_limiter.h        |     4 -
 be/src/runtime/memory/mem_tracker_task_pool.cpp    |    10 +-
 be/src/runtime/memory/mem_tracker_task_pool.h      |     2 +
 be/src/runtime/memory/thread_mem_tracker_mgr.cpp   |     8 +-
 be/src/runtime/memory/thread_mem_tracker_mgr.h     |    18 +-
 be/src/runtime/mysql_result_writer.cpp             |     2 +-
 be/src/runtime/row_batch.cpp                       |     3 +-
 be/src/runtime/runtime_filter_mgr.cpp              |     4 +
 be/src/runtime/runtime_state.cpp                   |     1 -
 .../runtime/stream_load/stream_load_executor.cpp   |    21 +-
 be/src/runtime/stream_load/stream_load_pipe.h      |     4 +-
 be/src/runtime/string_value.h                      |     3 +
 be/src/runtime/string_value.hpp                    |     5 +
 be/src/runtime/tablets_channel.cpp                 |   105 +-
 be/src/runtime/thread_context.cpp                  |    20 +
 be/src/runtime/thread_context.h                    |    93 +-
 be/src/runtime/types.cpp                           |    16 +-
 be/src/service/doris_main.cpp                      |     3 +
 be/src/service/internal_service.cpp                |    27 +-
 be/src/util/CMakeLists.txt                         |     6 +
 be/src/util/bfd_parser.cpp                         |     2 +-
 be/src/util/bit_packing.h                          |     2 +-
 be/src/util/bit_stream_utils.h                     |     2 +-
 be/src/util/bit_stream_utils.inline.h              |     2 +-
 be/src/util/bit_util.h                             |    12 +-
 be/src/util/block_compression.h                    |     2 +-
 be/src/util/core_local.h                           |     4 +
 be/src/util/cpu_info.cpp                           |    45 +-
 be/src/util/crc32c.cpp                             |     6 +-
 be/src/util/disk_info_mac.cpp                      |   163 +
 be/src/util/easy_json.cc                           |     7 +
 be/src/util/errno.cpp                              |     2 +
 .../q1.1.groovy => be/src/util/exception.cpp       |    29 +-
 .../{vec/io/reader_buffer.h => util/exception.h}   |    25 +-
 be/src/util/histogram.cpp                          |     2 +-
 be/src/util/jsonb_document.h                       |   122 +-
 be/src/util/jsonb_parser.h                         |     4 +-
 be/src/util/jsonb_updater.h                        |     2 +-
 be/src/util/jsonb_utils.h                          |    15 +-
 be/src/util/jsonb_writer.h                         |     3 +-
 be/src/util/lru_cache.hpp                          |     8 +-
 be/src/util/mem_info.cpp                           |    31 +-
 be/src/util/mem_info.h                             |     3 +-
 be/src/util/network_util.cpp                       |     6 +
 be/src/util/path_trie.hpp                          |    20 +-
 .../reader_buffer.h => util/perf_counters_mac.cpp} |    28 +-
 be/src/util/proto_util.h                           |     6 +-
 be/src/util/radix_sort.h                           |     3 +
 be/src/util/runtime_profile.cpp                    |     2 +-
 be/src/util/system_metrics.cpp                     |    10 +-
 be/src/util/thread.cpp                             |    29 +
 be/src/util/thread.h                               |     7 +-
 be/src/util/url_parser.cpp                         |    56 +
 be/src/util/url_parser.h                           |     5 +
 be/src/vec/CMakeLists.txt                          |    10 +-
 .../aggregate_function_collect.h                   |     8 +-
 .../aggregate_function_combinator.h                |     2 +-
 .../aggregate_functions/aggregate_function_count.h |     2 +-
 .../aggregate_function_distinct.h                  |     2 +-
 .../aggregate_function_reader.cpp                  |     2 +-
 .../aggregate_functions/aggregate_function_uniq.h  |     2 +-
 be/src/vec/columns/column.h                        |    19 +-
 be/src/vec/columns/column_array.cpp                |    42 +-
 be/src/vec/columns/column_array.h                  |     5 +-
 be/src/vec/columns/column_complex.h                |    14 +-
 be/src/vec/columns/column_const.cpp                |     3 +-
 be/src/vec/columns/column_const.h                  |     3 +-
 be/src/vec/columns/column_decimal.cpp              |    18 +-
 be/src/vec/columns/column_decimal.h                |     3 +-
 be/src/vec/columns/column_dictionary.h             |     2 +-
 be/src/vec/columns/column_jsonb.cpp                |    11 +-
 be/src/vec/columns/column_jsonb.h                  |     3 +-
 be/src/vec/columns/column_nullable.cpp             |     8 +-
 be/src/vec/columns/column_nullable.h               |     5 +-
 be/src/vec/columns/column_string.cpp               |    11 +-
 be/src/vec/columns/column_string.h                 |     3 +-
 be/src/vec/columns/column_vector.cpp               |    24 +-
 be/src/vec/columns/column_vector.h                 |     3 +-
 be/src/vec/common/allocator.h                      |     2 +
 be/src/vec/common/arena.h                          |    13 +-
 be/src/vec/common/cow.h                            |     2 +-
 be/src/vec/common/exception.cpp                    |    10 +-
 be/src/vec/common/hash_table/fixed_hash_table.h    |     9 +-
 be/src/vec/common/hash_table/hash_table.h          |     6 +-
 be/src/vec/common/hash_table/string_hash_table.h   |     3 -
 be/src/vec/common/int_exp.h                        |     2 +-
 be/src/vec/common/pod_array.h                      |    27 +-
 be/src/vec/common/sort/heap_sorter.cpp             |    11 +-
 be/src/vec/common/sort/sorter.cpp                  |    11 +-
 be/src/vec/common/sort/vsort_exec_exprs.cpp        |     8 +
 be/src/vec/common/sort/vsort_exec_exprs.h          |    20 +-
 be/src/vec/core/accurate_comparison.h              |     6 +-
 be/src/vec/core/block.cpp                          |     7 +-
 be/src/vec/core/sort_block.h                       |     5 +-
 be/src/vec/data_types/data_type.h                  |     2 +-
 be/src/vec/data_types/data_type_array.cpp          |    39 +-
 be/src/vec/data_types/data_type_decimal.h          |     2 +-
 be/src/vec/data_types/data_type_jsonb.cpp          |    23 +-
 be/src/vec/data_types/data_type_jsonb.h            |     1 +
 be/src/vec/exec/file_arrow_scanner.cpp             |   259 -
 be/src/vec/exec/file_arrow_scanner.h               |   118 -
 be/src/vec/exec/file_scan_node.cpp                 |   508 -
 be/src/vec/exec/file_scan_node.h                   |   148 -
 be/src/vec/exec/file_scanner.cpp                   |   199 -
 be/src/vec/exec/file_scanner.h                     |   112 -
 be/src/vec/exec/file_text_scanner.cpp              |   294 -
 be/src/vec/exec/file_text_scanner.h                |    72 -
 be/src/vec/exec/format/csv/csv_reader.cpp          |   130 +-
 be/src/vec/exec/format/csv/csv_reader.h            |    11 +-
 .../format/format_common.h}                        |    42 +-
 be/src/vec/exec/format/orc/vorc_reader.cpp         |   721 +
 be/src/vec/exec/format/orc/vorc_reader.h           |   284 +
 be/src/vec/exec/format/parquet/parquet_common.h    |    26 +-
 be/src/vec/exec/format/parquet/schema_desc.cpp     |    47 +-
 be/src/vec/exec/format/parquet/vparquet_reader.cpp |    44 +-
 be/src/vec/exec/format/parquet/vparquet_reader.h   |     4 +-
 be/src/vec/exec/join/join_op.h                     |   243 +-
 be/src/vec/exec/join/vhash_join_node.cpp           |  1097 +-
 be/src/vec/exec/join/vhash_join_node.h             |   212 +-
 be/src/vec/exec/scan/new_file_arrow_scanner.cpp    |   265 -
 be/src/vec/exec/scan/new_file_arrow_scanner.h      |    89 -
 be/src/vec/exec/scan/new_file_scan_node.cpp        |    27 +-
 be/src/vec/exec/scan/new_file_scanner.cpp          |   317 -
 be/src/vec/exec/scan/new_file_scanner.h            |   100 -
 be/src/vec/exec/scan/new_file_text_scanner.cpp     |   263 -
 be/src/vec/exec/scan/new_file_text_scanner.h       |    66 -
 be/src/vec/exec/scan/new_olap_scan_node.cpp        |     8 +-
 be/src/vec/exec/scan/vfile_scanner.cpp             |    29 +-
 be/src/vec/exec/scan/vscan_node.cpp                |     7 +
 be/src/vec/exec/scan/vscanner.cpp                  |     3 -
 be/src/vec/exec/vbroker_scanner.cpp                |     7 +-
 be/src/vec/exec/vjson_scanner.cpp                  |    10 +-
 be/src/vec/exec/volap_scan_node.cpp                |    15 +-
 be/src/vec/exec/vset_operation_node.cpp            |    32 +-
 be/src/vec/exec/vset_operation_node.h              |   133 +-
 .../functions/array/function_array_aggregation.cpp |     3 +-
 .../array/function_array_difference.cpp}           |    28 +-
 .../functions/array/function_array_difference.h    |   210 +
 .../functions/array/function_array_enumerate.cpp   |    98 +
 be/src/vec/functions/array/function_array_join.h   |    17 +-
 .../functions/array/function_array_register.cpp    |     4 +
 be/src/vec/functions/array/function_array_sort.h   |     2 +-
 be/src/vec/functions/date_time_transforms.h        |     4 +-
 .../vec/functions/function_always_not_nullable.h   |    20 +-
 be/src/vec/functions/function_binary_arithmetic.h  |     2 +-
 be/src/vec/functions/function_bitmap.cpp           |    51 +
 be/src/vec/functions/function_cast.h               |   303 +-
 be/src/vec/functions/function_helpers.h            |     2 +-
 be/src/vec/functions/function_java_udf.h           |    23 +-
 be/src/vec/functions/function_jsonb.cpp            |   363 +-
 be/src/vec/functions/function_string.cpp           |     2 +
 be/src/vec/functions/function_string.h             |   205 +-
 be/src/vec/functions/function_timestamp.cpp        |   152 +
 be/src/vec/functions/functions_comparison.h        |     2 +-
 be/src/vec/functions/minus.cpp                     |     2 +-
 be/src/vec/functions/multiply.cpp                  |     8 +-
 be/src/vec/io/io_helper.h                          |     8 +-
 be/src/vec/io/reader_buffer.h                      |     2 +
 be/src/vec/olap/block_reader.cpp                   |     2 +-
 be/src/vec/runtime/vdata_stream_recvr.cpp          |    19 +-
 be/src/vec/runtime/vdatetime_value.cpp             |     6 +
 be/src/vec/runtime/vdatetime_value.h               |    36 +-
 be/src/vec/runtime/vfile_result_writer.cpp         |     9 +-
 be/src/vec/runtime/vfile_result_writer.h           |     2 +-
 be/src/vec/sink/vdata_stream_sender.cpp            |     3 +
 be/src/vec/sink/vmysql_result_writer.cpp           |    26 +-
 be/src/vec/sink/vtablet_sink.cpp                   |    10 +-
 be/src/vec/utils/arrow_column_to_doris_column.cpp  |     2 +-
 be/test/exec/olap_common_test.cpp                  |    53 +-
 be/test/exprs/runtime_filter_test.cpp              |     6 +
 be/test/olap/cumulative_compaction_policy_test.cpp |   241 +-
 be/test/runtime/decimal_value_test.cpp             |     2 +-
 be/test/testutil/run_all_tests.cpp                 |     4 +-
 be/test/testutil/test_util.cpp                     |     5 +-
 be/test/vec/core/column_jsonb_test.cpp             |     4 +-
 be/test/vec/function/function_jsonb_test.cpp       |  1058 +-
 be/test/vec/function/function_string_test.cpp      |    26 +
 be/test/vec/function/function_test_util.cpp        |    85 +-
 be/test/vec/function/function_test_util.h          |    47 +-
 be/test/vec/runtime/vdatetime_value_test.cpp       |    21 +
 tools/find_libjvm.sh => bin/check_be_version.sh    |    65 +-
 bin/start_be.sh                                    |    30 +-
 bin/start_fe.sh                                    |     5 +
 bin/stop_be.sh                                     |     2 +-
 bin/stop_fe.sh                                     |     2 +-
 build.sh                                           |    71 +-
 dist/LICENSE-dist.txt                              |     2 +
 .../{ => elasticsearch}/elasticsearch.yaml         |     0
 .../hive/gen_env.sh}                               |    29 +-
 .../docker-compose/hive/hadoop-hive.env.tpl        |    50 +
 .../thirdparties/docker-compose/hive/hive-2x.yaml  |   122 +
 .../docker-compose/hive/scripts/README             |     4 +
 .../docker-compose/hive/scripts/create.hql         |   161 +
 .../docker-compose/hive/scripts/healthy_check.sh   |    21 +-
 .../hive/scripts/hive-metastore.sh}                |    28 +-
 .../docker-compose/mysql/init/01-drop-db.sql       |    18 +
 .../docker-compose/mysql/init/02-create-db.sql     |    18 +
 .../docker-compose/mysql/init/03-create-table.sql  |    31 +
 .../docker-compose/mysql/init/04-insert.sql        |  1043 +
 .../docker-compose/mysql/mysql-5.7.env             |    17 +-
 .../docker-compose/mysql/mysql-5.7.yaml            |    47 +
 .../postgresql/init/01-create-schema.sql           |    18 +
 .../postgresql/init/02-create-table.sql            |    29 +
 .../docker-compose/postgresql/init/03-insert.sql   |  1044 +
 .../docker-compose/postgresql/postgresql-14.env    |    17 +-
 .../docker-compose/postgresql/postgresql-14.yaml   |    44 +
 docker/thirdparties/start-thirdparties-docker.sh   |    40 +-
 ...rties-docker.sh => stop-thirdparties-docker.sh} |    22 +-
 docs/en/docs/admin-manual/config/be-config.md      |     8 -
 docs/en/docs/admin-manual/config/fe-config.md      |    32 +
 .../admin-manual/http-actions/compaction-action.md |     2 +-
 docs/en/docs/admin-manual/privilege-ldap/ldap.md   |     2 +-
 docs/en/docs/advanced/cold_hot_separation.md       |   117 +
 .../import/import-way/broker-load-manual.md        |     2 +-
 docs/en/docs/data-table/data-partition.md          |     9 +-
 .../docs/ecosystem/external-table/jdbc-of-doris.md |    21 +
 .../docs/ecosystem/external-table/multi-catalog.md |    72 +-
 .../array-functions/array_difference.md            |    66 +
 .../array-functions/array_enumerate.md             |    60 +
 .../date-time-functions/last_day.md}               |    48 +-
 .../string-functions/extract_url_parameter.md      |    50 +
 .../string-functions/not_null_or_empty.md}         |    72 +-
 .../Account-Management-Statements/LDAP.md          |     6 +-
 .../Alter/ALTER-RESOURCE.md                        |    16 +
 .../Alter/ALTER-STORAGE-POLICY.md}                 |    25 +-
 .../Alter/ALTER-TABLE-PROPERTY.md                  |    13 +
 .../Alter/ALTER-TABLE-RENAME.md                    |    18 +
 .../Create/CREATE-POLICY.md                        |    11 +-
 .../Create/CREATE-RESOURCE.md                      |    20 +-
 .../Create/CREATE-TABLE.md                         |    42 +-
 .../Data-Definition-Statements/Drop/DROP-POLICY.md |     5 -
 .../Load/BROKER-LOAD.md                            |     8 +
 .../Load/CREATE-ROUTINE-LOAD.md                    |     6 +
 .../Load/STREAM-LOAD.md                            |     3 +-
 .../Data-Manipulation-Statements/OUTFILE.md        |     2 +-
 .../sql-reference/Show-Statements/SHOW-BACKENDS.md |     2 +
 .../sql-reference/Show-Statements/SHOW-POLICY.md   |    36 +-
 docs/sidebars.json                                 |    18 +-
 .../developer-guide/regression-testing.md          |    82 +-
 docs/zh-CN/docs/admin-manual/config/be-config.md   |     8 -
 docs/zh-CN/docs/admin-manual/config/fe-config.md   |    34 +-
 .../admin-manual/http-actions/compaction-action.md |     2 +-
 .../zh-CN/docs/admin-manual/privilege-ldap/ldap.md |     2 +-
 docs/zh-CN/docs/advanced/cold_hot_separation.md    |   117 +
 .../import/import-way/broker-load-manual.md        |     2 +-
 docs/zh-CN/docs/data-table/data-partition.md       |     8 +-
 .../docs/ecosystem/external-table/jdbc-of-doris.md |    23 +-
 .../docs/ecosystem/external-table/multi-catalog.md |    71 +-
 .../array-functions/array_difference.md            |    66 +
 .../array-functions/array_enumerate.md             |    59 +
 .../date-time-functions/last_day.md}               |    46 +-
 .../string-functions/extract_url_parameter.md      |    50 +
 .../string-functions/not_null_or_empty.md}         |    53 +-
 .../Account-Management-Statements/LDAP.md          |     7 +-
 .../Alter/ALTER-RESOURCE.md                        |    16 +
 .../{ALTER-RESOURCE.md => ALTER-STORAGE-POLICY.md} |    21 +-
 .../Alter/ALTER-TABLE-PROPERTY.md                  |    11 +
 .../Alter/ALTER-TABLE-RENAME.md                    |    18 +
 .../Create/CREATE-POLICY.md                        |    12 +-
 .../Create/CREATE-RESOURCE.md                      |    20 +-
 .../Create/CREATE-TABLE.md                         |    44 +-
 .../Data-Definition-Statements/Drop/DROP-POLICY.md |    10 -
 .../Load/BROKER-LOAD.md                            |    36 +-
 .../Load/CREATE-ROUTINE-LOAD.md                    |     8 +
 .../Load/STREAM-LOAD.md                            |     3 +-
 .../Data-Manipulation-Statements/OUTFILE.md        |     2 +-
 .../sql-manual/sql-reference/Data-Types/ARRAY.md   |     4 +-
 .../sql-reference/Show-Statements/SHOW-BACKENDS.md |     2 +
 .../sql-reference/Show-Statements/SHOW-POLICY.md   |    26 +-
 env.sh                                             |    61 +-
 extension/mysql_to_doris/bin/e_mysql_to_doris.sh   |     4 +-
 fe/check/checkstyle/checkstyle.xml                 |     4 -
 fe/fe-core/pom.xml                                 |    20 +-
 .../antlr4/org/apache/doris/nereids/DorisParser.g4 |     3 +-
 fe/fe-core/src/main/cup/sql_parser.cup             |    20 +-
 .../org/apache/doris/analysis/AlterPolicyStmt.java |     6 +-
 .../org/apache/doris/analysis/ArithmeticExpr.java  |    14 +-
 .../java/org/apache/doris/analysis/CastExpr.java   |     5 +
 .../java/org/apache/doris/analysis/ColumnDef.java  |     2 +-
 .../doris/analysis/CreateEncryptKeyStmt.java       |     8 +-
 .../doris/analysis/CreateMaterializedViewStmt.java |    44 +-
 .../apache/doris/analysis/CreateResourceStmt.java  |     9 +-
 .../org/apache/doris/analysis/CreateTableStmt.java |     6 +-
 .../org/apache/doris/analysis/CreateViewStmt.java  |     2 +
 .../apache/doris/analysis/DropEncryptKeyStmt.java  |    11 +-
 .../apache/doris/analysis/DropResourceStmt.java    |     8 +-
 .../main/java/org/apache/doris/analysis/Expr.java  |     4 +
 .../apache/doris/analysis/ExpressionFunctions.java |     2 +
 .../apache/doris/analysis/FunctionCallExpr.java    |    37 +-
 .../org/apache/doris/analysis/GroupByClause.java   |    16 +-
 .../doris/analysis/MVColumnBitmapUnionPattern.java |     3 +-
 .../org/apache/doris/analysis/PartitionDesc.java   |    11 +-
 .../org/apache/doris/analysis/RefreshDbStmt.java   |    19 +-
 .../apache/doris/analysis/RefreshTableStmt.java    |    10 +-
 .../java/org/apache/doris/analysis/SelectStmt.java |    20 +
 .../apache/doris/analysis/SetOperationStmt.java    |    27 +-
 .../java/org/apache/doris/analysis/SlotRef.java    |    12 +
 .../java/org/apache/doris/backup/RestoreJob.java   |     4 +-
 .../java/org/apache/doris/catalog/ArrayType.java   |     2 +
 .../java/org/apache/doris/catalog/Database.java    |    36 +-
 .../org/apache/doris/catalog/EncryptKeyHelper.java |     4 +-
 .../main/java/org/apache/doris/catalog/Env.java    |   109 +-
 .../java/org/apache/doris/catalog/Function.java    |     4 +
 .../java/org/apache/doris/catalog/FunctionSet.java |   162 +-
 .../doris/catalog/HiveMetaStoreClientHelper.java   |     3 +
 .../java/org/apache/doris/catalog/JdbcTable.java   |     3 +
 .../java/org/apache/doris/catalog/OlapTable.java   |     8 +-
 .../org/apache/doris/catalog/RefreshManager.java   |   104 +-
 .../java/org/apache/doris/catalog/Resource.java    |     1 -
 .../java/org/apache/doris/catalog/ResourceMgr.java |    19 +-
 .../java/org/apache/doris/catalog/S3Resource.java  |     2 +-
 .../java/org/apache/doris/catalog/ScalarType.java  |    18 +-
 .../java/org/apache/doris/catalog/TableIf.java     |    12 +
 .../org/apache/doris/catalog/TableProperty.java    |     4 +-
 .../main/java/org/apache/doris/catalog/Tablet.java |     2 +-
 .../main/java/org/apache/doris/catalog/Type.java   |    23 +-
 .../doris/catalog/external/EsExternalDatabase.java |    30 +-
 .../doris/catalog/external/EsExternalTable.java    |     1 -
 .../doris/catalog/external/ExternalDatabase.java   |     5 +
 .../doris/catalog/external/ExternalTable.java      |     6 +
 .../catalog/external/HMSExternalDatabase.java      |    25 +-
 .../doris/catalog/external/HMSExternalTable.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  |    35 +-
 .../apache/doris/common/proc/BackendsProcDir.java  |     6 +
 .../doris/common/proc/ClusterLoadStatByTag.java    |     2 +-
 .../doris/common/profile/ProfileTreeBuilder.java   |    10 +-
 .../apache/doris/common/util/ProfileManager.java   |     5 +-
 .../apache/doris/datasource/EsExternalCatalog.java |    14 +-
 .../doris/datasource/HMSExternalCatalog.java       |    27 +-
 .../doris/external/elasticsearch/EsUtil.java       |     3 +-
 .../org/apache/doris/journal/JournalEntity.java    |     6 +
 .../org/apache/doris/nereids/NereidsPlanner.java   |    42 +-
 .../org/apache/doris/nereids/StatementContext.java |    30 +-
 .../doris/nereids/glue/LogicalPlanAdapter.java     |    19 +-
 .../glue/translator/PhysicalPlanTranslator.java    |    21 +-
 .../jobs/batch/NereidsRewriteJobExecutor.java      |     8 +-
 .../doris/nereids/jobs/cascades/ApplyRuleJob.java  |     7 -
 .../nereids/jobs/cascades/DeriveStatsJob.java      |     5 +-
 .../jobs/cascades/ExploreGroupExpressionJob.java   |    66 -
 .../nereids/jobs/cascades/ExploreGroupJob.java     |    53 -
 .../java/org/apache/doris/nereids/memo/Group.java  |     3 +-
 .../apache/doris/nereids/memo/GroupExpression.java |    11 +-
 .../java/org/apache/doris/nereids/memo/Memo.java   |    55 +-
 .../doris/nereids/parser/LogicalPlanBuilder.java   |    18 +-
 .../apache/doris/nereids/parser/NereidsParser.java |    35 +-
 .../org/apache/doris/nereids/rules/RuleType.java   |    16 +-
 .../doris/nereids/rules/analysis/BindRelation.java |     4 +-
 .../LogicalAggToPhysicalHashAgg.java               |    24 +-
 .../mv/AbstractSelectMaterializedIndexRule.java    |   273 +
 ...a => SelectMaterializedIndexWithAggregate.java} |   323 +-
 .../SelectMaterializedIndexWithoutAggregate.java   |   147 +
 .../rules/mv/SelectRollupWithoutAggregate.java     |    60 -
 .../nereids/rules/rewrite/logical/ReorderJoin.java |    82 +-
 .../doris/nereids/trees/expressions/Alias.java     |     2 -
 .../trees/expressions/NamedExpressionUtil.java     |    25 +-
 .../apache/doris/nereids/trees/plans/FakePlan.java |   104 +
 .../trees/plans/logical/LogicalOlapScan.java       |    34 +-
 .../java/org/apache/doris/persist/EditLog.java     |     9 +
 .../org/apache/doris/persist/OperationType.java    |     1 +
 .../doris/persist/TableRenameColumnInfo.java       |   101 +
 .../org/apache/doris/planner/BrokerScanNode.java   |    10 +-
 .../org/apache/doris/planner/OlapScanNode.java     |     8 +
 .../org/apache/doris/planner/RuntimeFilter.java    |     7 +-
 .../java/org/apache/doris/planner/SortNode.java    |    15 +
 .../apache/doris/planner/StreamLoadPlanner.java    |     2 +-
 .../doris/planner/external/BackendPolicy.java      |    13 +-
 .../planner/external/ExternalFileScanNode.java     |    26 +-
 .../doris/planner/external/HiveScanProvider.java   |    20 +
 .../apache/doris/plugin/DynamicPluginLoader.java   |    11 +-
 .../java/org/apache/doris/policy/PolicyMgr.java    |   120 +-
 .../java/org/apache/doris/qe/ConnectContext.java   |    11 +
 .../java/org/apache/doris/qe/ConnectProcessor.java |     8 +-
 .../main/java/org/apache/doris/qe/Coordinator.java |     2 +-
 .../java/org/apache/doris/qe/SimpleScheduler.java  |     8 +-
 .../java/org/apache/doris/qe/StmtExecutor.java     |    15 +-
 .../main/java/org/apache/doris/resource/Tag.java   |    11 +-
 .../rewrite/mvrewrite/FunctionCallEqualRule.java   |     1 +
 .../rewrite/mvrewrite/ToBitmapToSlotRefRule.java   |     3 +-
 .../apache/doris/service/FrontendServiceImpl.java  |     2 +-
 .../org/apache/doris/statistics/ColumnStat.java    |    19 +-
 .../apache/doris/statistics/SQLStatisticsTask.java |    26 +-
 .../doris/statistics/SampleSQLStatisticsTask.java  |    25 +-
 .../doris/statistics/util/InternalSqlTemplate.java |   227 +-
 .../main/java/org/apache/doris/system/Backend.java |    51 +-
 .../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  |     6 +-
 .../org/apache/doris/analysis/ColumnDefTest.java   |     2 -
 .../doris/analysis/CreateResourceStmtTest.java     |     8 +-
 .../apache/doris/analysis/CreateViewStmtTest.java  |    52 +
 .../apache/doris/analysis/InsertArrayStmtTest.java |     2 -
 .../org/apache/doris/catalog/CreateTableTest.java  |    39 +-
 .../org/apache/doris/catalog/CreateViewTest.java   |     2 -
 .../doris/catalog/OdbcCatalogResourceTest.java     |     4 +-
 .../org/apache/doris/catalog/OlapTableTest.java    |     8 +-
 .../org/apache/doris/catalog/ResourceMgrTest.java  |    12 +-
 .../org/apache/doris/catalog/S3ResourceTest.java   |     6 +-
 .../apache/doris/catalog/SparkResourceTest.java    |    10 +-
 .../doris/clone/ClusterLoadStatisticsTest.java     |    18 +
 .../clone/ColocateTableCheckerAndBalancerTest.java |    53 +-
 .../apache/doris/nereids/memo/MemoCopyInTest.java  |    84 -
 .../apache/doris/nereids/memo/MemoInitTest.java    |   182 -
 .../memo/{MemoRewriteTest.java => MemoTest.java}   |   307 +-
 .../doris/nereids/parser/NereidsParserTest.java    |     4 +-
 .../rules/implementation/ImplementationTest.java   |     9 +-
 .../rules/mv/BaseMaterializedIndexSelectTest.java  |    51 +
 .../doris/nereids/rules/mv/SelectMvIndexTest.java  |  1035 +
 ...tRollupTest.java => SelectRollupIndexTest.java} |   191 +-
 .../logical/PushdownFilterThroughJoinTest.java     |    34 +-
 .../rules/rewrite/logical/ReorderJoinTest.java     |    33 +-
 .../nereids/sqltest/CascadesJoinReorderTest.java   |    81 +
 .../doris/nereids/sqltest/MultiJoinTest.java       |    85 +-
 .../{MultiJoinTest.java => SqlTestBase.java}       |    60 +-
 .../doris/nereids/stats/StatsCalculatorTest.java   |    32 +-
 .../apache/doris/nereids/util/MemoTestUtils.java   |     4 +-
 .../org/apache/doris/nereids/util/PlanChecker.java |    14 +
 .../statistics/SampleSQLStatisticsTaskTest.java    |   205 +
 .../statistics/util/InternalSqlTemplateTest.java   |   299 +-
 .../apache/doris/system/SystemInfoServiceTest.java |    63 +
 .../doris/utframe/DemoMultiBackendsTest.java       |     5 +-
 .../apache/doris/utframe/TestWithFeService.java    |    57 +-
 .../java/org/apache/doris/udf/JdbcExecutor.java    |     8 +-
 .../org/apache/doris/load/loadv2/dpp/SparkDpp.java |    28 +-
 fs_brokers/apache_hdfs_broker/bin/start_broker.sh  |     5 +
 fs_brokers/apache_hdfs_broker/bin/stop_broker.sh   |     2 +-
 gensrc/script/doris_builtins_functions.py          |   119 +-
 gensrc/script/gen_builtins_functions.py            |     2 +
 gensrc/thrift/HeartbeatService.thrift              |     1 +
 gensrc/thrift/PlanNodes.thrift                     |     5 +
 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 +-
 regression-test/conf/regression-conf.groovy        |    17 +-
 .../data/correctness_p0/test_group_by_constant.out |     3 +
 .../data/correctness_p0/test_outer_join_sort.out   |     3 +
 ...ction.out => test_outer_join_with_subquery.out} |     0
 .../data/datev2/tpcds_sf1_p1/sql/q58.out           |     6 +-
 .../data/datev2/tpcds_sf1_p1/sql/q83.out           |    42 +-
 .../test_array_column_delete.out}                  |     3 +-
 .../test_javaudf_addone.out}                       |    23 +-
 .../data/jdbc_p0/test_jdbc_query_mysql.out         |  1031 +
 .../data/jdbc_p0/test_jdbc_query_pg.out            |  1032 +
 .../data/load_p0/broker_load/test_array_load.out   |    96 +-
 .../data/load_p0/broker_load/test_broker_load.out  |  4098 ++++
 .../data/load_p0/stream_load/array_malformat.csv   |     5 +
 .../data/load_p0/stream_load/array_normal.csv      |     9 +
 .../data/load_p0/stream_load/test_stream_load.out  |    18 +
 .../data/nereids_syntax_p0/function.out            |     5 +
 regression-test/data/query/join/test_join.out      |    18 +
 .../query/operator/test_arithmetic_operators.out   |   142 +-
 .../data/query/operator/test_logical_operators.out |    91 +-
 .../json_function/test_query_json_object.out}      |     7 +-
 regression-test/data/query_p0/sort/sort.out        |     9 +
 .../sql_functions/array_functions/sql/q01.out      |    27 +-
 .../sql_functions/array_functions/sql/q02.out      |    24 +-
 .../sql_functions/array_functions/sql/q03.out      |     5 +-
 .../array_functions/test_array_functions.out       |    45 +
 .../test_array_functions_by_literal.out            |   105 +
 .../test_array_functions_of_array_difference.out   |    10 +
 .../test_cast_array_functions_by_literal.out       |    22 +
 .../datetime_functions/test_date_function.out      |    20 +
 .../math_functions/test_multiply.out}              |     7 +-
 .../string_functions/test_string_function.out      |     9 +
 regression-test/data/query_p0/union/test_union.out |   222 +-
 .../data/schema_change_p0/test_rename_column.out   |   Bin 0 -> 4101 bytes
 regression-test/data/tpcds_sf1_p1/sql/q58.out      |     6 +-
 regression-test/data/tpcds_sf1_p1/sql/q83.out      |    42 +-
 .../data/tpcds_sf1_unique_p1/sql/q58.out           |     6 +-
 .../data/tpcds_sf1_unique_p1/sql/q83.out           |    42 +-
 .../multi_catalog_query_parquet/hive_catalog.out   | 20141 +++++++++++++++++++
 .../regression/action/StreamLoadAction.groovy      |    38 +
 .../doris/regression/action/TestAction.groovy      |    15 +-
 regression-test/java-udf-src/pom.xml               |    78 +
 .../src/main/java/org/apache/doris/udf/AddOne.java |     0
 .../bitmap_functions/test_bitmap_intersect.groovy  |     2 +-
 .../bloom_filter_p0/test_bloom_filter.groovy       |     5 +-
 .../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 +-
 .../suites/compaction/test_compaction_array.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   |    25 +-
 .../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     |    26 +-
 .../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 +-
 ...groovy => test_outer_join_with_subquery.groovy} |    54 +-
 .../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  |    30 +-
 .../storage/test_dup_tab_decimal_nullable.groovy   |    26 +-
 .../storage/test_dup_tab_mixed_type.groovy         |     2 +-
 .../test_dup_tab_mixed_type_nullable.groovy        |     2 +-
 .../data_model_p0/unique/test_unique_table.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 +-
 .../suites/datev2/ssb_sf1_p1/load.groovy           |     4 +-
 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      |    25 +-
 .../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/test_array_export.groovy         |     1 -
 .../suites/export_p0/test_outfile.groovy           |    12 +-
 .../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 +-
 .../insert_p0/test_array_insert_overflow.groovy    |     3 +-
 .../suites/javaudf_p0/test_javaudf_addone.groovy   |    69 +
 .../suites/jdbc_p0/test_jdbc_query_mysql.groovy    |    65 +
 .../suites/jdbc_p0/test_jdbc_query_pg.groovy       |    63 +
 .../suites/load/insert/test_array_insert.groovy    |     9 +-
 .../load/insert/test_array_string_insert.groovy    |     2 -
 .../load/insert/test_insert_nested_array.groovy    |     6 +-
 .../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    |    17 +
 .../broker_load/ddl/parquet_s3_case9_drop.sql      |     1 +
 .../load_p0/broker_load/test_array_load.groovy     |     8 +-
 .../load_p0/broker_load/test_broker_load.groovy    |    55 +-
 .../load_p0/stream_load/test_json_load.groovy      |    25 +-
 .../load_p0/stream_load/test_stream_load.groovy    |   119 +-
 .../suites/nereids_syntax_p0/agg_with_const.groovy |    13 +-
 .../suites/nereids_syntax_p0/function.groovy       |     4 +
 .../suites/nereids_syntax_p0/having.groovy         |    28 +-
 .../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          |     7 +-
 .../aggregate/aggregate_grouping_function.groovy   |     2 +-
 .../aggregate/aggregate_having_grouping.groovy     |     2 +-
 regression-test/suites/query/join/test_join.groovy |    19 +-
 .../suites/query/join/test_join3.groovy            |     6 +-
 .../suites/query/join/test_join4.groovy            |     4 +-
 .../suites/query/join/test_join5.groovy            |    18 +-
 .../query/operator/test_logical_operators.groovy   |     4 +-
 .../query/show/test_array_show_create.groovy       |    13 +-
 .../json_function/test_query_json_object.groovy}   |    42 +-
 .../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 +-
 .../q1.2.groovy => query_p0/sort/sort.groovy}      |    23 +-
 .../test_aggregate_all_functions.groovy            |     4 +-
 .../test_aggregate_collect.groovy                  |     1 -
 .../test_aggregate_retention.sql                   |     2 +-
 .../sql_functions/array_functions/sql/q01.sql      |     9 +-
 .../sql_functions/array_functions/sql/q02.sql      |     1 -
 .../sql_functions/array_functions/sql/q03.sql      |     3 +-
 .../test_array_aggregation_functions.groovy        |     2 -
 .../array_functions/test_array_functions.groovy    |    25 +-
 .../test_array_functions_by_literal.groovy         |    38 +-
 ...est_array_functions_of_array_difference.groovy} |    25 +-
 .../test_array_functions_with_where.groovy         |     2 -
 .../bitmap_functions/test_bitmap_function.groovy   |     6 +-
 .../cast_function/test_cast_array_function.groovy  |     2 -
 .../test_cast_array_functions_by_literal.groovy    |    41 +-
 .../cast_function/test_cast_string_to_array.groovy |     1 -
 .../datetime_functions/test_date_function.groovy   |    53 +
 .../math_functions/test_multiply.groovy            |    29 +-
 .../string_functions/test_string_function.groovy   |     4 +
 .../sql_functions/table_function/explode.groovy    |     1 -
 .../table_function/explode_json_array.groovy       |     2 +-
 .../table_function/explode_split.groovy            |     2 +-
 .../window_functions/test_ntile_function.groovy    |     4 +-
 .../test_select_stddev_variance_window.groovy      |     4 +-
 .../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        |     4 +-
 .../suites/query_p0/wide_table/sql/wide_table.sql  |     2 +-
 .../lateral_view/load_from_big_lateral_view.groovy |     2 +-
 ...groovy => test_materialized_view_bitmap.groovy} |    50 +-
 .../rollup/test_materialized_view_date.groovy      |     4 +-
 .../rollup/test_materialized_view_hll.groovy       |     2 +-
 ...test_materialized_view_hll_with_light_sc.groovy |     2 +-
 .../suites/rollup_p0/test_materialized_view.groovy |     4 +-
 .../rollup_p0/test_materialized_view_array.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     |   245 +
 .../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 +-
 .../sql_block_rule_p0/test_sql_block_rule.groovy   |     2 +-
 regression-test/suites/ssb_sf1/load.groovy         |     2 +-
 regression-test/suites/ssb_sf1/nereids/q1.1.groovy |    11 +-
 regression-test/suites/ssb_sf1/nereids/q1.2.groovy |    11 +-
 regression-test/suites/ssb_sf1/nereids/q1.3.groovy |    12 +-
 regression-test/suites/ssb_sf1/nereids/q2.1.groovy |    13 +-
 regression-test/suites/ssb_sf1/nereids/q2.2.groovy |    14 +-
 regression-test/suites/ssb_sf1/nereids/q2.3.groovy |    13 +-
 regression-test/suites/ssb_sf1/nereids/q3.1.groovy |    14 +-
 regression-test/suites/ssb_sf1/nereids/q3.2.groovy |    15 +-
 regression-test/suites/ssb_sf1/nereids/q3.3.groovy |    16 +-
 regression-test/suites/ssb_sf1/nereids/q3.4.groovy |    16 +-
 regression-test/suites/ssb_sf1/nereids/q4.1.groovy |    17 +-
 regression-test/suites/ssb_sf1/nereids/q4.2.groovy |    17 +-
 regression-test/suites/ssb_sf1/nereids/q4.3.groovy |    15 +-
 regression-test/suites/ssb_sf100_p2/load.groovy    |     2 +-
 regression-test/suites/ssb_sf1_p1/load.groovy      |     4 +-
 .../suites/tpcds_sf1_unique_p1/load.groovy         |     4 +-
 .../hive_catalog.groovy                            |   866 +
 .../suites/tpch_sf1_p1/tpch_sf1/nereids/q21.groovy |   107 +
 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 +-
 run-be-ut.sh                                       |    17 +-
 run-regression-test.sh                             |    10 +
 thirdparty/build-thirdparty.sh                     |   105 +-
 thirdparty/vars.sh                                 |    25 +-
 tools/find_libjvm.sh                               |     7 +-
 tools/tpch-tools/queries/q20.sql                   |     2 +-
 tools/tpch-tools/queries/q22.sql                   |     2 +-
 819 files changed, 45505 insertions(+), 8711 deletions(-)
 copy regression-test/suites/ssb_sf1/nereids/q1.1.groovy => be/src/agent/cgroups_mgr_mac.cpp (60%)
 create mode 100644 be/src/util/disk_info_mac.cpp
 copy regression-test/suites/ssb_sf1/nereids/q1.1.groovy => be/src/util/exception.cpp (60%)
 copy be/src/{vec/io/reader_buffer.h => util/exception.h} (61%)
 copy be/src/{vec/io/reader_buffer.h => util/perf_counters_mac.cpp} (60%)
 delete mode 100644 be/src/vec/exec/file_arrow_scanner.cpp
 delete mode 100644 be/src/vec/exec/file_arrow_scanner.h
 delete mode 100644 be/src/vec/exec/file_scan_node.cpp
 delete mode 100644 be/src/vec/exec/file_scan_node.h
 delete mode 100644 be/src/vec/exec/file_scanner.cpp
 delete mode 100644 be/src/vec/exec/file_scanner.h
 delete mode 100644 be/src/vec/exec/file_text_scanner.cpp
 delete mode 100644 be/src/vec/exec/file_text_scanner.h
 copy be/src/vec/{io/reader_buffer.h => exec/format/format_common.h} (52%)
 create mode 100644 be/src/vec/exec/format/orc/vorc_reader.cpp
 create mode 100644 be/src/vec/exec/format/orc/vorc_reader.h
 delete mode 100644 be/src/vec/exec/scan/new_file_arrow_scanner.cpp
 delete mode 100644 be/src/vec/exec/scan/new_file_arrow_scanner.h
 delete mode 100644 be/src/vec/exec/scan/new_file_scanner.cpp
 delete mode 100644 be/src/vec/exec/scan/new_file_scanner.h
 delete mode 100644 be/src/vec/exec/scan/new_file_text_scanner.cpp
 delete mode 100644 be/src/vec/exec/scan/new_file_text_scanner.h
 copy be/src/vec/{io/reader_buffer.h => functions/array/function_array_difference.cpp} (62%)
 create mode 100644 be/src/vec/functions/array/function_array_difference.h
 create mode 100644 be/src/vec/functions/array/function_array_enumerate.cpp
 copy tools/find_libjvm.sh => bin/check_be_version.sh (51%)
 mode change 100644 => 100755
 rename docker/thirdparties/docker-compose/{ => elasticsearch}/elasticsearch.yaml (100%)
 copy docker/thirdparties/{start-thirdparties-docker.sh => docker-compose/hive/gen_env.sh} (61%)
 create mode 100644 docker/thirdparties/docker-compose/hive/hadoop-hive.env.tpl
 create mode 100644 docker/thirdparties/docker-compose/hive/hive-2x.yaml
 create mode 100644 docker/thirdparties/docker-compose/hive/scripts/README
 create mode 100644 docker/thirdparties/docker-compose/hive/scripts/create.hql
 copy be/src/agent/CMakeLists.txt => docker/thirdparties/docker-compose/hive/scripts/healthy_check.sh (68%)
 mode change 100644 => 100755
 copy docker/thirdparties/{start-thirdparties-docker.sh => docker-compose/hive/scripts/hive-metastore.sh} (61%)
 create mode 100644 docker/thirdparties/docker-compose/mysql/init/01-drop-db.sql
 create mode 100644 docker/thirdparties/docker-compose/mysql/init/02-create-db.sql
 create mode 100644 docker/thirdparties/docker-compose/mysql/init/03-create-table.sql
 create mode 100644 docker/thirdparties/docker-compose/mysql/init/04-insert.sql
 copy be/src/agent/CMakeLists.txt => docker/thirdparties/docker-compose/mysql/mysql-5.7.env (68%)
 create mode 100644 docker/thirdparties/docker-compose/mysql/mysql-5.7.yaml
 create mode 100644 docker/thirdparties/docker-compose/postgresql/init/01-create-schema.sql
 create mode 100644 docker/thirdparties/docker-compose/postgresql/init/02-create-table.sql
 create mode 100644 docker/thirdparties/docker-compose/postgresql/init/03-insert.sql
 copy be/src/agent/CMakeLists.txt => docker/thirdparties/docker-compose/postgresql/postgresql-14.env (68%)
 create mode 100644 docker/thirdparties/docker-compose/postgresql/postgresql-14.yaml
 copy docker/thirdparties/{start-thirdparties-docker.sh => stop-thirdparties-docker.sh} (58%)
 create mode 100644 docs/en/docs/advanced/cold_hot_separation.md
 create mode 100644 docs/en/docs/sql-manual/sql-functions/array-functions/array_difference.md
 create mode 100644 docs/en/docs/sql-manual/sql-functions/array-functions/array_enumerate.md
 copy docs/en/docs/sql-manual/{sql-reference/Account-Management-Statements/LDAP.md => sql-functions/date-time-functions/last_day.md} (60%)
 create mode 100644 docs/en/docs/sql-manual/sql-functions/string-functions/extract_url_parameter.md
 copy docs/en/docs/sql-manual/{sql-reference/Data-Definition-Statements/Drop/DROP-POLICY.md => sql-functions/string-functions/not_null_or_empty.md} (50%)
 copy docs/{zh-CN/docs/sql-manual/sql-reference/Data-Definition-Statements/Alter/ALTER-RESOURCE.md => en/docs/sql-manual/sql-reference/Data-Definition-Statements/Alter/ALTER-STORAGE-POLICY.md} (59%)
 copy docs/{zh-CN => en}/docs/sql-manual/sql-reference/Show-Statements/SHOW-POLICY.md (62%)
 create mode 100644 docs/zh-CN/docs/advanced/cold_hot_separation.md
 create mode 100644 docs/zh-CN/docs/sql-manual/sql-functions/array-functions/array_difference.md
 create mode 100644 docs/zh-CN/docs/sql-manual/sql-functions/array-functions/array_enumerate.md
 copy docs/zh-CN/docs/sql-manual/{sql-reference/Account-Management-Statements/LDAP.md => sql-functions/date-time-functions/last_day.md} (58%)
 create mode 100644 docs/zh-CN/docs/sql-manual/sql-functions/string-functions/extract_url_parameter.md
 copy docs/zh-CN/docs/sql-manual/{sql-reference/Account-Management-Statements/LDAP.md => sql-functions/string-functions/not_null_or_empty.md} (50%)
 copy docs/zh-CN/docs/sql-manual/sql-reference/Data-Definition-Statements/Alter/{ALTER-RESOURCE.md => ALTER-STORAGE-POLICY.md} (63%)
 delete mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/jobs/cascades/ExploreGroupExpressionJob.java
 delete mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/jobs/cascades/ExploreGroupJob.java
 create mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/AbstractSelectMaterializedIndexRule.java
 rename fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/{SelectRollupWithAggregate.java => SelectMaterializedIndexWithAggregate.java} (61%)
 create mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/SelectMaterializedIndexWithoutAggregate.java
 delete mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/rules/mv/SelectRollupWithoutAggregate.java
 create mode 100644 fe/fe-core/src/main/java/org/apache/doris/nereids/trees/plans/FakePlan.java
 create mode 100644 fe/fe-core/src/main/java/org/apache/doris/persist/TableRenameColumnInfo.java
 create mode 100644 fe/fe-core/src/test/java/org/apache/doris/analysis/CreateViewStmtTest.java
 delete mode 100644 fe/fe-core/src/test/java/org/apache/doris/nereids/memo/MemoCopyInTest.java
 delete mode 100644 fe/fe-core/src/test/java/org/apache/doris/nereids/memo/MemoInitTest.java
 rename fe/fe-core/src/test/java/org/apache/doris/nereids/memo/{MemoRewriteTest.java => MemoTest.java} (74%)
 create mode 100644 fe/fe-core/src/test/java/org/apache/doris/nereids/rules/mv/BaseMaterializedIndexSelectTest.java
 create 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/{SelectRollupTest.java => SelectRollupIndexTest.java} (59%)
 create mode 100644 fe/fe-core/src/test/java/org/apache/doris/nereids/sqltest/CascadesJoinReorderTest.java
 copy fe/fe-core/src/test/java/org/apache/doris/nereids/sqltest/{MultiJoinTest.java => SqlTestBase.java} (56%)
 create mode 100644 fe/fe-core/src/test/java/org/apache/doris/statistics/SampleSQLStatisticsTaskTest.java
 copy regression-test/data/correctness_p0/{test_join_with_projection.out => test_outer_join_with_subquery.out} (100%)
 copy regression-test/data/{correctness_p0/test_group_by_constant.out => delete_p0/test_array_column_delete.out} (87%)
 copy regression-test/data/{correctness_p0/test_outer_join_sort.out => javaudf_p0/test_javaudf_addone.out} (63%)
 create mode 100644 regression-test/data/jdbc_p0/test_jdbc_query_mysql.out
 create mode 100644 regression-test/data/jdbc_p0/test_jdbc_query_pg.out
 create mode 100644 regression-test/data/load_p0/stream_load/array_malformat.csv
 create mode 100644 regression-test/data/load_p0/stream_load/array_normal.csv
 copy regression-test/data/{correctness_p0/test_group_by_constant.out => query/sql_functions/json_function/test_query_json_object.out} (60%)
 create mode 100644 regression-test/data/query_p0/sort/sort.out
 create mode 100644 regression-test/data/query_p0/sql_functions/array_functions/test_array_functions_of_array_difference.out
 create mode 100644 regression-test/data/query_p0/sql_functions/cast_function/test_cast_array_functions_by_literal.out
 copy regression-test/data/{correctness_p0/test_outer_join_sort.out => query_p0/sql_functions/math_functions/test_multiply.out} (76%)
 create mode 100644 regression-test/data/schema_change_p0/test_rename_column.out
 create mode 100644 regression-test/data/tpch_sf1_p0/multi_catalog_query_parquet/hive_catalog.out
 create mode 100644 regression-test/java-udf-src/pom.xml
 copy {samples/doris-demo/java-udf-demo => regression-test/java-udf-src}/src/main/java/org/apache/doris/udf/AddOne.java (100%)
 copy regression-test/suites/correctness_p0/{test_join_with_projection.groovy => test_outer_join_with_subquery.groovy} (50%)
 copy fe/fe-core/src/main/java/org/apache/doris/statistics/SampleSQLStatisticsTask.java => regression-test/suites/delete_p0/test_array_column_delete.groovy (52%)
 create mode 100644 regression-test/suites/javaudf_p0/test_javaudf_addone.groovy
 create mode 100644 regression-test/suites/jdbc_p0/test_jdbc_query_mysql.groovy
 create mode 100644 regression-test/suites/jdbc_p0/test_jdbc_query_pg.groovy
 create mode 100644 regression-test/suites/load_p0/broker_load/ddl/parquet_s3_case9_create.sql
 create mode 100644 regression-test/suites/load_p0/broker_load/ddl/parquet_s3_case9_drop.sql
 copy regression-test/suites/{insert_p0/test_array_insert_overflow.groovy => query/sql_functions/json_function/test_query_json_object.groovy} (57%)
 copy regression-test/suites/{ssb_sf1/nereids/q1.2.groovy => query_p0/sort/sort.groovy} (60%)
 copy regression-test/suites/{compaction/test_compaction_array.groovy => query_p0/sql_functions/array_functions/test_array_functions_of_array_difference.groovy} (65%)
 copy fe/fe-core/src/main/java/org/apache/doris/statistics/SampleSQLStatisticsTask.java => regression-test/suites/query_p0/sql_functions/math_functions/test_multiply.groovy (52%)
 copy regression-test/suites/rollup/{test_materialized_view_hll_with_light_sc.groovy => test_materialized_view_bitmap.groovy} (50%)
 create mode 100644 regression-test/suites/schema_change_p0/test_rename_column.groovy
 create mode 100644 regression-test/suites/tpch_sf1_p0/multi_catalog_query_parquet/hive_catalog.groovy
 create mode 100644 regression-test/suites/tpch_sf1_p1/tpch_sf1/nereids/q21.groovy
 mode change 100644 => 100755 tools/find_libjvm.sh


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