2021-07-26 16:48:25 +00:00
|
|
|
#include <Storages/MergeTree/MergeTreeSink.h>
|
2020-05-20 12:02:02 +00:00
|
|
|
#include <Storages/MergeTree/MergeTreeDataPartInMemory.h>
|
2017-06-25 00:01:10 +00:00
|
|
|
#include <Storages/StorageMergeTree.h>
|
|
|
|
#include <Interpreters/PartLog.h>
|
|
|
|
|
|
|
|
|
|
|
|
namespace DB
|
|
|
|
{
|
|
|
|
|
2022-02-01 10:36:51 +00:00
|
|
|
MergeTreeSink::~MergeTreeSink() = default;
|
|
|
|
|
|
|
|
MergeTreeSink::MergeTreeSink(
|
|
|
|
StorageMergeTree & storage_,
|
|
|
|
StorageMetadataPtr metadata_snapshot_,
|
|
|
|
size_t max_parts_per_block_,
|
|
|
|
ContextPtr context_)
|
|
|
|
: SinkToStorage(metadata_snapshot_->getSampleBlock())
|
|
|
|
, storage(storage_)
|
|
|
|
, metadata_snapshot(metadata_snapshot_)
|
|
|
|
, max_parts_per_block(max_parts_per_block_)
|
|
|
|
, context(context_)
|
|
|
|
{
|
|
|
|
}
|
|
|
|
|
2021-07-23 19:33:59 +00:00
|
|
|
void MergeTreeSink::onStart()
|
2017-06-25 00:01:10 +00:00
|
|
|
{
|
2020-11-29 15:08:02 +00:00
|
|
|
/// Only check "too many parts" before write,
|
|
|
|
/// because interrupting long-running INSERT query in the middle is not convenient for users.
|
2019-05-03 02:00:57 +00:00
|
|
|
storage.delayInsertOrThrowIfNeeded();
|
2020-11-29 15:08:02 +00:00
|
|
|
}
|
|
|
|
|
2022-02-01 10:36:51 +00:00
|
|
|
void MergeTreeSink::onFinish()
|
|
|
|
{
|
|
|
|
finishDelayedChunk();
|
|
|
|
}
|
|
|
|
|
|
|
|
struct MergeTreeSink::DelayedChunk
|
|
|
|
{
|
|
|
|
struct Partition
|
|
|
|
{
|
|
|
|
MergeTreeDataWriter::TemporaryPart temp_part;
|
|
|
|
UInt64 elapsed_ns;
|
|
|
|
String block_dedup_token;
|
|
|
|
};
|
|
|
|
|
|
|
|
std::vector<Partition> partitions;
|
|
|
|
};
|
|
|
|
|
2017-06-25 00:01:10 +00:00
|
|
|
|
2021-07-23 19:33:59 +00:00
|
|
|
void MergeTreeSink::consume(Chunk chunk)
|
2020-11-29 15:08:02 +00:00
|
|
|
{
|
2021-09-03 17:29:36 +00:00
|
|
|
auto block = getHeader().cloneWithColumns(chunk.detachColumns());
|
2021-07-23 19:33:59 +00:00
|
|
|
|
2021-05-21 16:14:01 +00:00
|
|
|
auto part_blocks = storage.writer.splitBlockIntoParts(block, max_parts_per_block, metadata_snapshot, context);
|
2022-02-01 10:36:51 +00:00
|
|
|
std::vector<MergeTreeSink::DelayedChunk::Partition> partitions;
|
2017-06-25 00:01:10 +00:00
|
|
|
for (auto & current_block : part_blocks)
|
|
|
|
{
|
|
|
|
Stopwatch watch;
|
2022-02-01 10:36:51 +00:00
|
|
|
String block_dedup_token;
|
|
|
|
|
|
|
|
auto temp_part = storage.writer.writeTempPart(current_block, metadata_snapshot, context);
|
2022-01-14 19:53:55 +00:00
|
|
|
|
2022-02-01 10:36:51 +00:00
|
|
|
UInt64 elapsed_ns = watch.elapsed();
|
2021-02-12 14:02:04 +00:00
|
|
|
|
|
|
|
/// If optimize_on_insert setting is true, current_block could become empty after merge
|
|
|
|
/// and we didn't create part.
|
2022-02-01 10:36:51 +00:00
|
|
|
if (!temp_part.part)
|
2021-02-12 14:02:04 +00:00
|
|
|
continue;
|
|
|
|
|
2022-01-03 23:04:56 +00:00
|
|
|
if (storage.getDeduplicationLog())
|
|
|
|
{
|
|
|
|
const String & dedup_token = context->getSettingsRef().insert_deduplication_token;
|
|
|
|
if (!dedup_token.empty())
|
|
|
|
{
|
|
|
|
/// multiple blocks can be inserted within the same insert query
|
|
|
|
/// an ordinal number is added to dedup token to generate a distinctive block id for each block
|
|
|
|
block_dedup_token = fmt::format("{}_{}", dedup_token, chunk_dedup_seqnum);
|
|
|
|
++chunk_dedup_seqnum;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-02-01 10:36:51 +00:00
|
|
|
partitions.emplace_back(MergeTreeSink::DelayedChunk::Partition
|
|
|
|
{
|
|
|
|
.temp_part = std::move(temp_part),
|
|
|
|
.elapsed_ns = elapsed_ns,
|
|
|
|
.block_dedup_token = std::move(block_dedup_token)
|
|
|
|
});
|
|
|
|
}
|
|
|
|
|
|
|
|
finishDelayedChunk();
|
|
|
|
delayed_chunk = std::make_unique<MergeTreeSink::DelayedChunk>();
|
|
|
|
delayed_chunk->partitions = std::move(partitions);
|
|
|
|
}
|
|
|
|
|
|
|
|
void MergeTreeSink::finishDelayedChunk()
|
|
|
|
{
|
|
|
|
if (!delayed_chunk)
|
|
|
|
return;
|
|
|
|
|
|
|
|
for (auto & partition : delayed_chunk->partitions)
|
|
|
|
{
|
|
|
|
partition.temp_part.finalize();
|
|
|
|
|
|
|
|
auto & part = partition.temp_part.part;
|
|
|
|
|
2021-04-02 17:54:24 +00:00
|
|
|
/// Part can be deduplicated, so increment counters and add to part log only if it's really added
|
2022-02-01 10:36:51 +00:00
|
|
|
if (storage.renameTempPartAndAdd(part, &storage.increment, nullptr, storage.getDeduplicationLog(), partition.block_dedup_token))
|
2021-04-02 11:46:42 +00:00
|
|
|
{
|
2022-02-01 10:36:51 +00:00
|
|
|
PartLog::addNewPart(storage.getContext(), part, partition.elapsed_ns);
|
2017-06-25 00:01:10 +00:00
|
|
|
|
2021-04-02 16:45:18 +00:00
|
|
|
/// Initiate async merge - it will be done if it's good time for merge and if there are space in 'background_pool'.
|
2021-09-08 00:21:21 +00:00
|
|
|
storage.background_operations_assignee.trigger();
|
2021-04-02 16:45:18 +00:00
|
|
|
}
|
2017-06-25 00:01:10 +00:00
|
|
|
}
|
2022-02-01 10:36:51 +00:00
|
|
|
|
|
|
|
delayed_chunk.reset();
|
2017-06-25 00:01:10 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
}
|