You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by ya...@apache.org on 2020/10/20 01:35:28 UTC

[incubator-doris] branch master updated (34d5ab8 -> 09f97f8)

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

yangzhg pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-doris.git.


    from 34d5ab8  [BUG] Ensure that the correct lead/lag function is selected (#4732)
     add 09f97f8  [Refactor] Fixes some be typo part 2 (#4747)

No new revisions were added by this update.

Summary of changes:
 be/src/common/daemon.cpp                           |   4 +-
 be/src/env/env.h                                   |   2 +-
 be/src/exec/broker_writer.cpp                      |   2 +-
 be/src/exec/decompressor.cpp                       |   2 +-
 be/src/exec/es/es_predicate.cpp                    |  12 +--
 be/src/exec/es/es_query_builder.cpp                |   6 +-
 be/src/exec/es/es_query_builder.h                  |   4 +-
 be/src/exec/es/es_scan_reader.h                    |   6 +-
 be/src/exec/es/es_scroll_parser.cpp                |  14 +--
 be/src/exec/es/es_scroll_query.cpp                 |   4 +-
 be/src/exec/es/es_scroll_query.h                   |   2 +-
 be/src/exec/es_http_scan_node.cpp                  |   4 +-
 be/src/exec/es_http_scan_node.h                    |   2 +-
 be/src/exec/es_scan_node.cpp                       |   2 +-
 be/src/exec/except_node.cpp                        |   2 +-
 be/src/exec/except_node.h                          |   2 +-
 be/src/exec/hash_join_node_ir.cpp                  |   2 +-
 be/src/exec/hash_table.h                           |   4 +-
 be/src/exec/intersect_node.h                       |   4 +-
 be/src/exec/json_scanner.cpp                       |  10 +-
 be/src/exec/json_scanner.h                         |   2 +-
 be/src/exec/merge_join_node.cpp                    |   2 +-
 be/src/exec/merge_join_node.h                      |   2 +-
 be/src/exec/odbc_scanner.cpp                       |   6 +-
 be/src/exec/olap_common.h                          |   4 +-
 be/src/exec/olap_rewrite_node.cpp                  |   4 +-
 be/src/exec/olap_scan_node.cpp                     |  18 ++--
 be/src/exec/olap_scan_node.h                       |   4 +-
 be/src/exec/olap_scanner.cpp                       |   4 +-
 be/src/exec/olap_scanner.h                         |   2 +-
 be/src/exec/olap_utils.h                           |   2 +-
 be/src/exec/partitioned_aggregation_node.h         |   2 +-
 be/src/exec/partitioned_hash_table.h               |  10 +-
 be/src/exec/plain_text_line_reader.cpp             |   8 +-
 be/src/exec/repeat_node.h                          |   2 +-
 .../exec/schema_scanner/schema_columns_scanner.cpp |  10 +-
 be/src/exec/schema_scanner/schema_helper.cpp       |   2 +-
 be/src/exec/schema_scanner/schema_helper.h         |   2 +-
 .../schema_scanner/schema_variables_scanner.cpp    |   2 +-
 be/src/exec/tablet_info.cpp                        |   2 +-
 be/src/exec/tablet_sink.cpp                        |   8 +-
 be/src/exec/tablet_sink.h                          |  10 +-
 be/src/exprs/case_expr.cpp                         |  24 ++---
 be/src/exprs/decimalv2_operators.cpp               |   2 +-
 be/src/exprs/json_functions.h                      |   2 +-
 be/src/exprs/like_predicate.h                      |   2 +-
 be/src/geo/geo_types.cpp                           |   4 +-
 be/src/geo/wkt_parse.h                             |   2 +-
 be/src/geo/wkt_yacc.y                              |   4 +-
 be/src/gutil/casts.h                               |   6 +-
 be/src/gutil/hash/jenkins_lookup2.h                |   2 +-
 be/src/gutil/hash/legacy_hash.h                    |   2 +-
 be/src/gutil/move.h                                |   2 +-
 be/src/gutil/spinlock_internal.h                   |   2 +-
 be/src/gutil/strings/join.cc                       |   8 +-
 be/src/gutil/strings/join.h                        |   2 +-
 be/src/gutil/strings/split.cc                      |   4 +-
 be/src/gutil/template_util.h                       |   2 +-
 be/src/http/action/mini_load.cpp                   |  20 ++--
 be/src/http/action/stream_load.cpp                 |   4 +-
 be/src/http/download_action.cpp                    |   2 +-
 be/src/http/http_channel.cpp                       |   8 +-
 be/src/http/http_client.cpp                        |   2 +-
 be/src/http/http_client.h                          |   2 +-
 be/src/http/http_handler.h                         |   2 +-
 be/src/http/http_parser.h                          |   2 +-
 be/src/http/http_status.cpp                        |   2 +-
 be/src/http/http_status.h                          |   2 +-
 be/src/olap/base_compaction.cpp                    |   2 +-
 be/src/olap/byte_buffer.h                          |   6 +-
 be/src/olap/cumulative_compaction.cpp              |   6 +-
 be/src/olap/cumulative_compaction_policy.cpp       |   4 +-
 be/src/olap/cumulative_compaction_policy.h         |  38 +++----
 be/src/olap/data_dir.cpp                           |   4 +-
 be/src/olap/delete_handler.cpp                     |  10 +-
 be/src/olap/delta_writer.cpp                       |   2 +-
 be/src/olap/field.h                                |  20 ++--
 be/src/olap/file_helper.h                          |   4 +-
 be/src/olap/fs/block_manager.cpp                   |   2 +-
 be/src/olap/generic_iterators.cpp                  |   2 +-
 be/src/olap/hll.cpp                                |  56 +++++------
 be/src/olap/hll.h                                  |  18 ++--
 be/src/olap/olap_common.h                          |   2 +-
 be/src/olap/olap_cond.cpp                          |  22 ++--
 be/src/olap/olap_define.h                          |   4 +-
 be/src/olap/olap_index.cpp                         |   4 +-
 be/src/olap/olap_meta.cpp                          |   2 +-
 be/src/olap/olap_server.cpp                        |   4 +-
 be/src/olap/olap_snapshot_converter.cpp            |   2 +-
 be/src/olap/out_stream.cpp                         |   2 +-
 be/src/olap/page_cache.h                           |   4 +-
 be/src/olap/push_handler.cpp                       |   4 +-
 be/src/olap/reader.cpp                             |   4 +-
 be/src/olap/reader.h                               |   2 +-
 be/src/olap/row.h                                  |   4 +-
 be/src/olap/row_block.cpp                          |   2 +-
 be/src/olap/rowset/rowset_meta.h                   |   2 +-
 be/src/olap/rowset/run_length_integer_reader.cpp   |   4 +-
 be/src/olap/rowset/run_length_integer_writer.cpp   |   6 +-
 be/src/olap/rowset/segment_reader.cpp              |   6 +-
 .../rowset/segment_v2/indexed_column_reader.cpp    |   4 +-
 .../olap/rowset/segment_v2/indexed_column_reader.h |   2 +-
 .../rowset/segment_v2/indexed_column_writer.cpp    |   6 +-
 .../olap/rowset/segment_v2/indexed_column_writer.h |   2 +-
 be/src/olap/rowset/segment_v2/page_builder.h       |   2 +-
 be/src/olap/rowset/segment_v2/plain_page.h         |   4 +-
 be/src/olap/schema.h                               |   2 +-
 be/src/olap/schema_change.cpp                      |   6 +-
 be/src/olap/schema_change.h                        |   2 +-
 be/src/olap/skiplist.h                             |   2 +-
 be/src/olap/snapshot_manager.cpp                   |  10 +-
 be/src/olap/storage_engine.cpp                     |   2 +-
 be/src/olap/tablet.cpp                             |  34 +++----
 be/src/olap/tablet.h                               |  14 +--
 be/src/olap/tablet_manager.cpp                     |  18 ++--
 be/src/olap/tablet_manager.h                       |   2 +-
 be/src/olap/tablet_meta_manager.cpp                |   2 +-
 be/src/olap/task/engine_batch_load_task.h          |   2 +-
 be/src/olap/task/engine_clone_task.cpp             |   8 +-
 be/src/olap/task/engine_storage_migration_task.cpp |   8 +-
 be/src/olap/txn_manager.h                          |   2 +-
 be/src/runtime/cache/result_cache.h                |   2 +-
 be/src/runtime/cache/result_node.cpp               |   2 +-
 be/src/runtime/cache/result_node.h                 |   2 +-
 be/src/runtime/data_spliter.cpp                    |   4 +-
 be/src/runtime/data_spliter.h                      |   2 +-
 be/src/runtime/data_stream_recvr.cc                |   2 +-
 be/src/runtime/datetime_value.cpp                  |   6 +-
 be/src/runtime/datetime_value.h                    |   6 +-
 be/src/runtime/decimal_value.cpp                   |   4 +-
 be/src/runtime/decimal_value.h                     |   2 +-
 be/src/runtime/decimalv2_value.cpp                 |   8 +-
 be/src/runtime/decimalv2_value.h                   |   8 +-
 be/src/runtime/descriptor_helper.h                 |   6 +-
 be/src/runtime/disk_io_mgr.cc                      |   4 +-
 be/src/runtime/disk_io_mgr.h                       |   4 +-
 be/src/runtime/disk_io_mgr_scan_range.cc           |   2 +-
 be/src/runtime/dpp_sink.cpp                        |  32 +++---
 be/src/runtime/dpp_sink.h                          |   4 +-
 be/src/runtime/dpp_writer.cpp                      |   2 +-
 be/src/runtime/etl_job_mgr.cpp                     |   4 +-
 be/src/runtime/file_result_writer.cpp              |   2 +-
 be/src/runtime/file_result_writer.h                |   4 +-
 be/src/runtime/fragment_mgr.cpp                    |   4 +-
 be/src/runtime/initial_reservations.cc             |   2 +-
 be/src/runtime/load_channel.cpp                    |   2 +-
 be/src/runtime/load_channel.h                      |   2 +-
 be/src/runtime/load_channel_mgr.cpp                |  14 +--
 be/src/runtime/load_channel_mgr.h                  |   6 +-
 be/src/runtime/load_path_mgr.cpp                   |   2 +-
 be/src/runtime/mem_pool.cpp                        |  12 +--
 be/src/runtime/mem_pool.h                          |   4 +-
 be/src/runtime/memory/chunk_allocator.h            |   2 +-
 be/src/runtime/mysql_result_writer.cpp             |   2 +-
 be/src/runtime/mysql_result_writer.h               |   4 +-
 be/src/runtime/mysql_table_writer.h                |   2 +-
 be/src/runtime/plan_fragment_executor.cpp          |   6 +-
 be/src/runtime/result_queue_mgr.cpp                |   6 +-
 be/src/runtime/routine_load/data_consumer.cpp      |   4 +-
 .../routine_load/routine_load_task_executor.cpp    |   2 +-
 be/src/runtime/row_batch.h                         |   6 +-
 be/src/runtime/stream_load/stream_load_context.h   |   2 +-
 .../runtime/stream_load/stream_load_executor.cpp   |   2 +-
 be/src/runtime/stream_load/stream_load_pipe.h      |   4 +-
 be/src/runtime/user_function_cache.h               |   8 +-
 be/src/service/doris_main.cpp                      |   2 +-
 be/src/service/internal_service.cpp                |   4 +-
 be/src/udf/udf.cpp                                 |   2 +-
 be/src/util/arrow/row_batch.cpp                    |   4 +-
 be/src/util/arrow/row_batch.h                      |   2 +-
 be/src/util/arrow/row_block.cpp                    |   2 +-
 be/src/util/bfd_parser.cpp                         |   2 +-
 be/src/util/cgroup_util.h                          |   2 +-
 be/src/util/cpu_info.cpp                           |   2 +-
 be/src/util/doris_metrics.h                        |   2 +-
 be/src/util/dynamic_util.h                         |   6 +-
 be/src/util/faststring.cc                          |   2 +-
 be/src/util/file_cache.h                           |   2 +-
 be/src/util/file_utils.cpp                         |   2 +-
 be/src/util/file_utils.h                           |   6 +-
 be/src/util/mutex.h                                |   2 +-
 be/src/util/mysql_global.h                         |   2 +-
 be/src/util/mysql_load_error_hub.cpp               |   4 +-
 be/src/util/mysql_row_buffer.cpp                   |  20 ++--
 be/src/util/null_load_error_hub.cpp                |   2 +-
 be/src/util/path_trie.hpp                          |   2 +-
 be/src/util/system_metrics.cpp                     |   2 +-
 be/src/util/tdigest.h                              |   2 +-
 be/src/util/thrift_rpc_helper.cpp                  |   2 +-
 be/test/env/env_posix_test.cpp                     |   4 +-
 be/test/exec/es_query_builder_test.cpp             |   8 +-
 be/test/exec/es_scan_reader_test.cpp               |  22 ++--
 be/test/exec/json_scanner_test.cpp                 |  26 ++---
 be/test/exec/json_scanner_test_with_jsonpath.cpp   |  26 ++---
 be/test/exec/parquet_scanner_test.cpp              |  36 +++----
 be/test/exec/schema_scan_node_test.cpp             |  42 ++++----
 .../schema_scanner/schema_authors_scanner_test.cpp |   2 +-
 .../schema_charsets_scanner_test.cpp               |   2 +-
 .../schema_collations_scanner_test.cpp             |   2 +-
 .../schema_scanner/schema_columns_scanner_test.cpp |   2 +-
 .../schema_create_table_scanner_test.cpp           |   2 +-
 .../schema_scanner/schema_engines_scanner_test.cpp |   2 +-
 .../schema_open_tables_scanner_test.cpp            |   2 +-
 be/test/exec/schema_scanner_test.cpp               |   2 +-
 be/test/exec/set_executor_test.cpp                 |   8 +-
 be/test/exec/tablet_sink_test.cpp                  |   4 +-
 be/test/exprs/CMakeLists.txt                       |   2 +-
 be/test/exprs/binary_predicate_test.cpp            |  22 ++--
 .../{hybird_set_test.cpp => hybrid_set_test.cpp}   |  60 +++++------
 be/test/exprs/in_op_test.cpp                       |  20 ++--
 be/test/olap/cumulative_compaction_policy_test.cpp |  30 +++---
 be/test/olap/push_handler_test.cpp                 |  10 +-
 be/test/olap/run_length_byte_test.cpp              |   8 +-
 be/test/olap/tablet_test.cpp                       |   9 +-
 be/test/olap/timestamped_version_tracker_test.cpp  | 112 ++++++++++-----------
 be/test/runtime/buffered_block_mgr2_test.cpp       |   2 +-
 be/test/runtime/datetime_value_test.cpp            |   2 +-
 be/test/runtime/decimalv2_value_test.cpp           |   2 +-
 be/test/runtime/etl_job_mgr_test.cpp               |   2 +-
 be/test/runtime/export_task_mgr_test.cpp           |   2 +-
 be/test/util/doris_metrics_test.cpp                |   2 +-
 be/test/util/new_metrics_test.cpp                  |  12 +--
 be/test/util/path_trie_test.cpp                    |   6 +-
 be/test/util/tdigest_test.cpp                      |   2 +-
 224 files changed, 744 insertions(+), 745 deletions(-)
 rename be/test/exprs/{hybird_set_test.cpp => hybrid_set_test.cpp} (83%)


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