Skip to content

Commit

Permalink
[Doc] Add meaning of 0 for variables (#53714)
Browse files Browse the repository at this point in the history
(cherry picked from commit b42eff7ae3538bc2e4e6bba68fb959d7089086a7)

# Conflicts:
#	.github/CODEOWNERS
#	.github/PULL_REQUEST_TEMPLATE.md
#	.github/workflows/ci-comment-tools.yml
#	.github/workflows/ci-merged-sonarcloud-fe.yml
#	.github/workflows/ci-merged.yml
#	.github/workflows/ci-pipeline-branch.yml
#	.github/workflows/ci-pipeline.yml
#	.github/workflows/ci-report.yml
#	.github/workflows/ci-sync.yml
#	.github/workflows/inspection-pipeline.yml
#	.github/workflows/pr-checker.yml
#	.gitignore
#	.trivyignore
#	README.md
#	be/.gitignore
#	be/CMakeLists.txt
#	be/cmake_modules/FindClangTidy.cmake
#	be/src/agent/agent_task.cpp
#	be/src/agent/finish_task.cpp
#	be/src/agent/heartbeat_server.cpp
#	be/src/agent/publish_version.cpp
#	be/src/agent/report_task.cpp
#	be/src/agent/task_worker_pool.cpp
#	be/src/agent/utils.cpp
#	be/src/agent/utils.h
#	be/src/bench/CMakeLists.txt
#	be/src/bench/block_cache_bench.cpp
#	be/src/bench/chunks_sorter_bench.cpp
#	be/src/bench/csv_reader_bench.cpp
#	be/src/bench/get_dict_codes_bench.cpp
#	be/src/bench/orc_column_reader_bench.cpp
#	be/src/bench/parquet_dict_decode_bench.cpp
#	be/src/bench/persistent_index_bench.cpp
#	be/src/bench/runtime_filter_bench.cpp
#	be/src/bench/shuffle_chunk_bench.cpp
#	be/src/block_cache/CMakeLists.txt
#	be/src/block_cache/block_cache.cpp
#	be/src/block_cache/block_cache.h
#	be/src/block_cache/cache_options.h
#	be/src/block_cache/datacache_utils.cpp
#	be/src/block_cache/datacache_utils.h
#	be/src/block_cache/disk_space_monitor.cpp
#	be/src/block_cache/kv_cache.h
#	be/src/block_cache/starcache_wrapper.cpp
#	be/src/block_cache/starcache_wrapper.h
#	be/src/column/adaptive_nullable_column.cpp
#	be/src/column/adaptive_nullable_column.h
#	be/src/column/array_column.h
#	be/src/column/array_view_column.h
#	be/src/column/binary_column.cpp
#	be/src/column/binary_column.h
#	be/src/column/bytes.h
#	be/src/column/chunk.cpp
#	be/src/column/chunk.h
#	be/src/column/column.cpp
#	be/src/column/column.h
#	be/src/column/column_builder.h
#	be/src/column/column_hash.h
#	be/src/column/column_helper.cpp
#	be/src/column/column_helper.h
#	be/src/column/column_viewer.cpp
#	be/src/column/const_column.cpp
#	be/src/column/const_column.h
#	be/src/column/datum.h
#	be/src/column/field.h
#	be/src/column/fixed_length_column_base.cpp
#	be/src/column/fixed_length_column_base.h
#	be/src/column/hash_set.h
#	be/src/column/json_column.cpp
#	be/src/column/json_column.h
#	be/src/column/map_column.h
#	be/src/column/nullable_column.cpp
#	be/src/column/nullable_column.h
#	be/src/column/object_column.cpp
#	be/src/column/object_column.h
#	be/src/column/schema.cpp
#	be/src/column/struct_column.cpp
#	be/src/column/struct_column.h
#	be/src/column/vectorized_fwd.h
#	be/src/common/config.h
#	be/src/common/daemon.cpp
#	be/src/common/logconfig.cpp
#	be/src/common/logging.h
#	be/src/common/status.cpp
#	be/src/common/status.h
#	be/src/connector/CMakeLists.txt
#	be/src/connector/connector.cpp
#	be/src/connector/connector.h
#	be/src/connector/hive_connector.cpp
#	be/src/connector/hive_connector.h
#	be/src/connector/lake_connector.cpp
#	be/src/connector/lake_connector.h
#	be/src/exec/CMakeLists.txt
#	be/src/exec/aggregate/agg_hash_map.h
#	be/src/exec/aggregate/agg_hash_set.h
#	be/src/exec/aggregate/aggregate_base_node.cpp
#	be/src/exec/aggregator.cpp
#	be/src/exec/aggregator.h
#	be/src/exec/analytor.cpp
#	be/src/exec/analytor.h
#	be/src/exec/arrow_to_starrocks_converter.cpp
#	be/src/exec/arrow_to_starrocks_converter.h
#	be/src/exec/capture_version_node.cpp
#	be/src/exec/chunks_sorter.cpp
#	be/src/exec/chunks_sorter.h
#	be/src/exec/chunks_sorter_full_sort.h
#	be/src/exec/chunks_sorter_heap_sort.h
#	be/src/exec/chunks_sorter_topn.h
#	be/src/exec/connector_scan_node.cpp
#	be/src/exec/csv_scanner.cpp
#	be/src/exec/csv_scanner.h
#	be/src/exec/data_sink.cpp
#	be/src/exec/data_sink.h
#	be/src/exec/dictionary_cache_writer.h
#	be/src/exec/es/es_predicate.cpp
#	be/src/exec/es/es_scan_reader.cpp
#	be/src/exec/except_hash_set.cpp
#	be/src/exec/except_hash_set.h
#	be/src/exec/exec_node.h
#	be/src/exec/file_scanner.cpp
#	be/src/exec/hash_join_components.cpp
#	be/src/exec/hash_join_components.h
#	be/src/exec/hash_join_node.cpp
#	be/src/exec/hash_join_node.h
#	be/src/exec/hash_joiner.cpp
#	be/src/exec/hash_joiner.h
#	be/src/exec/hdfs_scanner.cpp
#	be/src/exec/hdfs_scanner.h
#	be/src/exec/hdfs_scanner_orc.cpp
#	be/src/exec/hdfs_scanner_parquet.cpp
#	be/src/exec/hdfs_scanner_text.cpp
#	be/src/exec/iceberg/iceberg_delete_builder.cpp
#	be/src/exec/iceberg/iceberg_delete_builder.h
#	be/src/exec/intersect_hash_set.cpp
#	be/src/exec/intersect_hash_set.h
#	be/src/exec/jdbc_scanner.cpp
#	be/src/exec/jdbc_scanner.h
#	be/src/exec/jni_scanner.cpp
#	be/src/exec/jni_scanner.h
#	be/src/exec/join_hash_map.cpp
#	be/src/exec/join_hash_map.h
#	be/src/exec/join_hash_map.tpp
#	be/src/exec/json_scanner.cpp
#	be/src/exec/json_scanner.h
#	be/src/exec/local_file_writer.cpp
#	be/src/exec/olap_common.cpp
#	be/src/exec/olap_common.h
#	be/src/exec/olap_scan_node.cpp
#	be/src/exec/olap_scan_node.h
#	be/src/exec/olap_scan_prepare.cpp
#	be/src/exec/olap_scan_prepare.h
#	be/src/exec/olap_utils.h
#	be/src/exec/orc_scanner.cpp
#	be/src/exec/parquet_reader.cpp
#	be/src/exec/parquet_reader.h
#	be/src/exec/parquet_scanner.cpp
#	be/src/exec/partition/chunks_partitioner.cpp
#	be/src/exec/partition/chunks_partitioner.h
#	be/src/exec/partition/partition_hash_map.h
#	be/src/exec/partition/partition_hash_variant.cpp
#	be/src/exec/partition/partition_hash_variant.h
#	be/src/exec/pipeline/aggregate/aggregate_blocking_sink_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_blocking_source_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_distinct_blocking_sink_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_distinct_blocking_source_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_distinct_streaming_sink_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_distinct_streaming_source_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_streaming_sink_operator.h
#	be/src/exec/pipeline/aggregate/aggregate_streaming_source_operator.h
#	be/src/exec/pipeline/aggregate/sorted_aggregate_streaming_sink_operator.h
#	be/src/exec/pipeline/aggregate/sorted_aggregate_streaming_source_operator.h
#	be/src/exec/pipeline/aggregate/spillable_aggregate_blocking_sink_operator.h
#	be/src/exec/pipeline/aggregate/spillable_aggregate_blocking_source_operator.h
#	be/src/exec/pipeline/aggregate/spillable_aggregate_distinct_blocking_operator.h
#	be/src/exec/pipeline/audit_statistics_reporter.cpp
#	be/src/exec/pipeline/audit_statistics_reporter.h
#	be/src/exec/pipeline/chunk_accumulate_operator.h
#	be/src/exec/pipeline/context_with_dependency.h
#	be/src/exec/pipeline/exchange/exchange_sink_operator.cpp
#	be/src/exec/pipeline/exchange/local_exchange_sink_operator.h
#	be/src/exec/pipeline/exchange/local_exchange_source_operator.h
#	be/src/exec/pipeline/exchange/mem_limited_chunk_queue.cpp
#	be/src/exec/pipeline/exchange/multi_cast_local_exchange_sink_operator.h
#	be/src/exec/pipeline/exchange/multi_cast_local_exchange_source_operator.h
#	be/src/exec/pipeline/exchange/sink_buffer.cpp
#	be/src/exec/pipeline/exchange/sink_buffer.h
#	be/src/exec/pipeline/exec_state_reporter.cpp
#	be/src/exec/pipeline/fragment_context.cpp
#	be/src/exec/pipeline/fragment_context.h
#	be/src/exec/pipeline/fragment_executor.cpp
#	be/src/exec/pipeline/fragment_executor.h
#	be/src/exec/pipeline/hash_partition_context.cpp
#	be/src/exec/pipeline/hash_partition_context.h
#	be/src/exec/pipeline/hashjoin/hash_join_build_operator.cpp
#	be/src/exec/pipeline/hashjoin/hash_join_build_operator.h
#	be/src/exec/pipeline/hashjoin/hash_join_probe_operator.cpp
#	be/src/exec/pipeline/hashjoin/hash_join_probe_operator.h
#	be/src/exec/pipeline/hashjoin/spillable_hash_join_build_operator.cpp
#	be/src/exec/pipeline/hashjoin/spillable_hash_join_build_operator.h
#	be/src/exec/pipeline/hashjoin/spillable_hash_join_probe_operator.cpp
#	be/src/exec/pipeline/hashjoin/spillable_hash_join_probe_operator.h
#	be/src/exec/pipeline/limit_operator.cpp
#	be/src/exec/pipeline/limit_operator.h
#	be/src/exec/pipeline/nljoin/nljoin_build_operator.h
#	be/src/exec/pipeline/nljoin/nljoin_context.cpp
#	be/src/exec/pipeline/nljoin/nljoin_context.h
#	be/src/exec/pipeline/nljoin/nljoin_probe_operator.cpp
#	be/src/exec/pipeline/nljoin/nljoin_probe_operator.h
#	be/src/exec/pipeline/nljoin/spillable_nljoin_probe_operator.h
#	be/src/exec/pipeline/operator.cpp
#	be/src/exec/pipeline/operator.h
#	be/src/exec/pipeline/pipeline.h
#	be/src/exec/pipeline/pipeline_driver.cpp
#	be/src/exec/pipeline/pipeline_driver.h
#	be/src/exec/pipeline/pipeline_fwd.h
#	be/src/exec/pipeline/query_context.cpp
#	be/src/exec/pipeline/query_context.h
#	be/src/exec/pipeline/result_sink_operator.cpp
#	be/src/exec/pipeline/result_sink_operator.h
#	be/src/exec/pipeline/runtime_filter_types.h
#	be/src/exec/pipeline/scan/chunk_source.h
#	be/src/exec/pipeline/scan/connector_scan_operator.cpp
#	be/src/exec/pipeline/scan/connector_scan_operator.h
#	be/src/exec/pipeline/scan/meta_scan_operator.cpp
#	be/src/exec/pipeline/scan/meta_scan_operator.h
#	be/src/exec/pipeline/scan/meta_scan_prepare_operator.cpp
#	be/src/exec/pipeline/scan/morsel.cpp
#	be/src/exec/pipeline/scan/morsel.h
#	be/src/exec/pipeline/scan/olap_chunk_source.cpp
#	be/src/exec/pipeline/scan/olap_chunk_source.h
#	be/src/exec/pipeline/scan/olap_scan_context.cpp
#	be/src/exec/pipeline/scan/olap_scan_context.h
#	be/src/exec/pipeline/scan/olap_scan_operator.cpp
#	be/src/exec/pipeline/scan/olap_scan_operator.h
#	be/src/exec/pipeline/scan/scan_operator.cpp
#	be/src/exec/pipeline/scan/scan_operator.h
#	be/src/exec/pipeline/scan/schema_scan_operator.cpp
#	be/src/exec/pipeline/scan/schema_scan_operator.h
#	be/src/exec/pipeline/select_operator.cpp
#	be/src/exec/pipeline/select_operator.h
#	be/src/exec/pipeline/sort/local_partition_topn_context.cpp
#	be/src/exec/pipeline/sort/local_partition_topn_context.h
#	be/src/exec/pipeline/sort/sort_context.cpp
#	be/src/exec/pipeline/sort/sort_context.h
#	be/src/exec/pipeline/stream_epoch_manager.h
#	be/src/exec/pipeline/stream_pipeline_driver.h
#	be/src/exec/pipeline/table_function_operator.h
#	be/src/exec/query_cache/cache_manager.h
#	be/src/exec/query_cache/cache_operator.cpp
#	be/src/exec/query_cache/cache_operator.h
#	be/src/exec/query_cache/cache_param.h
#	be/src/exec/query_cache/multilane_operator.h
#	be/src/exec/scan_node.cpp
#	be/src/exec/scan_node.h
#	be/src/exec/schema_scan_node.cpp
#	be/src/exec/select_node.cpp
#	be/src/exec/select_node.h
#	be/src/exec/sorted_streaming_aggregator.cpp
#	be/src/exec/sorted_streaming_aggregator.h
#	be/src/exec/sorting/compare_column.cpp
#	be/src/exec/sorting/merge.h
#	be/src/exec/sorting/merge_column.cpp
#	be/src/exec/sorting/sort_permute.h
#	be/src/exec/sorting/sorting.h
#	be/src/exec/spill/common.h
#	be/src/exec/spill/mem_table.cpp
#	be/src/exec/spill/mem_table.h
#	be/src/exec/spill/spiller.h
#	be/src/exec/stream/aggregate/agg_group_state.cpp
#	be/src/exec/stream/aggregate/agg_group_state.h
#	be/src/exec/stream/aggregate/agg_state_data.cpp
#	be/src/exec/stream/aggregate/agg_state_data.h
#	be/src/exec/stream/aggregate/stream_aggregate_operator.h
#	be/src/exec/stream/aggregate/stream_aggregator.h
#	be/src/exec/stream/scan/stream_scan_operator.h
#	be/src/exec/stream/state/mem_state_table.cpp
#	be/src/exec/stream/state/mem_state_table.h
#	be/src/exec/stream/state/state_table.h
#	be/src/exec/tablet_info.cpp
#	be/src/exec/tablet_info.h
#	be/src/exec/tablet_scanner.cpp
#	be/src/exec/tablet_scanner.h
#	be/src/exec/tablet_sink.cpp
#	be/src/exec/tablet_sink.h
#	be/src/exec/tablet_sink_index_channel.cpp
#	be/src/exec/tablet_sink_index_channel.h
#	be/src/exec/tablet_sink_sender.cpp
#	be/src/exec/topn_node.cpp
#	be/src/exec/topn_node.h
#	be/src/exec/union_node.h
#	be/src/exec/write_combined_txn_log.h
#	be/src/exprs/CMakeLists.txt
#	be/src/exprs/agg/aggregate.h
#	be/src/exprs/agg/aggregate_factory.h
#	be/src/exprs/agg/approx_top_k.h
#	be/src/exprs/agg/array_agg.h
#	be/src/exprs/agg/array_union_agg.h
#	be/src/exprs/agg/avg.h
#	be/src/exprs/agg/bitmap_agg.h
#	be/src/exprs/agg/count.h
#	be/src/exprs/agg/distinct.h
#	be/src/exprs/agg/factory/aggregate_factory.cpp
#	be/src/exprs/agg/factory/aggregate_factory.hpp
#	be/src/exprs/agg/factory/aggregate_resolver.hpp
#	be/src/exprs/agg/factory/aggregate_resolver_approx.cpp
#	be/src/exprs/agg/factory/aggregate_resolver_avg.cpp
#	be/src/exprs/agg/factory/aggregate_resolver_minmaxany.cpp
#	be/src/exprs/agg/factory/aggregate_resolver_others.cpp
#	be/src/exprs/agg/group_concat.h
#	be/src/exprs/agg/hll_ndv.h
#	be/src/exprs/agg/hll_union.h
#	be/src/exprs/agg/hll_union_count.h
#	be/src/exprs/agg/java_udaf_function.h
#	be/src/exprs/agg/nullable_aggregate.h
#	be/src/exprs/agg/percentile_approx.h
#	be/src/exprs/agg/percentile_cont.h
#	be/src/exprs/agg/percentile_union.h
#	be/src/exprs/agg/sum.h
#	be/src/exprs/agg/window.h
#	be/src/exprs/arithmetic_expr.cpp
#	be/src/exprs/arithmetic_operation.h
#	be/src/exprs/array_element_expr.cpp
#	be/src/exprs/array_functions.tpp
#	be/src/exprs/array_map_expr.cpp
#	be/src/exprs/binary_predicate.cpp
#	be/src/exprs/bitmap_functions.cpp
#	be/src/exprs/builtin_functions.h
#	be/src/exprs/case_expr.cpp
#	be/src/exprs/cast_expr.cpp
#	be/src/exprs/cast_expr.h
#	be/src/exprs/compound_predicate.cpp
#	be/src/exprs/debug_expr.cpp
#	be/src/exprs/debug_expr.h
#	be/src/exprs/decimal_binary_function.h
#	be/src/exprs/expr.cpp
#	be/src/exprs/expr.h
#	be/src/exprs/expr_context.cpp
#	be/src/exprs/expr_context.h
#	be/src/exprs/function_call_expr.cpp
#	be/src/exprs/function_call_expr.h
#	be/src/exprs/function_context.cpp
#	be/src/exprs/function_context.h
#	be/src/exprs/function_helper.cpp
#	be/src/exprs/function_helper.h
#	be/src/exprs/in_const_predicate.hpp
#	be/src/exprs/java_function_call_expr.cpp
#	be/src/exprs/java_function_call_expr.h
#	be/src/exprs/jit/jit_expr.cpp
#	be/src/exprs/json_functions.h
#	be/src/exprs/like_predicate.cpp
#	be/src/exprs/literal.cpp
#	be/src/exprs/literal.h
#	be/src/exprs/locate.cpp
#	be/src/exprs/map_apply_expr.cpp
#	be/src/exprs/map_functions.cpp
#	be/src/exprs/math_functions.cpp
#	be/src/exprs/math_functions.h
#	be/src/exprs/percentile_functions.cpp
#	be/src/exprs/runtime_filter_bank.cpp
#	be/src/exprs/runtime_filter_bank.h
#	be/src/exprs/split.cpp
#	be/src/exprs/string_functions.cpp
#	be/src/exprs/string_functions.h
#	be/src/exprs/table_function/generate_series.h
#	be/src/exprs/table_function/java_udtf_function.h
#	be/src/exprs/table_function/json_each.h
#	be/src/exprs/table_function/list_rowsets.cpp
#	be/src/exprs/table_function/list_rowsets.h
#	be/src/exprs/table_function/multi_unnest.h
#	be/src/exprs/table_function/subdivide_bitmap.h
#	be/src/exprs/table_function/table_function.h
#	be/src/exprs/table_function/unnest.h
#	be/src/exprs/unary_function.h
#	be/src/exprs/utility_functions.cpp
#	be/src/exprs/utility_functions.h
#	be/src/formats/CMakeLists.txt
#	be/src/formats/csv/json_converter.h
#	be/src/formats/orc/apache-orc/c++/include/orc/Common.hh
#	be/src/formats/orc/apache-orc/c++/src/Int128.cc
#	be/src/formats/orc/apache-orc/c++/src/Statistics.hh
#	be/src/formats/orc/orc_chunk_reader.cpp
#	be/src/formats/parquet/chunk_writer.cpp
#	be/src/formats/parquet/chunk_writer.h
#	be/src/formats/parquet/column_chunk_reader.cpp
#	be/src/formats/parquet/column_chunk_reader.h
#	be/src/formats/parquet/column_chunk_writer.cpp
#	be/src/formats/parquet/column_chunk_writer.h
#	be/src/formats/parquet/column_converter.cpp
#	be/src/formats/parquet/column_converter.h
#	be/src/formats/parquet/column_read_order_ctx.cpp
#	be/src/formats/parquet/column_read_order_ctx.h
#	be/src/formats/parquet/column_reader.cpp
#	be/src/formats/parquet/column_reader.h
#	be/src/formats/parquet/encoding.cpp
#	be/src/formats/parquet/encoding.h
#	be/src/formats/parquet/encoding_dict.h
#	be/src/formats/parquet/file_reader.cpp
#	be/src/formats/parquet/file_reader.h
#	be/src/formats/parquet/file_writer.cpp
#	be/src/formats/parquet/file_writer.h
#	be/src/formats/parquet/group_reader.cpp
#	be/src/formats/parquet/group_reader.h
#	be/src/formats/parquet/level_builder.cpp
#	be/src/formats/parquet/level_builder.h
#	be/src/formats/parquet/level_codec.cpp
#	be/src/formats/parquet/level_codec.h
#	be/src/formats/parquet/meta_helper.cpp
#	be/src/formats/parquet/meta_helper.h
#	be/src/formats/parquet/metadata.cpp
#	be/src/formats/parquet/metadata.h
#	be/src/formats/parquet/page_index_reader.cpp
#	be/src/formats/parquet/page_index_reader.h
#	be/src/formats/parquet/page_reader.cpp
#	be/src/formats/parquet/page_reader.h
#	be/src/formats/parquet/parquet_file_writer.cpp
#	be/src/formats/parquet/parquet_file_writer.h
#	be/src/formats/parquet/schema.cpp
#	be/src/formats/parquet/schema.h
#	be/src/formats/parquet/statistics_helper.cpp
#	be/src/formats/parquet/statistics_helper.h
#	be/src/formats/parquet/stored_column_reader.cpp
#	be/src/formats/parquet/stored_column_reader.h
#	be/src/formats/parquet/stored_column_reader_with_index.cpp
#	be/src/formats/parquet/stored_column_reader_with_index.h
#	be/src/formats/parquet/utils.cpp
#	be/src/formats/parquet/utils.h
#	be/src/fs/CMakeLists.txt
#	be/src/fs/fs.cpp
#	be/src/fs/fs.h
#	be/src/fs/fs_broker.cpp
#	be/src/fs/fs_s3.cpp
#	be/src/fs/fs_s3.h
#	be/src/fs/fs_starlet.cpp
#	be/src/fs/hdfs/fs_hdfs.cpp
#	be/src/gen_cpp/CMakeLists.txt
#	be/src/geo/wkt_parse.cpp
#	be/src/geo/wkt_yacc.y
#	be/src/gutil/CMakeLists.txt
#	be/src/gutil/strings/join.h
#	be/src/http/action/checksum_action.cpp
#	be/src/http/action/datacache_action.cpp
#	be/src/http/action/memory_metrics_action.cpp
#	be/src/http/action/metrics_action.h
#	be/src/http/action/stream_load.cpp
#	be/src/http/action/stream_load.h
#	be/src/http/action/update_config_action.cpp
#	be/src/http/default_path_handlers.cpp
#	be/src/http/download_action.cpp
#	be/src/http/http_client.h
#	be/src/http/http_common.h
#	be/src/io/cache_input_stream.cpp
#	be/src/io/cache_input_stream.h
#	be/src/io/cache_select_input_stream.hpp
#	be/src/io/direct_s3_output_stream.cpp
#	be/src/io/s3_input_stream.cpp
#	be/src/io/s3_input_stream.h
#	be/src/io/s3_output_stream.cpp
#	be/src/runtime/CMakeLists.txt
#	be/src/runtime/broker_mgr.cpp
#	be/src/runtime/buffer_control_block.cpp
#	be/src/runtime/buffer_control_block.h
#	be/src/runtime/chunk_cursor.h
#	be/src/runtime/customized_result_writer.cpp
#	be/src/runtime/customized_result_writer.h
#	be/src/runtime/data_stream_mgr.h
#	be/src/runtime/data_stream_sender.cpp
#	be/src/runtime/data_stream_sender.h
#	be/src/runtime/descriptors.cpp
#	be/src/runtime/descriptors.h
#	be/src/runtime/exec_env.cpp
#	be/src/runtime/exec_env.h
#	be/src/runtime/file_result_writer.h
#	be/src/runtime/fragment_mgr.cpp
#	be/src/runtime/fragment_mgr.h
#	be/src/runtime/global_dict/miscs.cpp
#	be/src/runtime/global_dict/parser.cpp
#	be/src/runtime/global_dict/parser.h
#	be/src/runtime/http_result_writer.cpp
#	be/src/runtime/http_result_writer.h
#	be/src/runtime/lake_snapshot_loader.cpp
#	be/src/runtime/lake_tablets_channel.cpp
#	be/src/runtime/load_channel.cpp
#	be/src/runtime/load_channel.h
#	be/src/runtime/load_path_mgr.cpp
#	be/src/runtime/local_tablets_channel.cpp
#	be/src/runtime/local_tablets_channel.h
#	be/src/runtime/mem_pool.h
#	be/src/runtime/metadata_result_writer.cpp
#	be/src/runtime/metadata_result_writer.h
#	be/src/runtime/mysql_result_writer.cpp
#	be/src/runtime/mysql_result_writer.h
#	be/src/runtime/plan_fragment_executor.cpp
#	be/src/runtime/query_statistics.cpp
#	be/src/runtime/query_statistics.h
#	be/src/runtime/result_buffer_mgr.cpp
#	be/src/runtime/result_buffer_mgr.h
#	be/src/runtime/result_queue_mgr.h
#	be/src/runtime/result_sink.cpp
#	be/src/runtime/result_sink.h
#	be/src/runtime/result_writer.h
#	be/src/runtime/runtime_filter_worker.cpp
#	be/src/runtime/runtime_filter_worker.h
#	be/src/runtime/runtime_state.cpp
#	be/src/runtime/runtime_state.h
#	be/src/runtime/schema_table_sink.cpp
#	be/src/runtime/small_file_mgr.h
#	be/src/runtime/snapshot_loader.cpp
#	be/src/runtime/statistic_result_writer.cpp
#	be/src/runtime/statistic_result_writer.h
#	be/src/runtime/stream_load/stream_load_context.cpp
#	be/src/runtime/stream_load/stream_load_context.h
#	be/src/runtime/stream_load/stream_load_pipe.cpp
#	be/src/runtime/stream_load/stream_load_pipe.h
#	be/src/runtime/stream_load/transaction_mgr.h
#	be/src/runtime/table_function_table_sink.cpp
#	be/src/runtime/table_function_table_sink.h
#	be/src/runtime/tablets_channel.h
#	be/src/runtime/time_types.h
#	be/src/runtime/types.cpp
#	be/src/runtime/types.h
#	be/src/runtime/user_function_cache.cpp
#	be/src/runtime/user_function_cache.h
#	be/src/runtime/variable_result_writer.cpp
#	be/src/runtime/variable_result_writer.h
#	be/src/script/CMakeLists.txt
#	be/src/script/script.cpp
#	be/src/serde/column_array_serde.cpp
#	be/src/service/CMakeLists.txt
#	be/src/service/internal_service.cpp
#	be/src/service/internal_service.h
#	be/src/service/mem_hook.cpp
#	be/src/service/service_be/CMakeLists.txt
#	be/src/service/service_be/internal_service.cpp
#	be/src/service/service_be/internal_service.h
#	be/src/service/service_be/lake_service.cpp
#	be/src/service/service_be/lake_service.h
#	be/src/service/service_be/starrocks_be.cpp
#	be/src/service/staros_worker.cpp
#	be/src/service/staros_worker.h
#	be/src/service/starrocks_main.cpp
#	be/src/simd/simd.h
#	be/src/storage/CMakeLists.txt
#	be/src/storage/aggregate_iterator.cpp
#	be/src/storage/aggregate_type.cpp
#	be/src/storage/aggregate_type.h
#	be/src/storage/async_delta_writer.cpp
#	be/src/storage/base_tablet.h
#	be/src/storage/chunk_aggregator.cpp
#	be/src/storage/chunk_helper.cpp
#	be/src/storage/chunk_helper.h
#	be/src/storage/chunk_iterator.cpp
#	be/src/storage/chunk_iterator.h
#	be/src/storage/column_aggregate_func.cpp
#	be/src/storage/column_aggregate_func.h
#	be/src/storage/column_expr_predicate.h
#	be/src/storage/column_in_predicate.cpp
#	be/src/storage/column_not_in_predicate.cpp
#	be/src/storage/column_null_predicate.cpp
#	be/src/storage/column_operator_predicate.h
#	be/src/storage/column_or_predicate.cpp
#	be/src/storage/column_or_predicate.h
#	be/src/storage/column_predicate.h
#	be/src/storage/column_predicate_cmp.cpp
#	be/src/storage/column_predicate_dict_conjuct.cpp
#	be/src/storage/column_predicate_rewriter.cpp
#	be/src/storage/column_predicate_rewriter.h
#	be/src/storage/compaction.cpp
#	be/src/storage/compaction_manager.h
#	be/src/storage/compaction_task.cpp
#	be/src/storage/compaction_task.h
#	be/src/storage/compaction_utils.cpp
#	be/src/storage/compaction_utils.h
#	be/src/storage/delta_writer.cpp
#	be/src/storage/delta_writer.h
#	be/src/storage/horizontal_compaction_task.cpp
#	be/src/storage/lake/async_delta_writer.cpp
#	be/src/storage/lake/async_delta_writer.h
#	be/src/storage/lake/delta_writer.cpp
#	be/src/storage/lake/delta_writer.h
#	be/src/storage/lake/general_tablet_writer.cpp
#	be/src/storage/lake/horizontal_compaction_task.cpp
#	be/src/storage/lake/lake_primary_index.cpp
#	be/src/storage/lake/lake_primary_key_compaction_conflict_resolver.cpp
#	be/src/storage/lake/lake_primary_key_compaction_conflict_resolver.h
#	be/src/storage/lake/location_provider.h
#	be/src/storage/lake/meta_file.cpp
#	be/src/storage/lake/meta_file.h
#	be/src/storage/lake/metacache.h
#	be/src/storage/lake/pk_tablet_writer.cpp
#	be/src/storage/lake/rowset.cpp
#	be/src/storage/lake/rowset.h
#	be/src/storage/lake/schema_change.cpp
#	be/src/storage/lake/starlet_location_provider.cpp
#	be/src/storage/lake/starlet_location_provider.h
#	be/src/storage/lake/tablet.cpp
#	be/src/storage/lake/tablet.h
#	be/src/storage/lake/tablet_manager.cpp
#	be/src/storage/lake/tablet_manager.h
#	be/src/storage/lake/tablet_reader.cpp
#	be/src/storage/lake/tablet_reader.h
#	be/src/storage/lake/tablet_writer.h
#	be/src/storage/lake/transactions.cpp
#	be/src/storage/lake/transactions.h
#	be/src/storage/lake/txn_log_applier.cpp
#	be/src/storage/lake/update_manager.cpp
#	be/src/storage/lake/update_manager.h
#	be/src/storage/lake/vacuum.cpp
#	be/src/storage/lake/versioned_tablet.cpp
#	be/src/storage/lake/versioned_tablet.h
#	be/src/storage/lake/vertical_compaction_task.cpp
#	be/src/storage/local_primary_key_recover.cpp
#	be/src/storage/memtable.cpp
#	be/src/storage/memtable.h
#	be/src/storage/memtable_flush_executor.cpp
#	be/src/storage/memtable_flush_executor.h
#	be/src/storage/merge_iterator.cpp
#	be/src/storage/meta_reader.cpp
#	be/src/storage/meta_reader.h
#	be/src/storage/metadata_util.cpp
#	be/src/storage/olap_common.h
#	be/src/storage/olap_meta_reader.cpp
#	be/src/storage/olap_runtime_range_pruner.h
#	be/src/storage/olap_runtime_range_pruner.hpp
#	be/src/storage/options.h
#	be/src/storage/persistent_index.cpp
#	be/src/storage/predicate_parser.cpp
#	be/src/storage/predicate_parser.h
#	be/src/storage/predicate_tree/predicate_tree.cpp
#	be/src/storage/predicate_tree/predicate_tree.h
#	be/src/storage/predicate_tree/predicate_tree.hpp
#	be/src/storage/predicate_tree/predicate_tree_fwd.h
#	be/src/storage/primary_index.cpp
#	be/src/storage/projection_iterator.cpp
#	be/src/storage/protobuf_file.cpp
#	be/src/storage/protobuf_file.h
#	be/src/storage/range.h
#	be/src/storage/roaring2range.h
#	be/src/storage/row_source_mask.cpp
#	be/src/storage/rowset/array_column_iterator.h
#	be/src/storage/rowset/array_column_writer.cpp
#	be/src/storage/rowset/base_rowset.h
#	be/src/storage/rowset/binary_dict_page.h
#	be/src/storage/rowset/binary_plain_page.h
#	be/src/storage/rowset/binary_prefix_page.cpp
#	be/src/storage/rowset/binary_prefix_page.h
#	be/src/storage/rowset/bitmap_range_iterator.h
#	be/src/storage/rowset/bitshuffle_page.h
#	be/src/storage/rowset/cast_column_iterator.h
#	be/src/storage/rowset/column_iterator.h
#	be/src/storage/rowset/column_iterator_decorator.h
#	be/src/storage/rowset/column_reader.cpp
#	be/src/storage/rowset/column_reader.h
#	be/src/storage/rowset/column_writer.cpp
#	be/src/storage/rowset/column_writer.h
#	be/src/storage/rowset/default_value_column_iterator.cpp
#	be/src/storage/rowset/default_value_column_iterator.h
#	be/src/storage/rowset/fill_subfield_iterator.h
#	be/src/storage/rowset/frame_of_reference_page.h
#	be/src/storage/rowset/horizontal_update_rowset_writer.cpp
#	be/src/storage/rowset/indexed_column_reader.cpp
#	be/src/storage/rowset/indexed_column_reader.h
#	be/src/storage/rowset/json_column_iterator.cpp
#	be/src/storage/rowset/map_column_iterator.h
#	be/src/storage/rowset/ordinal_page_index.cpp
#	be/src/storage/rowset/ordinal_page_index.h
#	be/src/storage/rowset/page_decoder.h
#	be/src/storage/rowset/parsed_page.cpp
#	be/src/storage/rowset/parsed_page.h
#	be/src/storage/rowset/plain_page.h
#	be/src/storage/rowset/rle_page.h
#	be/src/storage/rowset/rowid_column_iterator.h
#	be/src/storage/rowset/rowset.cpp
#	be/src/storage/rowset/rowset.h
#	be/src/storage/rowset/rowset_meta.cpp
#	be/src/storage/rowset/rowset_meta.h
#	be/src/storage/rowset/rowset_options.h
#	be/src/storage/rowset/rowset_writer.cpp
#	be/src/storage/rowset/rowset_writer.h
#	be/src/storage/rowset/rowset_writer_context.h
#	be/src/storage/rowset/scalar_column_iterator.cpp
#	be/src/storage/rowset/scalar_column_iterator.h
#	be/src/storage/rowset/segment.cpp
#	be/src/storage/rowset/segment.h
#	be/src/storage/rowset/segment_iterator.cpp
#	be/src/storage/rowset/segment_options.h
#	be/src/storage/rowset/segment_rewriter.cpp
#	be/src/storage/rowset/segment_rewriter.h
#	be/src/storage/rowset/segment_writer.cpp
#	be/src/storage/rowset/struct_column_iterator.cpp
#	be/src/storage/rowset_update_state.cpp
#	be/src/storage/schema_change.cpp
#	be/src/storage/schema_change_utils.cpp
#	be/src/storage/schema_change_utils.h
#	be/src/storage/segment_flush_executor.cpp
#	be/src/storage/segment_flush_executor.h
#	be/src/storage/segment_replicate_executor.cpp
#	be/src/storage/segment_replicate_executor.h
#	be/src/storage/snapshot_manager.cpp
#	be/src/storage/table_reader.cpp
#	be/src/storage/table_reader.h
#	be/src/storage/tablet.cpp
#	be/src/storage/tablet.h
#	be/src/storage/tablet_index.cpp
#	be/src/storage/tablet_manager.h
#	be/src/storage/tablet_meta.h
#	be/src/storage/tablet_reader.cpp
#	be/src/storage/tablet_reader.h
#	be/src/storage/tablet_reader_params.h
#	be/src/storage/tablet_schema.cpp
#	be/src/storage/tablet_schema.h
#	be/src/storage/tablet_updates.cpp
#	be/src/storage/tablet_updates.h
#	be/src/storage/txn_manager.cpp
#	be/src/storage/txn_manager.h
#	be/src/storage/types.cpp
#	be/src/storage/union_iterator.cpp
#	be/src/storage/vertical_compaction_task.cpp
#	be/src/storage/zone_map_detail.h
#	be/src/testutil/column_test_helper.h
#	be/src/testutil/exprs_test_helper.h
#	be/src/testutil/init_test_env.h
#	be/src/testutil/schema_test_helper.cpp
#	be/src/testutil/schema_test_helper.h
#	be/src/types/CMakeLists.txt
#	be/src/types/bitmap_value.cpp
#	be/src/types/bitmap_value.h
#	be/src/types/bitmap_value_detail.h
#	be/src/types/constexpr.h
#	be/src/types/hll.cpp
#	be/src/types/hll.h
#	be/src/types/logical_type_infra.h
#	be/src/types/timestamp_value.cpp
#	be/src/types/timestamp_value.h
#	be/src/udf/CMakeLists.txt
#	be/src/udf/java/java_data_converter.h
#	be/src/udf/java/java_udf.h
#	be/src/util/CMakeLists.txt
#	be/src/util/arrow/row_batch.cpp
#	be/src/util/arrow/row_batch.h
#	be/src/util/arrow/starrocks_column_to_arrow.cpp
#	be/src/util/arrow/starrocks_column_to_arrow.h
#	be/src/util/arrow/utils.h
#	be/src/util/bit_packing.h
#	be/src/util/bit_stream_utils.h
#	be/src/util/bit_stream_utils.inline.h
#	be/src/util/bitmap_intersect.h
#	be/src/util/brpc_stub_cache.h
#	be/src/util/c_string.h
#	be/src/util/cpu_info.h
#	be/src/util/debug/query_trace_impl.h
#	be/src/util/decimal_types.h
#	be/src/util/failpoint/fail_point.cpp
#	be/src/util/filesystem_util.cc
#	be/src/util/hdfs_util.cpp
#	be/src/util/int96.cpp
#	be/src/util/json_converter.h
#	be/src/util/lru_cache.cpp
#	be/src/util/lru_cache.h
#	be/src/util/misc.cpp
#	be/src/util/mysql_row_buffer.cpp
#	be/src/util/phmap/phmap.h
#	be/src/util/raw_container.h
#	be/src/util/rle_encoding.h
#	be/src/util/starrocks_metrics.h
#	be/src/util/system_metrics.cpp
#	be/src/util/system_metrics.h
#	be/src/util/threadpool.h
#	be/src/util/thrift_rpc_helper.cpp
#	be/src/util/thrift_rpc_helper.h
#	be/src/util/thrift_util.h
#	be/src/util/timezone_hsscan.h
#	be/src/util/uid_util.cpp
#	be/src/util/uid_util.h
#	be/test/CMakeLists.txt
#	be/test/agent/agent_task_test.cpp
#	be/test/agent/heartbeat_server_test.cpp
#	be/test/block_cache/block_cache_test.cpp
#	be/test/block_cache/datacache_utils_test.cpp
#	be/test/block_cache/disk_space_monitor_test.cpp
#	be/test/column/avx_numeric_column.h
#	be/test/column/avx_numeric_column_test.cpp
#	be/test/column/binary_column_test.cpp
#	be/test/column/field_test.cpp
#	be/test/column/fixed_length_column_test.cpp
#	be/test/column/object_column_test.cpp
#	be/test/column/timestamp_value_test.cpp
#	be/test/exec/agg_hash_map_test.cpp
#	be/test/exec/chunks_sorter_test.cpp
#	be/test/exec/column_value_range_test.cpp
#	be/test/exec/hdfs_scan_node_test.cpp
#	be/test/exec/hdfs_scanner_test.cpp
#	be/test/exec/join_hash_map_test.cpp
#	be/test/exec/lake_meta_scanner_test.cpp
#	be/test/exec/parquet_scanner_test.cpp
#	be/test/exec/pipeline/mem_limited_chunk_queue_test.cpp
#	be/test/exprs/agg/aggregate_test.cpp
#	be/test/exprs/array_functions_test.cpp
#	be/test/exprs/cast_expr_test.cpp
#	be/test/exprs/like_test.cpp
#	be/test/exprs/string_fn_money_format_decimal_test.cpp
#	be/test/exprs/string_fn_test.cpp
#	be/test/exprs/time_functions_test.cpp
#	be/test/formats/csv/string_converter_test.cpp
#	be/test/formats/csv/varbinary_converter_test.cpp
#	be/test/formats/orc/orc_chunk_reader_test.cpp
#	be/test/formats/parquet/column_converter_test.cpp
#	be/test/formats/parquet/file_reader_test.cpp
#	be/test/formats/parquet/file_writer_test.cpp
#	be/test/formats/parquet/group_reader_test.cpp
#	be/test/formats/parquet/iceberg_schema_evolution_file_reader_test.cpp
#	be/test/formats/parquet/page_index_test.cpp
#	be/test/formats/parquet/parquet_cli_reader.h
#	be/test/formats/parquet/parquet_file_writer_test.cpp
#	be/test/formats/parquet/parquet_ut_base.cpp
#	be/test/formats/parquet/parquet_ut_base.h
#	be/test/fs/fs_posix_test.cpp
#	be/test/fs/fs_s3_test.cpp
#	be/test/fs/fs_test.cpp
#	be/test/http/stream_load_test.cpp
#	be/test/io/cache_input_stream_test.cpp
#	be/test/io/s3_input_stream_test.cpp
#	be/test/io/s3_output_stream_test.cpp
#	be/test/runtime/decimalv3_test.cpp
#	be/test/runtime/lake_tablets_channel_test.cpp
#	be/test/runtime/large_int_value_test.cpp
#	be/test/runtime/load_channel_test.cpp
#	be/test/runtime/local_tablets_channel_test.cpp
#	be/test/runtime/stream_load_pipe_test.cpp
#	be/test/runtime/type_descriptor_test.cpp
#	be/test/serde/column_array_serde_test.cpp
#	be/test/service/lake_service_test.cpp
#	be/test/storage/aggregate_iterator_test.cpp
#	be/test/storage/base_compaction_test.cpp
#	be/test/storage/chunk_helper_test.cpp
#	be/test/storage/column_predicate_test.cpp
#	be/test/storage/conjunctive_predicates_test.cpp
#	be/test/storage/delta_column_group_test.cpp
#	be/test/storage/lake/alter_tablet_meta_test.cpp
#	be/test/storage/lake/async_delta_writer_test.cpp
#	be/test/storage/lake/auto_increment_partial_update_test.cpp
#	be/test/storage/lake/compaction_policy_test.cpp
#	be/test/storage/lake/compaction_task_test.cpp
#	be/test/storage/lake/condition_update_test.cpp
#	be/test/storage/lake/delta_writer_test.cpp
#	be/test/storage/lake/lake_primary_key_consistency_test.cpp
#	be/test/storage/lake/lake_scan_node_test.cpp
#	be/test/storage/lake/meta_file_test.cpp
#	be/test/storage/lake/partial_update_test.cpp
#	be/test/storage/lake/primary_key_compaction_task_test.cpp
#	be/test/storage/lake/primary_key_publish_test.cpp
#	be/test/storage/lake/replication_txn_manager_test.cpp
#	be/test/storage/lake/rowset_test.cpp
#	be/test/storage/lake/schema_change_test.cpp
#	be/test/storage/lake/tablet_manager_test.cpp
#	be/test/storage/lake/tablet_writer_test.cpp
#	be/test/storage/lake/test_util.h
#	be/test/storage/meta_reader_test.cpp
#	be/test/storage/projection_iterator_test.cpp
#	be/test/storage/publish_version_manager_test.cpp
#	be/test/storage/publish_version_task_test.cpp
#	be/test/storage/roaring2range_test.cpp
#	be/test/storage/rows_mapper_test.cpp
#	be/test/storage/rowset/column_reader_writer_test.cpp
#	be/test/storage/rowset/default_value_column_iterator_test.cpp
#	be/test/storage/rowset/frame_of_reference_page_test.cpp
#	be/test/storage/rowset/rle_page_test.cpp
#	be/test/storage/rowset/segment_rewriter_test.cpp
#	be/test/storage/rowset/segment_test.cpp
#	be/test/storage/rowset_update_state_test.cpp
#	be/test/storage/tablet_index_test.cpp
#	be/test/storage/tablet_updates_test.cpp
#	be/test/storage/task/engine_storage_migration_task_test.cpp
#	be/test/storage/union_iterator_test.cpp
#	be/test/types/bitmap_value_test.cpp
#	be/test/util/arrow/starrocks_column_to_arrow_test.cpp
#	be/test/util/bit_stream_utils_test.cpp
#	be/test/util/brpc_stub_cache_test.cpp
#	be/test/util/mysql_row_buffer_test.cpp
#	be/test/util/threadpool_test.cpp
#	bin/common.sh
#	bin/show_be_version.sh
#	bin/start_backend.sh
#	bin/start_fe.sh
#	bin/stop_be.sh
#	build.sh
#	contrib/starrocks-python-client/README.md
#	contrib/starrocks-python-client/setup.py
#	contrib/starrocks-python-client/starrocks/__init__.py
#	contrib/starrocks-python-client/starrocks/dialect.py
#	contrib/starrocks-python-client/test/test_suite.py
#	docker/dockerfiles/dev-env/dev-env.Dockerfile
#	docker/dockerfiles/toolchains/toolchains-centos7.Dockerfile
#	docker/dockerfiles/toolchains/toolchains-ubuntu.Dockerfile
#	docs/docusaurus/i18n/zh/docusaurus-plugin-content-docs/current.json
#	docs/en/administration/management/FE_configuration.md
#	docs/en/administration/management/resource_management/query_queues.md
#	docs/en/administration/management/resource_management/resource_group.md
#	docs/en/data_source/catalog/iceberg_catalog.md
#	docs/en/developers/build-starrocks/build_starrocks_on_ubuntu.md
#	docs/en/ecosystem_release/flink_connector.md
#	docs/en/ecosystem_release/kafka_connector.md
#	docs/en/ecosystem_release/spark_connector.md
#	docs/en/integrations/BI_integrations/Metabase.md
#	docs/en/introduction/Architecture.md
#	docs/en/loading/Kafka-connector-starrocks.md
#	docs/en/quick_start/hudi.md
#	docs/en/release_notes/release-2.5.md
#	docs/en/release_notes/release-3.0.md
#	docs/en/release_notes/release-3.2.md
#	docs/en/sql-reference/System_limit.md
#	docs/en/sql-reference/System_variable.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/any_value.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/approx_count_distinct.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/approx_top_k.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/avg.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/corr.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/count.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/count_if.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/covar_pop.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/covar_samp.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/group_concat.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/grouping.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/grouping_id.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/hll_raw_agg.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/hll_union.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/hll_union_agg.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/max.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/max_by.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/min.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/min_by.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/multi_distinct_count.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/multi_distinct_sum.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/percentile_approx.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/percentile_cont.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/percentile_disc.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/retention.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/std.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/stddev.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/stddev_samp.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/sum.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/var_samp.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/variance.md
#	docs/en/sql-reference/sql-functions/aggregate-functions/window_funnel.md
#	docs/en/sql-reference/sql-functions/array-functions/all_match.md
#	docs/en/sql-reference/sql-functions/array-functions/any_match.md
#	docs/en/sql-reference/sql-functions/array-functions/array_agg.md
#	docs/en/sql-reference/sql-functions/array-functions/array_append.md
#	docs/en/sql-reference/sql-functions/array-functions/array_avg.md
#	docs/en/sql-reference/sql-functions/array-functions/array_concat.md
#	docs/en/sql-reference/sql-functions/array-functions/array_contains.md
#	docs/en/sql-reference/sql-functions/array-functions/array_contains_all.md
#	docs/en/sql-reference/sql-functions/array-functions/array_contains_seq.md
#	docs/en/sql-reference/sql-functions/array-functions/array_cum_sum.md
#	docs/en/sql-reference/sql-functions/array-functions/array_difference.md
#	docs/en/sql-reference/sql-functions/array-functions/array_distinct.md
#	docs/en/sql-reference/sql-functions/array-functions/array_filter.md
#	docs/en/sql-reference/sql-functions/array-functions/array_generate.md
#	docs/en/sql-reference/sql-functions/array-functions/array_intersect.md
#	docs/en/sql-reference/sql-functions/array-functions/array_join.md
#	docs/en/sql-reference/sql-functions/array-functions/array_length.md
#	docs/en/sql-reference/sql-functions/array-functions/array_map.md
#	docs/en/sql-reference/sql-functions/array-functions/array_max.md
#	docs/en/sql-reference/sql-functions/array-functions/array_min.md
#	docs/en/sql-reference/sql-functions/array-functions/array_position.md
#	docs/en/sql-reference/sql-functions/array-functions/array_remove.md
#	docs/en/sql-reference/sql-functions/array-functions/array_slice.md
#	docs/en/sql-reference/sql-functions/array-functions/array_sort.md
#	docs/en/sql-reference/sql-functions/array-functions/array_sortby.md
#	docs/en/sql-reference/sql-functions/array-functions/array_sum.md
#	docs/en/sql-reference/sql-functions/array-functions/array_to_bitmap.md
#	docs/en/sql-reference/sql-functions/array-functions/array_unique_agg.md
#	docs/en/sql-reference/sql-functions/array-functions/arrays_overlap.md
#	docs/en/sql-reference/sql-functions/array-functions/cardinality.md
#	docs/en/sql-reference/sql-functions/array-functions/element_at.md
#	docs/en/sql-reference/sql-functions/array-functions/reverse.md
#	docs/en/sql-reference/sql-functions/array-functions/unnest.md
#	docs/en/sql-reference/sql-functions/binary-functions/from_binary.md
#	docs/en/sql-reference/sql-functions/binary-functions/to_binary.md
#	docs/en/sql-reference/sql-functions/bit-functions/bit_shift_left.md
#	docs/en/sql-reference/sql-functions/bit-functions/bit_shift_right.md
#	docs/en/sql-reference/sql-functions/bit-functions/bit_shift_right_logical.md
#	docs/en/sql-reference/sql-functions/bit-functions/bitand.md
#	docs/en/sql-reference/sql-functions/bit-functions/bitnot.md
#	docs/en/sql-reference/sql-functions/bit-functions/bitor.md
#	docs/en/sql-reference/sql-functions/bit-functions/bitxor.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/base64_to_bitmap.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_agg.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_and.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_andnot.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_contains.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_count.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_empty.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_from_binary.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_from_string.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_has_any.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_hash.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_intersect.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_max.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_min.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_or.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_remove.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_subset_in_range.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_subset_limit.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_to_array.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_to_base64.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_to_binary.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_to_string.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_union.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_union_count.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_union_int.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/bitmap_xor.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/intersect_count.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/sub_bitmap.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/subdivide_bitmap.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/to_bitmap.md
#	docs/en/sql-reference/sql-functions/bitmap-functions/unnest_bitmap.md
#	docs/en/sql-reference/sql-functions/cast.md
#	docs/en/sql-reference/sql-functions/condition-functions/case_when.md
#	docs/en/sql-reference/sql-functions/condition-functions/coalesce.md
#	docs/en/sql-reference/sql-functions/condition-functions/if.md
#	docs/en/sql-reference/sql-functions/condition-functions/ifnull.md
#	docs/en/sql-reference/sql-functions/condition-functions/nullif.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/aes_decrypt.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/aes_encrypt.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/base64_decode_binary.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/base64_decode_string.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/from_base64.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/sm3.md
#	docs/en/sql-reference/sql-functions/crytographic-functions/to_base64.md
#	docs/en/sql-reference/sql-functions/date-time-functions/add_months.md
#	docs/en/sql-reference/sql-functions/date-time-functions/convert_tz.md
#	docs/en/sql-reference/sql-functions/date-time-functions/curdate.md
#	docs/en/sql-reference/sql-functions/date-time-functions/current_timestamp.md
#	docs/en/sql-reference/sql-functions/date-time-functions/curtime.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date_format.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date_slice.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/date_trunc.md
#	docs/en/sql-reference/sql-functions/date-time-functions/datediff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/day.md
#	docs/en/sql-reference/sql-functions/date-time-functions/day_of_week_iso.md
#	docs/en/sql-reference/sql-functions/date-time-functions/dayname.md
#	docs/en/sql-reference/sql-functions/date-time-functions/dayofmonth.md
#	docs/en/sql-reference/sql-functions/date-time-functions/dayofweek.md
#	docs/en/sql-reference/sql-functions/date-time-functions/dayofyear.md
#	docs/en/sql-reference/sql-functions/date-time-functions/days_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/days_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/days_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/from_days.md
#	docs/en/sql-reference/sql-functions/date-time-functions/from_unixtime.md
#	docs/en/sql-reference/sql-functions/date-time-functions/hour.md
#	docs/en/sql-reference/sql-functions/date-time-functions/hours_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/hours_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/hours_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/jodatime_format.md
#	docs/en/sql-reference/sql-functions/date-time-functions/last_day.md
#	docs/en/sql-reference/sql-functions/date-time-functions/makedate.md
#	docs/en/sql-reference/sql-functions/date-time-functions/microseconds_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/microseconds_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/milliseconds_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/minute.md
#	docs/en/sql-reference/sql-functions/date-time-functions/minutes_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/minutes_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/minutes_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/month.md
#	docs/en/sql-reference/sql-functions/date-time-functions/monthname.md
#	docs/en/sql-reference/sql-functions/date-time-functions/months_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/months_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/months_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/next_day.md
#	docs/en/sql-reference/sql-functions/date-time-functions/now.md
#	docs/en/sql-reference/sql-functions/date-time-functions/previous_day.md
#	docs/en/sql-reference/sql-functions/date-time-functions/quarter.md
#	docs/en/sql-reference/sql-functions/date-time-functions/second.md
#	docs/en/sql-reference/sql-functions/date-time-functions/seconds_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/seconds_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/str2date.md
#	docs/en/sql-reference/sql-functions/date-time-functions/str_to_date.md
#	docs/en/sql-reference/sql-functions/date-time-functions/str_to_jodatime.md
#	docs/en/sql-reference/sql-functions/date-time-functions/time_slice.md
#	docs/en/sql-reference/sql-functions/date-time-functions/time_to_sec.md
#	docs/en/sql-reference/sql-functions/date-time-functions/timediff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/timestamp.md
#	docs/en/sql-reference/sql-functions/date-time-functions/timestampadd.md
#	docs/en/sql-reference/sql-functions/date-time-functions/timestampdiff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/to_date.md
#	docs/en/sql-reference/sql-functions/date-time-functions/to_days.md
#	docs/en/sql-reference/sql-functions/date-time-functions/to_iso8601.md
#	docs/en/sql-reference/sql-functions/date-time-functions/to_tera_date.md
#	docs/en/sql-reference/sql-functions/date-time-functions/to_tera_timestamp.md
#	docs/en/sql-reference/sql-functions/date-time-functions/unix_timestamp.md
#	docs/en/sql-reference/sql-functions/date-time-functions/utc_time.md
#	docs/en/sql-reference/sql-functions/date-time-functions/utc_timestamp.md
#	docs/en/sql-reference/sql-functions/date-time-functions/week.md
#	docs/en/sql-reference/sql-functions/date-time-functions/week_iso.md
#	docs/en/sql-reference/sql-functions/date-time-functions/weekofyear.md
#	docs/en/sql-reference/sql-functions/date-time-functions/weeks_add.md
#	docs/en/sql-reference/sql-functions/date-time-functions/weeks_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/weeks_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/year.md
#	docs/en/sql-reference/sql-functions/date-time-functions/years_diff.md
#	docs/en/sql-reference/sql-functions/date-time-functions/years_sub.md
#	docs/en/sql-reference/sql-functions/date-time-functions/yearweek.md
#	docs/en/sql-reference/sql-functions/dict-functions/dict_mapping.md
#	docs/en/sql-reference/sql-functions/hash-functions/murmur_hash3_32.md
#	docs/en/sql-reference/sql-functions/hash-functions/xx_hash3_128.md
#	docs/en/sql-reference/sql-functions/hash-functions/xx_hash3_64.md
#	docs/en/sql-reference/sql-functions/json-functions/json-constructor-functions/json_array.md
#	docs/en/sql-reference/sql-functions/json-functions/json-constructor-functions/json_object.md
#	docs/en/sql-reference/sql-functions/json-functions/json-constructor-functions/parse_json.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/arrow-function.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/cast.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/get_json_bool.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/get_json_double.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/get_json_int.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/get_json_string.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/json_each.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/json_exists.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/json_keys.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/json_length.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/json_query.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/json_string.md
#	docs/en/sql-reference/sql-functions/json-functions/json-query-and-processing-functions/to_json.md
#	docs/en/sql-reference/sql-functions/like-predicate-functions/like.md
#	docs/en/sql-reference/sql-functions/like-predicate-functions/regexp.md
#	docs/en/sql-reference/sql-functions/like-predicate-functions/regexp_extract.md
#	docs/en/sql-reference/sql-functions/like-predicate-functions/regexp_extract_all.md
#	docs/en/sql-reference/sql-functions/like-predicate-functions/regexp_replace.md
#	docs/en/sql-reference/sql-functions/map-functions/cardinality.md
#	docs/en/sql-reference/sql-functions/map-functions/distinct_map_keys.md
#	docs/en/sql-reference/sql-functions/map-functions/element_at.md
#	docs/en/sql-reference/sql-functions/map-functions/map_apply.md
#	docs/en/sql-reference/sql-functions/map-functions/map_concat.md
#	docs/en/sql-reference/sql-functions/map-functions/map_filter.md
#	docs/en/sql-reference/sql-functions/map-functions/map_from_arrays.md
#	docs/en/sql-reference/sql-functions/map-functions/map_keys.md
#	docs/en/sql-reference/sql-functions/map-functions/map_size.md
#	docs/en/sql-reference/sql-functions/map-functions/map_values.md
#	docs/en/sql-reference/sql-functions/map-functions/transform_keys.md
#	docs/en/sql-reference/sql-functions/map-functions/transform_values.md
#	docs/en/sql-reference/sql-functions/math-functions/abs.md
#	docs/en/sql-reference/sql-functions/math-functions/acos.md
#	docs/en/sql-reference/sql-functions/math-functions/asin.md
#	docs/en/sql-reference/sql-functions/math-functions/atan.md
#	docs/en/sql-reference/sql-functions/math-functions/atan2.md
#	docs/en/sql-reference/sql-functions/math-functions/bin.md
#	docs/en/sql-reference/sql-functions/math-functions/cbrt.md
#	docs/en/sql-reference/sql-functions/math-functions/ceil.md
#	docs/en/sql-reference/sql-functions/math-functions/ceiling.md
#	docs/en/sql-reference/sql-functions/math-functions/conv.md
#	docs/en/sql-reference/sql-functions/math-functions/cos.md
#	docs/en/sql-reference/sql-functions/math-functions/cos_similarity.md
#	docs/en/sql-reference/sql-functions/math-functions/cos_similarity_norm.md
#	docs/en/sql-reference/sql-functions/math-functions/cosh.md
#	docs/en/sql-reference/sql-functions/math-functions/cot.md
#	docs/en/sql-reference/sql-functions/math-functions/degrees.md
#	docs/en/sql-reference/sql-functions/math-functions/divide.md
#	docs/en/sql-reference/sql-functions/math-functions/e.md
#	docs/en/sql-reference/sql-functions/math-functions/exp.md
#	docs/en/sql-reference/sql-functions/math-functions/floor.md
#	docs/en/sql-reference/sql-functions/math-functions/fmod.md
#	docs/en/sql-reference/sql-functions/math-functions/greatest.md
#	docs/en/sql-reference/sql-functions/math-functions/least.md
#	docs/en/sql-reference/sql-functions/math-functions/ln.md
#	docs/en/sql-reference/sql-functions/math-functions/log.md
#	docs/en/sql-reference/sql-functions/math-functions/log10.md
#	docs/en/sql-reference/sql-functions/math-functions/log2.md
#	docs/en/sql-reference/sql-functions/math-functions/mod.md
#	docs/en/sql-reference/sql-functions/math-functions/multiply.md
#	docs/en/sql-reference/sql-functions/math-functions/negative.md
#	docs/en/sql-reference/sql-functions/math-functions/pi.md
#	docs/en/sql-reference/sql-functions/math-functions/pmod.md
#	docs/en/sql-reference/sql-functions/math-functions/positive.md
#	docs/en/sql-reference/sql-functions/math-functions/pow.md
#	docs/en/sql-reference/sql-functions/math-functions/radians.md
#	docs/en/sql-reference/sql-functions/math-functions/rand.md
#	docs/en/sql-reference/sql-functions/math-functions/round.md
#	docs/en/sql-reference/sql-functions/math-functions/sign.md
#	docs/en/sql-reference/sql-functions/math-functions/sin.md
#	docs/en/sql-reference/sql-functions/math-functions/sinh.md
#	docs/en/sql-reference/sql-functions/math-functions/sqrt.md
#	docs/en/sql-reference/sql-functions/math-functions/square.md
#	docs/en/sql-reference/sql-functions/math-functions/tan.md
#	docs/en/sql-reference/sql-functions/math-functions/tanh.md
#	docs/en/sql-reference/sql-functions/math-functions/truncate.md
#	docs/en/sql-reference/sql-functions/percentile-functions/percentile_approx_raw.md
#	docs/en/sql-reference/sql-functions/percentile-functions/percentile_empty.md
#	docs/en/sql-reference/sql-functions/percentile-functions/percentile_hash.md
#	docs/en/sql-reference/sql-functions/percentile-functions/percentile_union.md
#	docs/en/sql-reference/sql-functions/scalar-functions/hll_cardinality.md
#	docs/en/sql-reference/sql-functions/scalar-functions/hll_empty.md
#	docs/en/sql-reference/sql-functions/scalar-functions/hll_hash.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_astext.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_circle.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_contains.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_distance_sphere.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_geometryfromtext.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_linefromtext.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_point.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_polygon.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_x.md
#	docs/en/sql-reference/sql-functions/spatial-functions/st_y.md
#	docs/en/sql-reference/sql-functions/string-functions/append_trailing_char_if_absent.md
#	docs/en/sql-reference/sql-functions/string-functions/ascii.md
#	docs/en/sql-reference/sql-functions/string-functions/char.md
#	docs/en/sql-reference/sql-functions/string-functions/char_length.md
#	docs/en/sql-reference/sql-functions/string-functions/character_length.md
#	docs/en/sql-reference/sql-functions/string-functions/concat.md
#	docs/en/sql-reference/sql-functions/string-functions/concat_ws.md
#	docs/en/sql-reference/sql-functions/string-functions/crc32.md
#	docs/en/sql-reference/sql-functions/string-functions/ends_with.md
#	docs/en/sql-reference/sql-functions/string-functions/find_in_set.md
#	docs/en/sql-reference/sql-functions/string-functions/group_concat.md
#	docs/en/sql-reference/sql-functions/string-functions/hex.md
#	docs/en/sql-reference/sql-functions/string-functions/hex_decode_binary.md
#	docs/en/sql-reference/sql-functions/string-functions/hex_decode_string.md
#	docs/en/sql-reference/sql-functions/string-functions/instr.md
#	docs/en/sql-reference/sql-functions/string-functions/lcase.md
#	docs/en/sql-reference/sql-functions/string-functions/left.md
#	docs/en/sql-reference/sql-functions/string-functions/length.md
#	docs/en/sql-reference/sql-functions/string-functions/locate.md
#	docs/en/sql-reference/sql-functions/string-functions/lower.md
#	docs/en/sql-reference/sql-functions/string-functions/lpad.md
#	docs/en/sql-reference/sql-functions/string-functions/ltrim.md
#	docs/en/sql-reference/sql-functions/string-functions/money_format.md
#	docs/en/sql-reference/sql-functions/string-functions/ngram_search.md
#	docs/en/sql-reference/sql-functions/string-functions/null_or_empty.md
#	docs/en/sql-reference/sql-functions/string-functions/parse_url.md
#	docs/en/sql-reference/sql-functions/string-functions/repeat.md
#	docs/en/sql-reference/sql-functions/string-functions/replace.md
#	docs/en/sql-reference/sql-functions/string-functions/reverse.md
#	docs/en/sql-reference/sql-functions/string-functions/right.md
#	docs/en/sql-reference/sql-functions/string-functions/rpad.md
#	docs/en/sql-reference/sql-functions/string-functions/rtrim.md
#	docs/en/sql-reference/sql-functions/string-functions/space.md
#	docs/en/sql-reference/sql-functions/string-functions/split.md
#	docs/en/sql-reference/sql-functions/string-functions/split_part.md
#	docs/en/sql-reference/sql-functions/string-functions/starts_with.md
#	docs/en/sql-reference/sql-functions/string-functions/str_to_map.md
#	docs/en/sql-reference/sql-functions/string-functions/strcmp.md
#	docs/en/sql-reference/sql-functions/string-functions/strleft.md
#	docs/en/sql-reference/sql-functions/string-functions/strright.md
#	docs/en/sql-reference/sql-functions/string-functions/substring.md
#	docs/en/sql-reference/sql-functions/string-functions/substring_index.md
#	docs/en/sql-reference/sql-functions/string-functions/translate.md
#	docs/en/sql-reference/sql-functions/string-functions/trim.md
#	docs/en/sql-reference/sql-functions/string-functions/ucase.md
#	docs/en/sql-reference/sql-functions/string-functions/unhex.md
#	docs/en/sql-reference/sql-functions/string-functions/upper.md
#	docs/en/sql-reference/sql-functions/string-functions/url_decode.md
#	docs/en/sql-reference/sql-functions/string-functions/url_encode.md
#	docs/en/sql-reference/sql-functions/string-functions/url_extract_host.md
#	docs/en/sql-reference/sql-functions/string-functions/url_extract_parameter.md
#	docs/en/sql-reference/sql-functions/struct-functions/named_struct.md
#	docs/en/sql-reference/sql-functions/struct-functions/row.md
#	docs/en/sql-reference/sql-functions/table-functions/files.md
#	docs/en/sql-reference/sql-functions/table-functions/generate_series.md
#	docs/en/sql-reference/sql-functions/utility-functions/catalog.md
#	docs/en/sql-reference/sql-functions/utility-functions/current_role.md
#	docs/en/sql-reference/sql-functions/utility-functions/current_version.md
#	docs/en/sql-reference/sql-functions/utility-functions/database.md
#	docs/en/sql-reference/sql-functions/utility-functions/get_query_profile.md
#	docs/en/sql-reference/sql-functions/utility-functions/host_name.md
#	docs/en/sql-reference/sql-functions/utility-functions/is_role_in_session.md
#	docs/en/sql-reference/sql-functions/utility-functions/isnotnull.md
#	docs/en/sql-reference/sql-functions/utility-functions/isnull.md
#	docs/en/sql-reference/sql-functions/utility-functions/last_query_id.md
#	docs/en/sql-reference/sql-functions/utility-functions/sleep.md
#	docs/en/sql-reference/sql-functions/utility-functions/uuid.md
#	docs/en/sql-reference/sql-functions/utility-functions/uuid_numeric.md
#	docs/en/sql-reference/sql-functions/utility-functions/version.md
#	docs/en/sql-reference/sql-statements/Database/SHOW_DATA.md
#	docs/en/sql-reference/sql-statements/Function/CREATE_FUNCTION.md
#	docs/en/sql-reference/sql-statements/table_bucket_part_index/ALTER_TABLE.md
#	docs/en/sql-reference/template_for_config.md
#	docs/en/table_design/data_distribution/expression_partitioning.md
#	docs/en/table_design/indexes/Bitmap_index.md
#	docs/zh/administration/management/FE_configuration.md
#	docs/zh/administration/management/resource_management/query_queues.md
#	docs/zh/data_source/catalog/iceberg_catalog.md
#	docs/zh/deployment/environment_configurations.md
#	docs/zh/developers/build-starrocks/build_starrocks_on_ubuntu.md
#	docs/zh/ecosystem_release/flink_connector.md
#	docs/zh/ecosystem_release/kafka_connector.md
#	docs/zh/ecosystem_release/spark_connector.md
#	docs/zh/introduction/what_is_starrocks.md
#	docs/zh/loading/Kafka-connector-starrocks.md
#	docs/zh/quick_start/helm.md
#	docs/zh/release_notes/release-2.5.md
#	docs/zh/release_notes/release-3.0.md
#	docs/zh/release_notes/release-3.2.md
#	docs/zh/sql-reference/System_variable.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/any_value.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/approx_count_distinct.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/approx_top_k.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/avg.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/corr.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/count.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/count_if.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/covar_pop.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/covar_samp.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/group_concat.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/grouping.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/grouping_id.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/hll_raw_agg.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/hll_union.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/hll_union_agg.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/max.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/max_by.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/min.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/min_by.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/multi_distinct_count.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/multi_distinct_sum.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/percentile_approx.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/percentile_cont.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/percentile_disc.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/retention.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/std.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/stddev.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/stddev_samp.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/sum.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/var_samp.md
#	docs/zh/sql-reference/sql-functions/aggregate-functions/variance.md
#	docs/zh/sql-reference/sql-functions/aggregate-function…
  • Loading branch information
EsoragotoSpirit authored and mergify[bot] committed Dec 13, 2024
1 parent 225a9bf commit 039e00c
Show file tree
Hide file tree
Showing 3,907 changed files with 217,918 additions and 32 deletions.
The diff you're trying to view is too large. We only load the first 3000 changed files.
136 changes: 136 additions & 0 deletions .github/CODEOWNERS
Validating CODEOWNERS rules …
Original file line number Diff line number Diff line change
@@ -1,3 +1,139 @@
# committer will be the owner of all codes
* @StarRocks/starrocks-committer

<<<<<<< HEAD
=======
# cpp miscellaneous
/be/src/common/ @StarRocks/cpp-misc-maintainer
/be/src/gen_cpp/ @StarRocks/cpp-misc-maintainer
/be/src/gutil/ @StarRocks/cpp-misc-maintainer
/be/src/simd/ @StarRocks/cpp-misc-maintainer
/be/src/testutil/ @StarRocks/cpp-misc-maintainer
/be/src/util/ @StarRocks/cpp-misc-maintainer

# execution engine
/be/src/column/ @StarRocks/execution-maintainer
/be/src/exec/ @StarRocks/execution-maintainer
/be/src/exprs/ @StarRocks/execution-maintainer
/be/src/runtime/ @StarRocks/execution-maintainer
/be/src/types/ @StarRocks/execution-maintainer
/be/src/udf/ @StarRocks/execution-maintainer

# open formats
/be/src/formats/ @StarRocks/open-format-maintainer

# storage engine
/be/src/fs/ @StarRocks/storage-maintainer
/be/src/io/ @StarRocks/storage-maintainer
/be/src/storage/ @StarRocks/storage-maintainer

# /docs/ belong to docs-maintainer
/docs/ @StarRocks/docs-maintainer

# /docker
/docker/ @StarRocks/docker-maintainer

# metadata
/fe/fe-core/src/main/java/com/starrocks/authentication/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/privilege/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/common/util/concurrent/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/mysql/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/transaction/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/healthchecker/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/clone/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/consistency/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/ha/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/journal/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/leader/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/meta/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/persist/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/alter/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/backup/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/catalog/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/metric/ @StarRocks/metadata-maintainer
/fe/fe-core/src/main/java/com/starrocks/system/ @StarRocks/metadata-maintainer

# connector
/fe/fe-core/src/main/java/com/starrocks/connector/ @StarRocks/connector-maintainer
/fe/fe-core/src/main/java/com/starrocks/credential/ @StarRocks/connector-maintainer

# parser
/fe/fe-core/src/main/java/com/starrocks/sql/ast/ @StarRocks/parser
/fe/fe-core/src/main/java/com/starrocks/sql/parser/ @StarRocks/parser

# analyzer
/fe/fe-core/src/main/java/com/starrocks/sql/analyzer/ @StarRocks/analyzer
/fe/fe-core/src/main/java/com/starrocks/analysis/ @StarRocks/analyzer

# optimizer
/fe/fe-core/src/main/java/com/starrocks/sql/optimizer/ @StarRocks/optimizer
/fe/fe-core/src/main/java/com/starrocks/statistic/ @StarRocks/optimizer

# scheduler
/fe/fe-core/src/main/java/com/starrocks/qe/scheduler/ @StarRocks/scheduler-maintainer

# sql/parser/StarRocksLex.g4 sql/parser/StarRocks.g4 belong to syntax-committer
/fe/fe-core/src/main/java/com/starrocks/sql/parser/StarRocksLex.g4 @StarRocks/syntax-committer
/fe/fe-core/src/main/java/com/starrocks/sql/parser/StarRocks.g4 @StarRocks/syntax-committer
/gensrc/script/functions.py @StarRocks/syntax-committer

# /thirdparty/ /docker/dockerfiles/dev-env/dev-env.Dockerfile belong to thirdparty-maintainer
/be/src/thirdparty/ @StarRocks/thirdparty-maintainer
/thirdparty/ @StarRocks/thirdparty-maintainer
/docker/dockerfiles/dev-env/dev-env.Dockerfile @StarRocks/thirdparty-maintainer

# cloud native
/be/src/storage/lake/ @StarRocks/cloud-native-maintainer
/be/src/runtime/lake_tablets_channel.h @StarRocks/cloud-native-maintainer
/be/src/runtime/lake_tablets_channel.cpp @StarRocks/cloud-native-maintainer

# error message
/fe/fe-core/src/main/java/com/starrocks/common/ErrorCode.java @StarRocks/msg-reviewer

# StorageEngine/ExecEnv/GlobalEnv
/be/src/runtime/exec_env.h @StarRocks/thread-committer
/be/src/runtime/exec_env.cpp @StarRocks/thread-committer
/be/src/storage/olap_server.cpp @StarRocks/thread-committer
/be/src/storage/storage_engine.h @StarRocks/thread-committer
/be/src/storage/storage_engine.cpp @StarRocks/thread-committer
/be/src/service/starrocks_main.cpp @StarRocks/thread-committer
/be/src/service/service_be/starrocks_be.cpp @StarRocks/thread-committer

# restful
/fe/fe-core/src/main/java/com/starrocks/http @StarRocks/restful-maintainer
/be/src/http @StarRocks/restful-maintainer


# load and unload
/fe/fe-core/src/main/java/com/starrocks/load/* @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/plan/StreamLoad* @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/plan/*Sink.java @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/sql/InsertPlanner.java @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/sql/LoadPlanner.java @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/backup/* @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/alter/Optimize* @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/alter/Compaction* @StarRocks/load-unload-maintainer
/fe/fe-core/src/main/java/com/starrocks/catalog/*Partition* @StarRocks/load-unload-maintainer

/be/src/storage/* @StarRocks/load-unload-maintainer
/be/src/exec/tablet_sink* @StarRocks/load-unload-maintainer
/be/src/exec/csv_scanner.cpp @StarRocks/load-unload-maintainer
/be/src/exec/json_scanner.cpp @StarRocks/load-unload-maintainer
/be/src/exec/pipeline/olap_table_sink_operator.cpp @StarRocks/load-unload-maintainer
/be/src/formats/avro/* @StarRocks/load-unload-maintainer
/be/src/formats/csv/* @StarRocks/load-unload-maintainer
/be/src/formats/json/* @StarRocks/load-unload-maintainer
/be/src/http/action/compaction_action.cpp @StarRocks/load-unload-maintainer
/be/src/http/action/*stream_load.cpp @StarRocks/load-unload-maintainer
/be/src/http/action/restore* @StarRocks/load-unload-maintainer
/be/src/runtime/routine_load/* @StarRocks/load-unload-maintainer
/be/src/runtime/stream_load/* @StarRocks/load-unload-maintainer
/be/src/runtime/load* @StarRocks/load-unload-maintainer
/be/src/runtime/tablets_channel.cpp @StarRocks/load-unload-maintainer
/be/src/runtime/export_sink.cpp @StarRocks/load-unload-maintainer

# meta upgrade/downgrade compatibility
/fe/fe-core/src/main/java/com/starrocks/persist/gson/GsonUtils.java @StarRocks/meta-compatibility-maintainer


>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
8 changes: 8 additions & 0 deletions .github/PULL_REQUEST_TEMPLATE.md
Original file line number Diff line number Diff line change
Expand Up @@ -36,8 +36,16 @@ If yes, please specify the type of change:

## Bugfix cherry-pick branch check:
- [ ] I have checked the version labels which the pr will be auto-backported to the target branch
<<<<<<< HEAD
- [ ] 3.3
- [ ] 3.2
- [ ] 3.1
- [ ] 3.0
- [ ] 2.5
=======
- [ ] 3.4
- [ ] 3.3
- [ ] 3.2
- [ ] 3.1
- [ ] 3.0
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
29 changes: 29 additions & 0 deletions .github/workflows/ci-comment-tools.yml
Original file line number Diff line number Diff line change
Expand Up @@ -22,3 +22,32 @@ jobs:
- name: CLOSE
run: |
gh pr close ${PR_NUMBER} -R ${{ github.repository }} -c "PR was manually closed."
<<<<<<< HEAD
=======

automerge:
name: AutoMerge PR
runs-on: ubuntu-latest
if: >
contains(github.event.issue.pull_request.html_url, 'pull') &&
contains(github.event.comment.body, '@Mergify automerge')
env:
PR_NUMBER: ${{ github.event.issue.number }}

steps:
- name: BASE REF
id: get_base_ref
env:
GITHUB_TOKEN: ${{ secrets.GITHUB_TOKEN }}
run: |
base_ref=$(gh pr view ${PR_NUMBER} -R ${{ github.repository }} --json baseRefName | jq -r '.baseRefName')
echo "base_ref=${base_ref}" >> $GITHUB_OUTPUT
- name: AutoMerge
if: startsWith(steps.get_base_ref.outputs.base_ref, 'mergify/bp')
env:
GITHUB_TOKEN: ${{ secrets.PAT }}
run: |
gh pr merge ${PR_NUMBER} -R ${{ github.repository }} -s --auto
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
8 changes: 8 additions & 0 deletions .github/workflows/ci-merged-sonarcloud-fe.yml
Original file line number Diff line number Diff line change
Expand Up @@ -35,14 +35,22 @@ jobs:
distribution: 'adopt'

- name: Cache SonarCloud packages
<<<<<<< HEAD
uses: actions/cache@v3
=======
uses: actions/cache@v4
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
path: ~/.sonar/cache
key: ${{ runner.os }}-sonar
restore-keys: ${{ runner.os }}-sonar

- name: Cache Maven packages
<<<<<<< HEAD
uses: actions/cache@v3
=======
uses: actions/cache@v4
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
path: ~/.m2
key: ${{ runner.os }}-maven-${{ hashFiles('**/pom.xml') }}
Expand Down
42 changes: 42 additions & 0 deletions .github/workflows/ci-merged.yml
Original file line number Diff line number Diff line change
Expand Up @@ -23,6 +23,7 @@ jobs:
github.repository == 'StarRocks/starrocks' &&
!contains(github.event.pull_request.title, 'cherry-pick') &&
!contains(github.event.pull_request.title, 'backport') && (
<<<<<<< HEAD
contains(github.event.pull_request.labels.*.name, '3.3') ||
contains(github.event.pull_request.labels.*.name, '3.2') ||
contains(github.event.pull_request.labels.*.name, '3.1') ||
Expand All @@ -34,6 +35,32 @@ jobs:
- name: backport branch-3.3
if: contains(github.event.pull_request.labels.*.name, '3.3')
uses: thollander/actions-comment-pull-request@v1
=======
contains(github.event.pull_request.labels.*.name, '3.4') ||
contains(github.event.pull_request.labels.*.name, '3.3') ||
contains(github.event.pull_request.labels.*.name, '3.2') ||
contains(github.event.pull_request.labels.*.name, '3.1') ||
contains(github.event.pull_request.labels.*.name, '3.0') )
env:
PR_NUMBER: ${{ github.event.number }}
steps:
- name: backport branch-3.4
if: contains(github.event.pull_request.labels.*.name, '3.4')
uses: thollander/actions-comment-pull-request@v2
with:
message: |
@Mergifyio backport branch-3.4
GITHUB_TOKEN: ${{ secrets.GITHUB_TOKEN }}

- uses: actions-ecosystem/action-remove-labels@v1
if: contains(github.event.pull_request.labels.*.name, '3.4')
with:
labels: '3.4'

- name: backport branch-3.3
if: contains(github.event.pull_request.labels.*.name, '3.3')
uses: thollander/actions-comment-pull-request@v2
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
message: |
@Mergifyio backport branch-3.3
Expand All @@ -46,7 +73,11 @@ jobs:

- name: backport branch-3.2
if: contains(github.event.pull_request.labels.*.name, '3.2')
<<<<<<< HEAD
uses: thollander/actions-comment-pull-request@v1
=======
uses: thollander/actions-comment-pull-request@v2
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
message: |
@Mergifyio backport branch-3.2
Expand All @@ -59,7 +90,11 @@ jobs:

- name: backport branch-3.1
if: contains(github.event.pull_request.labels.*.name, '3.1')
<<<<<<< HEAD
uses: thollander/actions-comment-pull-request@v1
=======
uses: thollander/actions-comment-pull-request@v2
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
message: |
@Mergifyio backport branch-3.1
Expand All @@ -72,7 +107,11 @@ jobs:

- name: backport branch-3.0
if: contains(github.event.pull_request.labels.*.name, '3.0')
<<<<<<< HEAD
uses: thollander/actions-comment-pull-request@v1
=======
uses: thollander/actions-comment-pull-request@v2
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
message: |
@Mergifyio backport branch-3.0
Expand All @@ -83,6 +122,7 @@ jobs:
with:
labels: '3.0'

<<<<<<< HEAD
- name: backport branch-2.5
if: contains(github.event.pull_request.labels.*.name, '2.5')
uses: thollander/actions-comment-pull-request@v1
Expand All @@ -96,6 +136,8 @@ jobs:
with:
labels: '2.5'

=======
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
thirdparty-update-image:
runs-on: [self-hosted, normal]
name: Thirdparty Update Image
Expand Down
12 changes: 12 additions & 0 deletions .github/workflows/ci-pipeline-branch.yml
Original file line number Diff line number Diff line change
Expand Up @@ -382,14 +382,22 @@ jobs:
distribution: 'adopt'

- name: Cache SonarCloud packages
<<<<<<< HEAD
uses: actions/cache@v3
=======
uses: actions/cache@v4
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
path: ~/.sonar/cache
key: ${{ runner.os }}-sonar
restore-keys: ${{ runner.os }}-sonar

- name: Cache Maven packages
<<<<<<< HEAD
uses: actions/cache@v3
=======
uses: actions/cache@v4
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
with:
path: ~/.m2
key: ${{ runner.os }}-maven-${{ hashFiles('**/pom.xml') }}
Expand Down Expand Up @@ -507,4 +515,8 @@ jobs:

- name: Clean
run: |
<<<<<<< HEAD
rm -rf ${{ github.workspace }}/*
=======
rm -rf ${{ github.workspace }}/*
>>>>>>> b42eff7ae3 ([Doc] Add meaning of 0 for variables (#53714))
Loading

0 comments on commit 039e00c

Please sign in to comment.