You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by yi...@apache.org on 2022/04/18 01:52:38 UTC

[incubator-doris] branch master updated: [Refactor] Cleanup some unused include (#9063)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new c71ffc01de [Refactor] Cleanup some unused include (#9063)
c71ffc01de is described below

commit c71ffc01de84482ab268aefc2b32d18d66908a62
Author: hongbin <xl...@users.noreply.github.com>
AuthorDate: Mon Apr 18 09:52:31 2022 +0800

    [Refactor] Cleanup some unused include (#9063)
---
 be/src/runtime/buffered_block_mgr2.cc                      | 2 --
 be/src/runtime/buffered_tuple_stream3.cc                   | 2 --
 be/src/runtime/client_cache.cpp                            | 5 -----
 be/src/runtime/collection_value.cpp                        | 2 --
 be/src/runtime/data_stream_mgr.cpp                         | 1 -
 be/src/runtime/data_stream_recvr.cc                        | 1 -
 be/src/runtime/data_stream_sender.cpp                      | 2 --
 be/src/runtime/descriptors.cpp                             | 1 -
 be/src/runtime/disk_io_mgr_scan_range.cc                   | 1 -
 be/src/runtime/dpp_writer.cpp                              | 1 -
 be/src/runtime/exec_env_init.cpp                           | 5 -----
 be/src/runtime/export_sink.cpp                             | 1 -
 be/src/runtime/file_result_writer.cpp                      | 2 --
 be/src/runtime/fold_constant_executor.cpp                  | 2 +-
 be/src/runtime/initial_reservations.cc                     | 2 --
 be/src/runtime/memory/chunk_allocator.cpp                  | 2 --
 be/src/runtime/memory_scratch_sink.cpp                     | 5 -----
 be/src/runtime/message_body_sink.cpp                       | 2 --
 be/src/runtime/mysql_result_writer.cpp                     | 6 ------
 be/src/runtime/mysql_table_sink.cpp                        | 1 -
 be/src/runtime/mysql_table_writer.cpp                      | 1 -
 be/src/runtime/plan_fragment_executor.cpp                  | 2 --
 be/src/runtime/result_buffer_mgr.cpp                       | 1 -
 be/src/runtime/result_file_sink.cpp                        | 1 -
 be/src/runtime/result_queue_mgr.cpp                        | 3 ---
 be/src/runtime/routine_load/routine_load_task_executor.cpp | 1 -
 be/src/runtime/runtime_filter_mgr.cpp                      | 2 --
 be/src/runtime/runtime_state.cpp                           | 6 ------
 be/src/runtime/small_file_mgr.cpp                          | 1 -
 be/src/runtime/snapshot_loader.cpp                         | 2 --
 be/src/runtime/stream_load/stream_load_executor.cpp        | 1 -
 be/src/runtime/thread_resource_mgr.cpp                     | 1 -
 be/src/runtime/threadlocal.cc                              | 1 -
 be/src/runtime/tmp_file_mgr.cc                             | 2 --
 be/src/runtime/tmp_file_mgr.h                              | 1 -
 be/src/runtime/tuple.cpp                                   | 4 ----
 be/src/runtime/types.cpp                                   | 1 -
 be/src/runtime/user_function_cache.cpp                     | 2 --
 be/src/service/http_service.cpp                            | 1 -
 39 files changed, 1 insertion(+), 79 deletions(-)

diff --git a/be/src/runtime/buffered_block_mgr2.cc b/be/src/runtime/buffered_block_mgr2.cc
index 4e388f9d01..81cfc37630 100644
--- a/be/src/runtime/buffered_block_mgr2.cc
+++ b/be/src/runtime/buffered_block_mgr2.cc
@@ -19,7 +19,6 @@
 
 #include "exec/exec_node.h"
 #include "runtime/exec_env.h"
-#include "runtime/mem_pool.h"
 #include "runtime/mem_tracker.h"
 #include "runtime/runtime_state.h"
 #include "runtime/tmp_file_mgr.h"
@@ -27,7 +26,6 @@
 #include "util/debug_util.h"
 #include "util/disk_info.h"
 #include "util/doris_metrics.h"
-#include "util/filesystem_util.h"
 #include "util/pretty_printer.h"
 #include "util/runtime_profile.h"
 #include "util/stack_util.h"
diff --git a/be/src/runtime/buffered_tuple_stream3.cc b/be/src/runtime/buffered_tuple_stream3.cc
index 72eead6b08..afdba93961 100644
--- a/be/src/runtime/buffered_tuple_stream3.cc
+++ b/be/src/runtime/buffered_tuple_stream3.cc
@@ -26,8 +26,6 @@
 #include "runtime/tuple_row.h"
 #include "util/bit_util.h"
 #include "util/debug_util.h"
-#include "util/pretty_printer.h"
-#include "util/runtime_profile.h"
 
 #ifdef NDEBUG
 #define CHECK_CONSISTENCY_FAST()
diff --git a/be/src/runtime/client_cache.cpp b/be/src/runtime/client_cache.cpp
index 47d69886f8..2e6217df2c 100644
--- a/be/src/runtime/client_cache.cpp
+++ b/be/src/runtime/client_cache.cpp
@@ -18,19 +18,14 @@
 #include "runtime/client_cache.h"
 
 #include <thrift/protocol/TBinaryProtocol.h>
-#include <thrift/server/TServer.h>
-#include <thrift/transport/TSocket.h>
-#include <thrift/transport/TTransportUtils.h>
 
 #include <memory>
 #include <sstream>
 
 #include "common/logging.h"
 #include "gen_cpp/FrontendService.h"
-#include "util/container_util.hpp"
 #include "util/doris_metrics.h"
 #include "util/network_util.h"
-#include "util/thrift_util.h"
 
 namespace doris {
 
diff --git a/be/src/runtime/collection_value.cpp b/be/src/runtime/collection_value.cpp
index f738695273..f115db2cba 100644
--- a/be/src/runtime/collection_value.cpp
+++ b/be/src/runtime/collection_value.cpp
@@ -21,8 +21,6 @@
 
 #include "common/logging.h"
 #include "common/utils.h"
-#include "exprs/anyval_util.h"
-#include "exprs/literal.h"
 #include "runtime/descriptors.h"
 #include "util//mem_util.hpp"
 
diff --git a/be/src/runtime/data_stream_mgr.cpp b/be/src/runtime/data_stream_mgr.cpp
index 6363c61d4b..0a7f337a24 100644
--- a/be/src/runtime/data_stream_mgr.cpp
+++ b/be/src/runtime/data_stream_mgr.cpp
@@ -28,7 +28,6 @@
 #include "runtime/row_batch.h"
 #include "runtime/runtime_state.h"
 #include "util/doris_metrics.h"
-#include "util/uid_util.h"
 
 namespace doris {
 
diff --git a/be/src/runtime/data_stream_recvr.cc b/be/src/runtime/data_stream_recvr.cc
index 1232cceeb5..d31d3a8a54 100644
--- a/be/src/runtime/data_stream_recvr.cc
+++ b/be/src/runtime/data_stream_recvr.cc
@@ -32,7 +32,6 @@
 #include "util/debug_util.h"
 #include "util/logging.h"
 #include "util/runtime_profile.h"
-#include "util/uid_util.h"
 
 using std::list;
 using std::vector;
diff --git a/be/src/runtime/data_stream_sender.cpp b/be/src/runtime/data_stream_sender.cpp
index dae7b8a621..753b312495 100644
--- a/be/src/runtime/data_stream_sender.cpp
+++ b/be/src/runtime/data_stream_sender.cpp
@@ -18,12 +18,10 @@
 #include "runtime/data_stream_sender.h"
 
 #include <arpa/inet.h>
-#include <thrift/protocol/TDebugProtocol.h>
 
 #include <algorithm>
 #include <iostream>
 #include <random>
-#include <thread>
 
 #include "common/config.h"
 #include "common/logging.h"
diff --git a/be/src/runtime/descriptors.cpp b/be/src/runtime/descriptors.cpp
index 0ed1e531c1..6a341dafce 100644
--- a/be/src/runtime/descriptors.cpp
+++ b/be/src/runtime/descriptors.cpp
@@ -25,7 +25,6 @@
 #include "gen_cpp/Descriptors_types.h"
 #include "gen_cpp/descriptors.pb.h"
 #include "vec/columns/column_nullable.h"
-#include "vec/core/columns_with_type_and_name.h"
 #include "vec/data_types/data_type_factory.hpp"
 #include "vec/data_types/data_type_nullable.h"
 
diff --git a/be/src/runtime/disk_io_mgr_scan_range.cc b/be/src/runtime/disk_io_mgr_scan_range.cc
index 03a5437135..014d16e365 100644
--- a/be/src/runtime/disk_io_mgr_scan_range.cc
+++ b/be/src/runtime/disk_io_mgr_scan_range.cc
@@ -18,7 +18,6 @@
 #include "runtime/disk_io_mgr.h"
 #include "runtime/disk_io_mgr_internal.h"
 #include "util/error_util.h"
-// #include "util/hdfs-util.h"
 
 using std::string;
 using std::stringstream;
diff --git a/be/src/runtime/dpp_writer.cpp b/be/src/runtime/dpp_writer.cpp
index 445ff32fe1..00a746872d 100644
--- a/be/src/runtime/dpp_writer.cpp
+++ b/be/src/runtime/dpp_writer.cpp
@@ -21,7 +21,6 @@
 
 #include <vector>
 
-#include "exprs/expr.h"
 #include "exprs/expr_context.h"
 #include "olap/utils.h"
 #include "runtime/primitive_type.h"
diff --git a/be/src/runtime/exec_env_init.cpp b/be/src/runtime/exec_env_init.cpp
index 0d483eaa4c..8118fd2683 100644
--- a/be/src/runtime/exec_env_init.cpp
+++ b/be/src/runtime/exec_env_init.cpp
@@ -15,13 +15,10 @@
 // specific language governing permissions and limitations
 // under the License.
 
-#include <boost/algorithm/string.hpp>
-
 #include "agent/cgroups_mgr.h"
 #include "common/config.h"
 #include "common/logging.h"
 #include "gen_cpp/BackendService.h"
-#include "gen_cpp/FrontendService.h"
 #include "gen_cpp/HeartbeatService_types.h"
 #include "gen_cpp/TExtDataSourceService.h"
 #include "gen_cpp/TPaloBrokerService.h"
@@ -55,11 +52,9 @@
 #include "runtime/tmp_file_mgr.h"
 #include "util/bfd_parser.h"
 #include "util/brpc_client_cache.h"
-#include "util/debug_util.h"
 #include "util/doris_metrics.h"
 #include "util/mem_info.h"
 #include "util/metrics.h"
-#include "util/network_util.h"
 #include "util/parse_util.h"
 #include "util/pretty_printer.h"
 #include "util/priority_thread_pool.hpp"
diff --git a/be/src/runtime/export_sink.cpp b/be/src/runtime/export_sink.cpp
index c9d529ab32..69c1b0d13c 100644
--- a/be/src/runtime/export_sink.cpp
+++ b/be/src/runtime/export_sink.cpp
@@ -28,7 +28,6 @@
 #include "exprs/expr.h"
 #include "exprs/expr_context.h"
 #include "gutil/strings/numbers.h"
-#include "runtime/mysql_table_sink.h"
 #include "runtime/row_batch.h"
 #include "runtime/runtime_state.h"
 #include "runtime/tuple_row.h"
diff --git a/be/src/runtime/file_result_writer.cpp b/be/src/runtime/file_result_writer.cpp
index 6b20f5dfd0..9ac230310a 100644
--- a/be/src/runtime/file_result_writer.cpp
+++ b/be/src/runtime/file_result_writer.cpp
@@ -19,11 +19,9 @@
 
 #include "exec/broker_writer.h"
 #include "exec/hdfs_reader_writer.h"
-#include "exec/hdfs_writer.h"
 #include "exec/local_file_writer.h"
 #include "exec/parquet_writer.h"
 #include "exec/s3_writer.h"
-#include "exprs/expr.h"
 #include "exprs/expr_context.h"
 #include "gen_cpp/PaloInternalService_types.h"
 #include "runtime/buffer_control_block.h"
diff --git a/be/src/runtime/fold_constant_executor.cpp b/be/src/runtime/fold_constant_executor.cpp
index 274750b8b3..4a51b91932 100644
--- a/be/src/runtime/fold_constant_executor.cpp
+++ b/be/src/runtime/fold_constant_executor.cpp
@@ -14,10 +14,10 @@
 // KIND, either express or implied.  See the License for the
 // specific language governing permissions and limitations
 // under the License.
+
 #include "runtime/fold_constant_executor.h"
 
 #include <map>
-#include <string>
 
 #include "runtime/tuple_row.h"
 #include "runtime/exec_env.h"
diff --git a/be/src/runtime/initial_reservations.cc b/be/src/runtime/initial_reservations.cc
index 86b1f2f1b6..1783b080dd 100644
--- a/be/src/runtime/initial_reservations.cc
+++ b/be/src/runtime/initial_reservations.cc
@@ -17,8 +17,6 @@
 
 #include "runtime/initial_reservations.h"
 
-#include <gflags/gflags.h>
-
 #include <limits>
 #include <mutex>
 
diff --git a/be/src/runtime/memory/chunk_allocator.cpp b/be/src/runtime/memory/chunk_allocator.cpp
index 5d4c7b34f9..2d2a9a5c01 100644
--- a/be/src/runtime/memory/chunk_allocator.cpp
+++ b/be/src/runtime/memory/chunk_allocator.cpp
@@ -17,11 +17,9 @@
 
 #include "runtime/memory/chunk_allocator.h"
 
-#include <atomic>
 #include <list>
 #include <mutex>
 
-#include "gutil/dynamic_annotations.h"
 #include "runtime/mem_tracker.h"
 #include "runtime/memory/chunk.h"
 #include "runtime/memory/system_allocator.h"
diff --git a/be/src/runtime/memory_scratch_sink.cpp b/be/src/runtime/memory_scratch_sink.cpp
index 03b87ba80e..ffa0e200dc 100644
--- a/be/src/runtime/memory_scratch_sink.cpp
+++ b/be/src/runtime/memory_scratch_sink.cpp
@@ -22,19 +22,14 @@
 
 #include <sstream>
 
-#include "common/logging.h"
 #include "exprs/expr.h"
-#include "gen_cpp/DorisExternalService_types.h"
 #include "gen_cpp/Types_types.h"
 #include "runtime/exec_env.h"
 #include "runtime/primitive_type.h"
-#include "runtime/result_queue_mgr.h"
 #include "runtime/row_batch.h"
 #include "runtime/runtime_state.h"
 #include "runtime/tuple_row.h"
 #include "util/arrow/row_batch.h"
-#include "util/date_func.h"
-#include "util/types.h"
 
 namespace doris {
 
diff --git a/be/src/runtime/message_body_sink.cpp b/be/src/runtime/message_body_sink.cpp
index 6538ece187..62aa309c24 100644
--- a/be/src/runtime/message_body_sink.cpp
+++ b/be/src/runtime/message_body_sink.cpp
@@ -18,8 +18,6 @@
 #include "runtime/message_body_sink.h"
 
 #include <fcntl.h>
-#include <sys/stat.h>
-#include <sys/types.h>
 
 #include <algorithm>
 
diff --git a/be/src/runtime/mysql_result_writer.cpp b/be/src/runtime/mysql_result_writer.cpp
index 6920db6870..83e12660eb 100644
--- a/be/src/runtime/mysql_result_writer.cpp
+++ b/be/src/runtime/mysql_result_writer.cpp
@@ -17,7 +17,6 @@
 
 #include "runtime/mysql_result_writer.h"
 
-#include "exprs/expr.h"
 #include "exprs/expr_context.h"
 #include "gen_cpp/PaloInternalService_types.h"
 #include "runtime/buffer_control_block.h"
@@ -25,15 +24,10 @@
 #include "runtime/result_buffer_mgr.h"
 #include "runtime/row_batch.h"
 #include "runtime/tuple_row.h"
-#include "util/date_func.h"
 #include "util/mysql_row_buffer.h"
 #include "util/types.h"
-#include "vec/columns/column_nullable.h"
 #include "vec/columns/column_vector.h"
-#include "vec/common/assert_cast.h"
 #include "vec/core/block.h"
-#include "vec/exprs/vexpr.h"
-#include "vec/exprs/vexpr_context.h"
 
 namespace doris {
 
diff --git a/be/src/runtime/mysql_table_sink.cpp b/be/src/runtime/mysql_table_sink.cpp
index 3b17c1c09f..ad4f4db085 100644
--- a/be/src/runtime/mysql_table_sink.cpp
+++ b/be/src/runtime/mysql_table_sink.cpp
@@ -21,7 +21,6 @@
 
 #include "exprs/expr.h"
 #include "runtime/mem_tracker.h"
-#include "runtime/mysql_table_sink.h"
 #include "runtime/runtime_state.h"
 #include "util/debug_util.h"
 #include "util/runtime_profile.h"
diff --git a/be/src/runtime/mysql_table_writer.cpp b/be/src/runtime/mysql_table_writer.cpp
index 3055da70d3..1eee906d80 100644
--- a/be/src/runtime/mysql_table_writer.cpp
+++ b/be/src/runtime/mysql_table_writer.cpp
@@ -21,7 +21,6 @@
 
 #include <sstream>
 
-#include "exprs/expr.h"
 #include "exprs/expr_context.h"
 #include "runtime/row_batch.h"
 #include "runtime/tuple_row.h"
diff --git a/be/src/runtime/plan_fragment_executor.cpp b/be/src/runtime/plan_fragment_executor.cpp
index 3f984a0270..df907bd2a6 100644
--- a/be/src/runtime/plan_fragment_executor.cpp
+++ b/be/src/runtime/plan_fragment_executor.cpp
@@ -21,7 +21,6 @@
 
 #include <unordered_map>
 
-#include "common/object_pool.h"
 #include "exec/data_sink.h"
 #include "exec/exchange_node.h"
 #include "exec/exec_node.h"
@@ -36,7 +35,6 @@
 #include "runtime/row_batch.h"
 #include "runtime/thread_context.h"
 #include "util/container_util.hpp"
-#include "util/cpu_info.h"
 #include "util/logging.h"
 #include "util/mem_info.h"
 #include "util/parse_util.h"
diff --git a/be/src/runtime/result_buffer_mgr.cpp b/be/src/runtime/result_buffer_mgr.cpp
index aaaae29b09..d51ae4a679 100644
--- a/be/src/runtime/result_buffer_mgr.cpp
+++ b/be/src/runtime/result_buffer_mgr.cpp
@@ -21,7 +21,6 @@
 #include "gen_cpp/types.pb.h"
 #include "runtime/buffer_control_block.h"
 #include "runtime/raw_value.h"
-#include "util/debug_util.h"
 #include "util/doris_metrics.h"
 
 namespace doris {
diff --git a/be/src/runtime/result_file_sink.cpp b/be/src/runtime/result_file_sink.cpp
index 6f5e4d540e..c4c45ad16f 100644
--- a/be/src/runtime/result_file_sink.cpp
+++ b/be/src/runtime/result_file_sink.cpp
@@ -22,7 +22,6 @@
 #include "runtime/buffer_control_block.h"
 #include "runtime/exec_env.h"
 #include "runtime/file_result_writer.h"
-#include "runtime/mysql_result_writer.h"
 #include "runtime/result_buffer_mgr.h"
 #include "runtime/row_batch.h"
 #include "runtime/runtime_state.h"
diff --git a/be/src/runtime/result_queue_mgr.cpp b/be/src/runtime/result_queue_mgr.cpp
index 78d4d692fb..5dbae4787e 100644
--- a/be/src/runtime/result_queue_mgr.cpp
+++ b/be/src/runtime/result_queue_mgr.cpp
@@ -18,12 +18,9 @@
 #include "runtime/result_queue_mgr.h"
 
 #include "common/config.h"
-#include "common/logging.h"
 #include "common/status.h"
-#include "gen_cpp/DorisExternalService_types.h"
 #include "gen_cpp/Types_types.h"
 #include "runtime/exec_env.h"
-#include "util/arrow/row_batch.h"
 #include "util/doris_metrics.h"
 
 namespace doris {
diff --git a/be/src/runtime/routine_load/routine_load_task_executor.cpp b/be/src/runtime/routine_load/routine_load_task_executor.cpp
index 1c72a52eaa..d74442975c 100644
--- a/be/src/runtime/routine_load/routine_load_task_executor.cpp
+++ b/be/src/runtime/routine_load/routine_load_task_executor.cpp
@@ -27,7 +27,6 @@
 #include "runtime/routine_load/data_consumer_group.h"
 #include "runtime/routine_load/kafka_consumer_pipe.h"
 #include "runtime/stream_load/stream_load_context.h"
-#include "runtime/stream_load/stream_load_executor.h"
 #include "util/defer_op.h"
 #include "util/uid_util.h"
 
diff --git a/be/src/runtime/runtime_filter_mgr.cpp b/be/src/runtime/runtime_filter_mgr.cpp
index a5bb1df0c0..4eade51b46 100644
--- a/be/src/runtime/runtime_filter_mgr.cpp
+++ b/be/src/runtime/runtime_filter_mgr.cpp
@@ -25,12 +25,10 @@
 #include "runtime/exec_env.h"
 #include "runtime/mem_tracker.h"
 #include "runtime/plan_fragment_executor.h"
-#include "runtime/runtime_filter_mgr.h"
 #include "runtime/runtime_state.h"
 #include "runtime/thread_context.h"
 #include "service/brpc.h"
 #include "util/brpc_client_cache.h"
-#include "util/time.h"
 
 namespace doris {
 
diff --git a/be/src/runtime/runtime_state.cpp b/be/src/runtime/runtime_state.cpp
index e274c0e5bd..a60d502131 100644
--- a/be/src/runtime/runtime_state.cpp
+++ b/be/src/runtime/runtime_state.cpp
@@ -19,7 +19,6 @@
 
 #include <boost/algorithm/string/join.hpp>
 #include <fmt/format.h>
-#include <iostream>
 #include <sstream>
 #include <string>
 
@@ -27,22 +26,17 @@
 #include "common/object_pool.h"
 #include "common/status.h"
 #include "exec/exec_node.h"
-#include "exprs/expr.h"
 #include "runtime/buffered_block_mgr2.h"
 #include "runtime/bufferpool/reservation_tracker.h"
 #include "runtime/bufferpool/reservation_util.h"
-#include "runtime/descriptors.h"
 #include "runtime/exec_env.h"
 #include "runtime/initial_reservations.h"
 #include "runtime/load_path_mgr.h"
 #include "runtime/mem_tracker.h"
 #include "runtime/mem_tracker_task_pool.h"
 #include "runtime/runtime_filter_mgr.h"
-#include "util/cpu_info.h"
-#include "util/disk_info.h"
 #include "util/file_utils.h"
 #include "util/load_error_hub.h"
-#include "util/mem_info.h"
 #include "util/pretty_printer.h"
 #include "util/timezone_utils.h"
 #include "util/uid_util.h"
diff --git a/be/src/runtime/small_file_mgr.cpp b/be/src/runtime/small_file_mgr.cpp
index fc0aa2056a..e7b842a347 100644
--- a/be/src/runtime/small_file_mgr.cpp
+++ b/be/src/runtime/small_file_mgr.cpp
@@ -20,7 +20,6 @@
 #include <stdint.h>
 #include <stdio.h>
 
-#include <boost/algorithm/string/classification.hpp> // boost::is_any_of
 #include <boost/algorithm/string/predicate.hpp>      // boost::algorithm::starts_with
 #include <sstream>
 
diff --git a/be/src/runtime/snapshot_loader.cpp b/be/src/runtime/snapshot_loader.cpp
index 02340d4931..79fff7f02e 100644
--- a/be/src/runtime/snapshot_loader.cpp
+++ b/be/src/runtime/snapshot_loader.cpp
@@ -21,8 +21,6 @@
 
 #include "common/logging.h"
 #include "env/env.h"
-#include "exec/broker_reader.h"
-#include "exec/broker_writer.h"
 #include "gen_cpp/FrontendService.h"
 #include "gen_cpp/FrontendService_types.h"
 #include "gen_cpp/HeartbeatService_types.h"
diff --git a/be/src/runtime/stream_load/stream_load_executor.cpp b/be/src/runtime/stream_load/stream_load_executor.cpp
index 67b8336fbe..f93d7c97d7 100644
--- a/be/src/runtime/stream_load/stream_load_executor.cpp
+++ b/be/src/runtime/stream_load/stream_load_executor.cpp
@@ -23,7 +23,6 @@
 #include "runtime/exec_env.h"
 #include "runtime/fragment_mgr.h"
 #include "runtime/plan_fragment_executor.h"
-#include "runtime/runtime_state.h"
 #include "runtime/stream_load/stream_load_context.h"
 #include "util/doris_metrics.h"
 #include "util/thrift_rpc_helper.h"
diff --git a/be/src/runtime/thread_resource_mgr.cpp b/be/src/runtime/thread_resource_mgr.cpp
index be6d21a027..fcf9e47068 100644
--- a/be/src/runtime/thread_resource_mgr.cpp
+++ b/be/src/runtime/thread_resource_mgr.cpp
@@ -17,7 +17,6 @@
 
 #include "runtime/thread_resource_mgr.h"
 
-#include <boost/algorithm/string.hpp>
 #include <vector>
 
 #include "common/config.h"
diff --git a/be/src/runtime/threadlocal.cc b/be/src/runtime/threadlocal.cc
index ac2bf2e62a..83e38e6a45 100644
--- a/be/src/runtime/threadlocal.cc
+++ b/be/src/runtime/threadlocal.cc
@@ -20,7 +20,6 @@
 
 #include <memory>
 #include <ostream>
-#include <string>
 
 #include "common/logging.h"
 #include "gutil/once.h"
diff --git a/be/src/runtime/tmp_file_mgr.cc b/be/src/runtime/tmp_file_mgr.cc
index f8cc4ad71a..15a1516293 100644
--- a/be/src/runtime/tmp_file_mgr.cc
+++ b/be/src/runtime/tmp_file_mgr.cc
@@ -21,8 +21,6 @@
 #include <boost/uuid/random_generator.hpp>
 #include <boost/uuid/uuid_io.hpp>
 #include <filesystem>
-// #include <gutil/strings/substitute.h>
-// #include <gutil/strings/join.h>
 
 #include "olap/storage_engine.h"
 #include "runtime/exec_env.h"
diff --git a/be/src/runtime/tmp_file_mgr.h b/be/src/runtime/tmp_file_mgr.h
index 9ca97a6e0c..f9d2799ce0 100644
--- a/be/src/runtime/tmp_file_mgr.h
+++ b/be/src/runtime/tmp_file_mgr.h
@@ -20,7 +20,6 @@
 
 #include "common/status.h"
 #include "gen_cpp/Types_types.h" // for TUniqueId
-// #include "util/collection_metrics.h"
 #include "util/metrics.h"
 #include "util/spinlock.h"
 
diff --git a/be/src/runtime/tuple.cpp b/be/src/runtime/tuple.cpp
index 464442616a..e798159663 100644
--- a/be/src/runtime/tuple.cpp
+++ b/be/src/runtime/tuple.cpp
@@ -18,14 +18,10 @@
 #include "runtime/tuple.h"
 
 #include <functional>
-#include <iomanip>
 #include <iostream>
-#include <sstream>
-#include <string>
 #include <vector>
 
 #include "common/utils.h"
-#include "exprs/expr.h"
 #include "exprs/expr_context.h"
 #include "runtime/collection_value.h"
 #include "runtime/descriptors.h"
diff --git a/be/src/runtime/types.cpp b/be/src/runtime/types.cpp
index 63ff515121..c25cbb50f1 100644
--- a/be/src/runtime/types.cpp
+++ b/be/src/runtime/types.cpp
@@ -18,7 +18,6 @@
 #include "runtime/types.h"
 
 #include <ostream>
-#include <sstream>
 
 namespace doris {
 
diff --git a/be/src/runtime/user_function_cache.cpp b/be/src/runtime/user_function_cache.cpp
index 503ba5e67b..27e590e5a3 100644
--- a/be/src/runtime/user_function_cache.cpp
+++ b/be/src/runtime/user_function_cache.cpp
@@ -18,7 +18,6 @@
 #include "runtime/user_function_cache.h"
 
 #include <atomic>
-#include <boost/algorithm/string/classification.hpp> // boost::is_any_of
 #include <boost/algorithm/string/predicate.hpp>      // boost::algorithm::ends_with
 #include <regex>
 #include <vector>
@@ -28,7 +27,6 @@
 #include "http/http_client.h"
 #include "util/dynamic_util.h"
 #include "util/file_utils.h"
-#include "util/jni-util.h"
 #include "util/md5.h"
 #include "util/spinlock.h"
 
diff --git a/be/src/service/http_service.cpp b/be/src/service/http_service.cpp
index 89267dfc48..2d3b9daba3 100644
--- a/be/src/service/http_service.cpp
+++ b/be/src/service/http_service.cpp
@@ -26,7 +26,6 @@
 #include "http/action/meta_action.h"
 #include "http/action/metrics_action.h"
 #include "http/action/mini_load.h"
-#include "http/action/monitor_action.h"
 #include "http/action/pprof_actions.h"
 #include "http/action/reload_tablet_action.h"
 #include "http/action/reset_rpc_channel_action.h"


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