mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-21 23:21:59 +00:00
delete and fix strange code
This commit is contained in:
parent
161c921dba
commit
57705f5b73
@ -1,5 +1,5 @@
|
||||
if (USE_CLANG_TIDY)
|
||||
set (CMAKE_CXX_CLANG_TIDY "${CLANG_TIDY_PATH} -fix")
|
||||
set (CMAKE_CXX_CLANG_TIDY "${CLANG_TIDY_PATH}")
|
||||
endif ()
|
||||
|
||||
add_subdirectory (common)
|
||||
|
@ -1,5 +1,5 @@
|
||||
if (USE_CLANG_TIDY)
|
||||
set (CMAKE_CXX_CLANG_TIDY "${CLANG_TIDY_PATH} -fix")
|
||||
set (CMAKE_CXX_CLANG_TIDY "${CLANG_TIDY_PATH}")
|
||||
endif ()
|
||||
|
||||
# The `clickhouse` binary is a multi purpose tool that contains multiple execution modes (client, server, etc.),
|
||||
|
@ -3,7 +3,7 @@ if (USE_INCLUDE_WHAT_YOU_USE)
|
||||
endif ()
|
||||
|
||||
if (USE_CLANG_TIDY)
|
||||
set (CMAKE_CXX_CLANG_TIDY "${CLANG_TIDY_PATH} -fix")
|
||||
set (CMAKE_CXX_CLANG_TIDY "${CLANG_TIDY_PATH}")
|
||||
endif ()
|
||||
|
||||
if(COMPILER_PIPE)
|
||||
|
@ -121,7 +121,7 @@ class IColumn;
|
||||
\
|
||||
M(Bool, input_format_parallel_parsing, true, "Enable parallel parsing for some data formats.", 0) \
|
||||
M(UInt64, min_chunk_bytes_for_parallel_parsing, (10 * 1024 * 1024), "The minimum chunk size in bytes, which each thread will parse in parallel.", 0) \
|
||||
M(Bool, output_format_parallel_formatting, false, "Enable parallel formatting for all data formats.", 0) \
|
||||
M(Bool, output_format_parallel_formatting, false, "Enable parallel formatting for all data formats.", 1) \
|
||||
\
|
||||
M(UInt64, merge_tree_min_rows_for_concurrent_read, (20 * 8192), "If at least as many lines are read from one file, the reading can be parallelized.", 0) \
|
||||
M(UInt64, merge_tree_min_bytes_for_concurrent_read, (24 * 10 * 1024 * 1024), "If at least as many bytes are read from one file, the reading can be parallelized.", 0) \
|
||||
|
@ -149,17 +149,7 @@ InputFormatPtr FormatFactory::getInput(
|
||||
|
||||
if (!getCreators(name).input_processor_creator)
|
||||
{
|
||||
|
||||
|
||||
// const auto & input_getter = getCreators(name).input_creator;
|
||||
// if (!input_getter)
|
||||
// throw Exception("Format " + name + " is not suitable for input", ErrorCodes::FORMAT_IS_NOT_SUITABLE_FOR_INPUT);
|
||||
//
|
||||
// const Settings & settings = context.getSettingsRef();
|
||||
// FormatSettings format_settings = getInputFormatSetting(settings, context);
|
||||
//
|
||||
// return input_getter(buf, sample, max_block_size, callback ? callback : ReadCallback(), format_settings);
|
||||
throw;
|
||||
throw Exception("Format " + name + " is not suitable for input (with processors)", ErrorCodes::FORMAT_IS_NOT_SUITABLE_FOR_INPUT;;
|
||||
}
|
||||
|
||||
const Settings & settings = context.getSettingsRef();
|
||||
@ -185,8 +175,6 @@ InputFormatPtr FormatFactory::getInput(
|
||||
if (parallel_parsing)
|
||||
{
|
||||
const auto & input_getter = getCreators(name).input_processor_creator;
|
||||
if (!input_getter)
|
||||
throw Exception("Format " + name + " is not suitable for input", ErrorCodes::FORMAT_IS_NOT_SUITABLE_FOR_INPUT);
|
||||
|
||||
RowInputFormatParams row_input_format_params;
|
||||
row_input_format_params.max_block_size = max_block_size;
|
||||
@ -221,16 +209,7 @@ BlockOutputStreamPtr FormatFactory::getOutput(const String & name,
|
||||
|
||||
if (!getCreators(name).output_processor_creator)
|
||||
{
|
||||
const auto & output_getter = getCreators(name).output_creator;
|
||||
if (!output_getter)
|
||||
throw Exception("Format " + name + " is not suitable for output", ErrorCodes::FORMAT_IS_NOT_SUITABLE_FOR_OUTPUT);
|
||||
|
||||
/** Materialization is needed, because formats can use the functions `IDataType`,
|
||||
* which only work with full columns.
|
||||
*/
|
||||
return std::make_shared<MaterializingBlockOutputStream>(
|
||||
output_getter(buf, sample, std::move(callback), format_settings),
|
||||
sample);
|
||||
throw Exception("Format " + name + " is not suitable for output (with processors)", ErrorCodes::FORMAT_IS_NOT_SUITABLE_FOR_OUTPUT);
|
||||
}
|
||||
|
||||
|
||||
@ -240,8 +219,6 @@ BlockOutputStreamPtr FormatFactory::getOutput(const String & name,
|
||||
if (parallel_formatting)
|
||||
{
|
||||
const auto & output_getter = getCreators(name).output_processor_creator;
|
||||
if (!output_getter)
|
||||
throw Exception("Format " + name + " is not suitable for output", ErrorCodes::FORMAT_IS_NOT_SUITABLE_FOR_OUTPUT);
|
||||
|
||||
FormatSettings format_settings = getOutputFormatSetting(settings, context);
|
||||
|
||||
@ -256,7 +233,7 @@ BlockOutputStreamPtr FormatFactory::getOutput(const String & name,
|
||||
// if (format_settings.enable_streaming)
|
||||
// format->setAutoFlush();
|
||||
|
||||
ParallelFormattingOutputFormat::Params params{buf, sample, formatter_creator};
|
||||
ParallelFormattingOutputFormat::Params params{buf, sample, formatter_creator, settings.max_threads};
|
||||
auto format = std::make_shared<ParallelFormattingOutputFormat>(params);
|
||||
return std::make_shared<MaterializingBlockOutputStream>(std::make_shared<OutputStreamToOutputFormat>(format), sample);
|
||||
}
|
||||
|
@ -39,15 +39,12 @@ protected:
|
||||
|
||||
RowsBeforeLimitCounterPtr rows_before_limit_counter;
|
||||
|
||||
friend class ParallelFormattingOutputFormat;
|
||||
|
||||
virtual void consume(Chunk) = 0;
|
||||
virtual void consumeTotals(Chunk) {}
|
||||
virtual void consumeExtremes(Chunk) {}
|
||||
virtual void finalize() {}
|
||||
|
||||
public:
|
||||
|
||||
IOutputFormat(const Block & header_, WriteBuffer & out_);
|
||||
|
||||
Status prepare() override;
|
||||
|
@ -23,12 +23,12 @@ public:
|
||||
void prepareReadBuffer(ReadBuffer & buffer) override
|
||||
{
|
||||
/// In this format, BOM at beginning of stream cannot be confused with value, so it is safe to skip it.
|
||||
skipBOMIfExists(in);
|
||||
skipBOMIfExists(buffer);
|
||||
|
||||
skipWhitespaceIfAny(in);
|
||||
if (!in.eof() && *in.position() == '[')
|
||||
skipWhitespaceIfAny(buffer);
|
||||
if (!buffer.eof() && *buffer.position() == '[')
|
||||
{
|
||||
++in.position();
|
||||
++buffer.position();
|
||||
data_in_square_brackets = true;
|
||||
}
|
||||
}
|
||||
|
@ -16,9 +16,6 @@
|
||||
namespace DB
|
||||
{
|
||||
|
||||
const size_t min_chunk_bytes_for_parallel_formatting = 1024;
|
||||
const size_t max_threads_for_parallel_formatting = 6;
|
||||
|
||||
class ParallelFormattingOutputFormat : public IOutputFormat
|
||||
{
|
||||
public:
|
||||
@ -30,15 +27,16 @@ public:
|
||||
WriteBuffer & out;
|
||||
const Block & header;
|
||||
InternalFormatterCreator internal_formatter_creator;
|
||||
const size_t max_thread_for_parallel_formatting;
|
||||
};
|
||||
|
||||
explicit ParallelFormattingOutputFormat(Params params)
|
||||
: IOutputFormat(params.header, params.out)
|
||||
, internal_formatter_creator(params.internal_formatter_creator)
|
||||
, pool(max_threads_for_parallel_formatting)
|
||||
, pool(params.max_threads_for_parallel_formatting)
|
||||
|
||||
{
|
||||
processing_units.resize(max_threads_for_parallel_formatting + 2);
|
||||
processing_units.resize(params.max_threads_for_parallel_formatting + 2);
|
||||
|
||||
collector_thread = ThreadFromGlobalPool([&] { collectorThreadFunction(); });
|
||||
}
|
||||
|
Loading…
Reference in New Issue
Block a user