mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-23 16:12:01 +00:00
Fix all style warnings
This commit is contained in:
parent
777dfc774d
commit
47c649f6c3
@ -19,7 +19,9 @@
|
||||
namespace DB
|
||||
{
|
||||
|
||||
namespace {
|
||||
namespace
|
||||
{
|
||||
|
||||
ASTPtr defaultRequiredExpressions(Block & block, const NamesAndTypesList & required_columns, const ColumnDefaults & column_defaults)
|
||||
{
|
||||
ASTPtr default_expr_list = std::make_shared<ASTExpressionList>();
|
||||
|
@ -1105,7 +1105,8 @@ MergeTreeData::MutableDataPartPtr MergeTreeDataMergerMutator::mutatePartToTempor
|
||||
for (const NameAndTypePair & column : source_part->columns)
|
||||
{
|
||||
column.type->enumerateStreams(
|
||||
[&](const IDataType::SubstreamPath & substream_path) {
|
||||
[&](const IDataType::SubstreamPath & substream_path)
|
||||
{
|
||||
++stream_counts[IDataType::getFileNameForStream(column.name, substream_path)];
|
||||
},
|
||||
{});
|
||||
@ -1123,7 +1124,8 @@ MergeTreeData::MutableDataPartPtr MergeTreeDataMergerMutator::mutatePartToTempor
|
||||
}
|
||||
else if (command.type == MutationCommand::Type::DROP_COLUMN)
|
||||
{
|
||||
IDataType::StreamCallback callback = [&](const IDataType::SubstreamPath & substream_path) {
|
||||
IDataType::StreamCallback callback = [&](const IDataType::SubstreamPath & substream_path)
|
||||
{
|
||||
String stream_name = IDataType::getFileNameForStream(command.column_name, substream_path);
|
||||
/// Delete files if they are no longer shared with another column.
|
||||
if (--stream_counts[stream_name] == 0)
|
||||
|
@ -459,7 +459,7 @@ void MergeTreeReader::performRequiredConversions(Columns & res_columns)
|
||||
res_columns[pos] = std::move(copy_block.getByName(name_and_type->name).column);
|
||||
}
|
||||
}
|
||||
catch(Exception & e)
|
||||
catch (Exception & e)
|
||||
{
|
||||
/// Better diagnostics.
|
||||
e.addMessage("(while reading from part " + path + ")");
|
||||
|
@ -564,7 +564,9 @@ void ReplicatedMergeTreeQueue::pullLogsToQueue(zkutil::ZooKeeperPtr zookeeper, C
|
||||
}
|
||||
|
||||
|
||||
namespace {
|
||||
namespace
|
||||
{
|
||||
|
||||
Names getPartNamesToMutate(
|
||||
const ReplicatedMergeTreeMutationEntry & mutation, const ActiveDataPartSet & parts)
|
||||
{
|
||||
|
@ -3271,8 +3271,8 @@ void StorageReplicatedMergeTree::alter(
|
||||
std::optional<ReplicatedMergeTreeLogEntryData> alter_entry;
|
||||
std::optional<String> mutation_znode;
|
||||
|
||||
while (true) {
|
||||
|
||||
while (true)
|
||||
{
|
||||
/// Clear nodes from previous iteration
|
||||
alter_entry.emplace();
|
||||
mutation_znode.reset();
|
||||
|
@ -177,9 +177,7 @@ public:
|
||||
/// Checks ability to use granularity
|
||||
bool canUseAdaptiveGranularity() const override;
|
||||
|
||||
int getMetadataVersion() const {
|
||||
return metadata_version;
|
||||
}
|
||||
int getMetadataVersion() const { return metadata_version; }
|
||||
|
||||
private:
|
||||
|
||||
|
@ -102,6 +102,7 @@ done
|
||||
|
||||
for i in `seq $REPLICAS`; do
|
||||
$CLICKHOUSE_CLIENT --query "SYSTEM SYNC REPLICA concurrent_alter_detach_$i"
|
||||
$CLICKHOUSE_CLIENT --query "SELECT SUM(toUInt64(value1)) > $INITIAL_SUM FROM concurrent_alter_detach_$i"
|
||||
$CLICKHOUSE_CLIENT --query "SELECT COUNT() FROM system.mutations WHERE is_done=0" # all mutations have to be done
|
||||
$CLICKHOUSE_CLIENT --query "DROP TABLE IF EXISTS concurrent_alter_detach_$i"
|
||||
done
|
||||
|
Loading…
Reference in New Issue
Block a user