mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-21 15:12:02 +00:00
Fix something
This commit is contained in:
parent
4afd5f60fe
commit
4217d029c0
@ -2731,8 +2731,7 @@ void Server::createInterserverServers(
|
||||
|
||||
void Server::stopServers(
|
||||
std::vector<ProtocolServerAdapter> & servers,
|
||||
const ServerType & server_type
|
||||
) const
|
||||
const ServerType & server_type) const
|
||||
{
|
||||
LoggerRawPtr log = &logger();
|
||||
|
||||
|
@ -129,8 +129,7 @@ private:
|
||||
|
||||
void stopServers(
|
||||
std::vector<ProtocolServerAdapter> & servers,
|
||||
const ServerType & server_type
|
||||
) const;
|
||||
const ServerType & server_type) const;
|
||||
};
|
||||
|
||||
}
|
||||
|
@ -6,7 +6,6 @@
|
||||
#include <Interpreters/executeQuery.h>
|
||||
#include <Parsers/IAST_fwd.h>
|
||||
#include <QueryPipeline/BlockIO.h>
|
||||
#include <Storages/IStorage.h>
|
||||
#include <Storages/IStorage_fwd.h>
|
||||
#include <base/types.h>
|
||||
#include <Common/AsyncLoader.h>
|
||||
|
@ -8,7 +8,6 @@
|
||||
namespace DB
|
||||
{
|
||||
|
||||
|
||||
/// Alter conversions which should be applied on-fly for part.
|
||||
/// Built from of the most recent mutation commands for part.
|
||||
/// Now only ALTER RENAME COLUMN is applied.
|
||||
|
@ -118,11 +118,11 @@ UInt64 MergeTreeDataMergerMutator::getMaxSourcePartSizeForMutation() const
|
||||
occupied >= data_settings->max_number_of_mutations_for_replica)
|
||||
return 0;
|
||||
|
||||
/// DataPart can be store only at one disk. Get maximum reservable free space at all disks.
|
||||
/// A DataPart can be stored only at a single disk. Get the maximum reservable free space at all disks.
|
||||
UInt64 disk_space = data.getStoragePolicy()->getMaxUnreservedFreeSpace();
|
||||
auto max_tasks_count = data.getContext()->getMergeMutateExecutor()->getMaxTasksCount();
|
||||
|
||||
/// Allow mutations only if there are enough threads, leave free threads for merges else
|
||||
/// Allow mutations only if there are enough threads, otherwise, leave free threads for merges.
|
||||
if (occupied <= 1
|
||||
|| max_tasks_count - occupied >= data_settings->number_of_free_entries_in_pool_to_execute_mutation)
|
||||
return static_cast<UInt64>(disk_space / DISK_USAGE_COEFFICIENT_TO_RESERVE);
|
||||
|
@ -11,22 +11,17 @@
|
||||
#include <Interpreters/ClusterProxy/SelectStreamFactory.h>
|
||||
#include <Interpreters/ClusterProxy/executeQuery.h>
|
||||
#include <Interpreters/Context.h>
|
||||
#include <Interpreters/InterpreterSelectQueryAnalyzer.h>
|
||||
#include <Interpreters/MutationsInterpreter.h>
|
||||
#include <Interpreters/PartLog.h>
|
||||
#include <Interpreters/TransactionLog.h>
|
||||
#include <Parsers/ASTCheckQuery.h>
|
||||
#include <Parsers/ASTFunction.h>
|
||||
#include <Parsers/ASTLiteral.h>
|
||||
#include <Parsers/ASTPartition.h>
|
||||
#include <Parsers/ASTSetQuery.h>
|
||||
#include <Parsers/formatAST.h>
|
||||
#include <Parsers/queryToString.h>
|
||||
#include <Planner/Utils.h>
|
||||
#include <Processors/QueryPlan/BuildQueryPipelineSettings.h>
|
||||
#include <Processors/QueryPlan/Optimizations/QueryPlanOptimizationSettings.h>
|
||||
#include <Processors/QueryPlan/QueryPlan.h>
|
||||
#include <QueryPipeline/Pipe.h>
|
||||
#include <Storages/AlterCommands.h>
|
||||
#include <Storages/MergeTree/ActiveDataPartSet.h>
|
||||
#include <Storages/MergeTree/IMergeTreeDataPart.h>
|
||||
@ -35,19 +30,14 @@
|
||||
#include <Storages/MergeTree/MergeTreeData.h>
|
||||
#include <Storages/MergeTree/MergeTreeSettings.h>
|
||||
#include <Storages/MergeTree/MergeTreeSink.h>
|
||||
#include <Storages/MergeTree/PartitionPruner.h>
|
||||
#include <Storages/MergeTree/checkDataPart.h>
|
||||
#include <Storages/PartitionCommands.h>
|
||||
#include <Storages/buildQueryTreeForShard.h>
|
||||
#include <base/sort.h>
|
||||
#include <fmt/core.h>
|
||||
#include <Poco/Timestamp.h>
|
||||
#include <Common/Exception.h>
|
||||
#include <Common/MemoryTracker.h>
|
||||
#include <Common/ProfileEventsScope.h>
|
||||
#include <Common/ThreadPool.h>
|
||||
#include <Common/escapeForFileName.h>
|
||||
#include <Common/typeid_cast.h>
|
||||
|
||||
|
||||
namespace DB
|
||||
@ -1197,7 +1187,6 @@ bool StorageMergeTree::merge(
|
||||
task->setCurrentTransaction(MergeTreeTransactionHolder{}, MergeTreeTransactionPtr{txn});
|
||||
|
||||
executeHere(task);
|
||||
|
||||
return true;
|
||||
}
|
||||
|
||||
@ -1493,7 +1482,6 @@ bool StorageMergeTree::scheduleDataProcessingJob(BackgroundJobsAssignee & assign
|
||||
scheduled = true;
|
||||
}
|
||||
|
||||
|
||||
return scheduled;
|
||||
}
|
||||
|
||||
@ -1600,9 +1588,7 @@ bool StorageMergeTree::optimize(
|
||||
if (!partition && final)
|
||||
{
|
||||
if (cleanup && this->merging_params.mode != MergingParams::Mode::Replacing)
|
||||
{
|
||||
throw Exception(ErrorCodes::CANNOT_ASSIGN_OPTIMIZE, "Cannot OPTIMIZE with CLEANUP table: only ReplacingMergeTree can be CLEANUP");
|
||||
}
|
||||
|
||||
if (cleanup && !getSettings()->allow_experimental_replacing_merge_with_cleanup)
|
||||
throw Exception(ErrorCodes::SUPPORT_IS_DISABLED, "Experimental merges with CLEANUP are not allowed");
|
||||
@ -1616,15 +1602,15 @@ bool StorageMergeTree::optimize(
|
||||
for (const String & partition_id : partition_ids)
|
||||
{
|
||||
if (!merge(
|
||||
true,
|
||||
partition_id,
|
||||
true,
|
||||
deduplicate,
|
||||
deduplicate_by_columns,
|
||||
cleanup,
|
||||
txn,
|
||||
disable_reason,
|
||||
local_context->getSettingsRef().optimize_skip_merged_partitions))
|
||||
true,
|
||||
partition_id,
|
||||
true,
|
||||
deduplicate,
|
||||
deduplicate_by_columns,
|
||||
cleanup,
|
||||
txn,
|
||||
disable_reason,
|
||||
local_context->getSettingsRef().optimize_skip_merged_partitions))
|
||||
{
|
||||
constexpr auto message = "Cannot OPTIMIZE table: {}";
|
||||
if (disable_reason.text.empty())
|
||||
@ -1644,15 +1630,15 @@ bool StorageMergeTree::optimize(
|
||||
partition_id = getPartitionIDFromQuery(partition, local_context);
|
||||
|
||||
if (!merge(
|
||||
true,
|
||||
partition_id,
|
||||
final,
|
||||
deduplicate,
|
||||
deduplicate_by_columns,
|
||||
cleanup,
|
||||
txn,
|
||||
disable_reason,
|
||||
local_context->getSettingsRef().optimize_skip_merged_partitions))
|
||||
true,
|
||||
partition_id,
|
||||
final,
|
||||
deduplicate,
|
||||
deduplicate_by_columns,
|
||||
cleanup,
|
||||
txn,
|
||||
disable_reason,
|
||||
local_context->getSettingsRef().optimize_skip_merged_partitions))
|
||||
{
|
||||
constexpr auto message = "Cannot OPTIMIZE table: {}";
|
||||
if (disable_reason.text.empty())
|
||||
|
@ -211,7 +211,6 @@ private:
|
||||
bool optimize_skip_merged_partitions = false,
|
||||
SelectPartsDecision * select_decision_out = nullptr);
|
||||
|
||||
|
||||
MergeMutateSelectedEntryPtr selectPartsToMutate(
|
||||
const StorageMetadataPtr & metadata_snapshot, PreformattedMessage & disable_reason,
|
||||
TableLockHolder & table_lock_holder, std::unique_lock<std::mutex> & currently_processing_in_background_mutex_lock);
|
||||
@ -310,6 +309,7 @@ private:
|
||||
};
|
||||
|
||||
protected:
|
||||
/// Collect mutations that have to be applied on the fly: currently they are only RENAME COLUMN.
|
||||
MutationCommands getAlterMutationCommandsForPart(const DataPartPtr & part) const override;
|
||||
};
|
||||
|
||||
|
Loading…
Reference in New Issue
Block a user