Skip to content
Closed
Show file tree
Hide file tree
Changes from all commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
1 change: 1 addition & 0 deletions .clang-tidy
Original file line number Diff line number Diff line change
Expand Up @@ -28,6 +28,7 @@ Checks: [
'-bugprone-unchecked-optional-access',
'-bugprone-crtp-constructor-accessibility',
'-bugprone-not-null-terminated-result',
'-bugprone-forward-declaration-namespace',

'-cert-dcl16-c',
'-cert-err58-cpp',
Expand Down
2 changes: 0 additions & 2 deletions ci/jobs/scripts/check_style/aspell-ignore/en/aspell-dict.txt
Original file line number Diff line number Diff line change
Expand Up @@ -800,8 +800,6 @@ PagerDuty
ParallelFormattingOutputFormatThreads
ParallelFormattingOutputFormatThreadsActive
ParallelParsingInputFormat
ParallelParsingInputFormatThreads
ParallelParsingInputFormatThreadsActive
ParallelReplicasMode
ParquetCompression
ParquetMetadata
Expand Down
8 changes: 0 additions & 8 deletions docs/en/operations/system-tables/metrics.md
Original file line number Diff line number Diff line change
Expand Up @@ -524,14 +524,6 @@ Number of threads in the ParallelFormattingOutputFormatThreads thread pool.

Number of threads in the ParallelFormattingOutputFormatThreads thread pool running a task.

### ParallelParsingInputFormatThreads {#parallelparsinginputformatthreads}

Number of threads in the ParallelParsingInputFormat thread pool.

### ParallelParsingInputFormatThreadsActive {#parallelparsinginputformatthreadsactive}

Number of threads in the ParallelParsingInputFormat thread pool running a task.

### PartMutation {#partmutation}

Number of mutations (ALTER DELETE/UPDATE)
Expand Down
3 changes: 1 addition & 2 deletions programs/keeper-bench/Runner.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -576,8 +576,7 @@ struct ZooKeeperRequestFromLogReader
context,
context->getSettingsRef()[DB::Setting::max_block_size],
format_settings,
1,
std::nullopt,
DB::FormatParserGroup::singleThreaded(context->getSettingsRef()),
/*is_remote_fs*/ false,
DB::CompressionMethod::None,
false);
Expand Down
8 changes: 8 additions & 0 deletions programs/local/LocalServer.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -129,6 +129,9 @@ namespace ServerSetting
extern const ServerSettingsUInt64 max_prefixes_deserialization_thread_pool_size;
extern const ServerSettingsUInt64 max_prefixes_deserialization_thread_pool_free_size;
extern const ServerSettingsUInt64 prefixes_deserialization_thread_pool_thread_pool_queue_size;
extern const ServerSettingsUInt64 max_format_parsing_thread_pool_size;
extern const ServerSettingsUInt64 max_format_parsing_thread_pool_free_size;
extern const ServerSettingsUInt64 format_parsing_thread_pool_queue_size;
}

namespace ErrorCodes
Expand Down Expand Up @@ -266,6 +269,11 @@ void LocalServer::initialize(Poco::Util::Application & self)
server_settings[ServerSetting::max_prefixes_deserialization_thread_pool_size],
server_settings[ServerSetting::max_prefixes_deserialization_thread_pool_free_size],
server_settings[ServerSetting::prefixes_deserialization_thread_pool_thread_pool_queue_size]);

getFormatParsingThreadPool().initialize(
server_settings[ServerSetting::max_format_parsing_thread_pool_size],
server_settings[ServerSetting::max_format_parsing_thread_pool_free_size],
server_settings[ServerSetting::format_parsing_thread_pool_queue_size]);
}


Expand Down
13 changes: 13 additions & 0 deletions programs/server/Server.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -316,6 +316,9 @@ namespace ServerSetting
extern const ServerSettingsUInt64 max_prefixes_deserialization_thread_pool_size;
extern const ServerSettingsUInt64 max_prefixes_deserialization_thread_pool_free_size;
extern const ServerSettingsUInt64 prefixes_deserialization_thread_pool_thread_pool_queue_size;
extern const ServerSettingsUInt64 max_format_parsing_thread_pool_size;
extern const ServerSettingsUInt64 max_format_parsing_thread_pool_free_size;
extern const ServerSettingsUInt64 format_parsing_thread_pool_queue_size;
extern const ServerSettingsUInt64 page_cache_history_window_ms;
extern const ServerSettingsString page_cache_policy;
extern const ServerSettingsDouble page_cache_size_ratio;
Expand Down Expand Up @@ -1365,6 +1368,11 @@ try
server_settings[ServerSetting::max_prefixes_deserialization_thread_pool_free_size],
server_settings[ServerSetting::prefixes_deserialization_thread_pool_thread_pool_queue_size]);

getFormatParsingThreadPool().initialize(
server_settings[ServerSetting::max_format_parsing_thread_pool_size],
server_settings[ServerSetting::max_format_parsing_thread_pool_free_size],
server_settings[ServerSetting::format_parsing_thread_pool_queue_size]);

std::string path_str = getCanonicalPath(config().getString("path", DBMS_DEFAULT_PATH));
fs::path path = path_str;

Expand Down Expand Up @@ -2088,6 +2096,11 @@ try
new_server_settings[ServerSetting::max_prefixes_deserialization_thread_pool_free_size],
new_server_settings[ServerSetting::prefixes_deserialization_thread_pool_thread_pool_queue_size]);

getFormatParsingThreadPool().reloadConfiguration(
new_server_settings[ServerSetting::max_format_parsing_thread_pool_size],
new_server_settings[ServerSetting::max_format_parsing_thread_pool_free_size],
new_server_settings[ServerSetting::format_parsing_thread_pool_queue_size]);

global_context->setMergeWorkload(new_server_settings[ServerSetting::merge_workload]);
global_context->setMutationWorkload(new_server_settings[ServerSetting::mutation_workload]);
global_context->setThrowOnUnknownWorkload(new_server_settings[ServerSetting::throw_on_unknown_workload]);
Expand Down
2 changes: 2 additions & 0 deletions src/Client/ClientBase.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -70,9 +70,11 @@
#include <IO/WriteBufferFromFileDescriptor.h>
#include <IO/CompressionMethod.h>
#include <IO/ForkWriteBuffer.h>
#include <IO/SharedThreadPools.h>

#include <Access/AccessControl.h>
#include <Storages/ColumnsDescription.h>
#include <Storages/SelectQueryInfo.h>
#include <TableFunctions/ITableFunction.h>

#include <filesystem>
Expand Down
15 changes: 3 additions & 12 deletions src/Common/CurrentMetrics.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -153,9 +153,6 @@
M(ParallelFormattingOutputFormatThreads, "Number of threads in the ParallelFormattingOutputFormatThreads thread pool.") \
M(ParallelFormattingOutputFormatThreadsActive, "Number of threads in the ParallelFormattingOutputFormatThreads thread pool running a task.") \
M(ParallelFormattingOutputFormatThreadsScheduled, "Number of queued or active jobs in the ParallelFormattingOutputFormatThreads thread pool.") \
M(ParallelParsingInputFormatThreads, "Number of threads in the ParallelParsingInputFormat thread pool.") \
M(ParallelParsingInputFormatThreadsActive, "Number of threads in the ParallelParsingInputFormat thread pool running a task.") \
M(ParallelParsingInputFormatThreadsScheduled, "Number of queued or active jobs in the ParallelParsingInputFormat thread pool.") \
M(MergeTreeBackgroundExecutorThreads, "Number of threads in the MergeTreeBackgroundExecutor thread pool.") \
M(MergeTreeBackgroundExecutorThreadsActive, "Number of threads in the MergeTreeBackgroundExecutor thread pool running a task.") \
M(MergeTreeBackgroundExecutorThreadsScheduled, "Number of queued or active jobs in the MergeTreeBackgroundExecutor thread pool.") \
Expand Down Expand Up @@ -239,21 +236,15 @@
M(QueryPipelineExecutorThreads, "Number of threads in the PipelineExecutor thread pool.") \
M(QueryPipelineExecutorThreadsActive, "Number of threads in the PipelineExecutor thread pool running a task.") \
M(QueryPipelineExecutorThreadsScheduled, "Number of queued or active jobs in the PipelineExecutor thread pool.") \
M(ParquetDecoderThreads, "Number of threads in the ParquetBlockInputFormat thread pool.") \
M(ParquetDecoderThreadsActive, "Number of threads in the ParquetBlockInputFormat thread pool running a task.") \
M(ParquetDecoderThreadsScheduled, "Number of queued or active jobs in the ParquetBlockInputFormat thread pool.") \
M(ParquetDecoderIOThreads, "Number of threads in the ParquetBlockInputFormat io thread pool.") \
M(ParquetDecoderIOThreadsActive, "Number of threads in the ParquetBlockInputFormat io thread pool running a task.") \
M(ParquetDecoderIOThreadsScheduled, "Number of queued or active jobs in the ParquetBlockInputFormat io thread pool.") \
M(ParquetEncoderThreads, "Number of threads in ParquetBlockOutputFormat thread pool.") \
M(ParquetEncoderThreadsActive, "Number of threads in ParquetBlockOutputFormat thread pool running a task.") \
M(ParquetEncoderThreadsScheduled, "Number of queued or active jobs in ParquetBlockOutputFormat thread pool.") \
M(MergeTreeSubcolumnsReaderThreads, "Number of threads in the thread pool used for subcolumns reading in MergeTree.") \
M(MergeTreeSubcolumnsReaderThreadsActive, "Number of threads in the thread pool used for subcolumns reading in MergeTree running a task.") \
M(MergeTreeSubcolumnsReaderThreadsScheduled, "Number of queued or active jobs in the thread pool used for subcolumns reading in MergeTree.") \
M(DWARFReaderThreads, "Number of threads in the DWARFBlockInputFormat thread pool.") \
M(DWARFReaderThreadsActive, "Number of threads in the DWARFBlockInputFormat thread pool running a task.") \
M(DWARFReaderThreadsScheduled, "Number of queued or active jobs in the DWARFBlockInputFormat thread pool.") \
M(FormatParsingThreads, "Number of threads in the thread pool used for parsing input.") \
M(FormatParsingThreadsActive, "Number of threads in the thread pool used for parsing input running a task.") \
M(FormatParsingThreadsScheduled, "Number of queued or active jobs in the thread pool used for parsing input.") \
M(OutdatedPartsLoadingThreads, "Number of threads in the threadpool for loading Outdated data parts.") \
M(OutdatedPartsLoadingThreadsActive, "Number of active threads in the threadpool for loading Outdated data parts.") \
M(OutdatedPartsLoadingThreadsScheduled, "Number of queued or active jobs in the threadpool for loading Outdated data parts.") \
Expand Down
Loading
Loading