Merge pull request #37382 from ClickHouse/wc++98-compat-extra-semi

Enable -Wc++98-compat-extra-semi
This commit is contained in:
Robert Schulze 2022-05-22 09:40:45 +02:00 committed by GitHub
commit 19d53c14fa
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
16 changed files with 20 additions and 20 deletions

View File

@ -345,7 +345,7 @@ HedgedConnections::ReplicaLocation HedgedConnections::getReadyReplicaLocation(As
else
throw Exception("Unknown event from epoll", ErrorCodes::LOGICAL_ERROR);
}
};
}
bool HedgedConnections::resumePacketReceiver(const HedgedConnections::ReplicaLocation & location)
{

View File

@ -32,7 +32,7 @@ void assertRange(
ASSERT_EQ(range.left, expected_range.left);
ASSERT_EQ(range.right, expected_range.right);
ASSERT_EQ(file_segment->state(), expected_state);
};
}
void printRanges(const auto & segments)
{

View File

@ -22,7 +22,7 @@ extern const int CANNOT_COMPILE_REGEXP;
extern const int NO_ELEMENTS_IN_CONFIG;
extern const int INVALID_CONFIG_PARAMETER;
}
};
}
TEST(Common, SensitiveDataMasker)

View File

@ -790,7 +790,7 @@ std::vector<CodecTestSequence> generatePyramidOfSequences(const size_t sequences
}
return sequences;
};
}
// helper macro to produce human-friendly sequence name from generator
#define G(generator) generator, #generator

View File

@ -22,7 +22,7 @@ static auto typeFromString(const std::string & str)
{
auto & data_type_factory = DataTypeFactory::instance();
return data_type_factory.get(str);
};
}
static auto typesFromString(const std::string & str)
{
@ -33,7 +33,7 @@ static auto typesFromString(const std::string & str)
data_types.push_back(typeFromString(data_type));
return data_types;
};
}
struct TypesTestCase
{

View File

@ -23,7 +23,7 @@ namespace ErrorCodes
extern const int INCORRECT_DISK_INDEX;
extern const int UNKNOWN_FORMAT;
extern const int FILE_ALREADY_EXISTS;
extern const int PATH_ACCESS_DENIED;;
extern const int PATH_ACCESS_DENIED;
extern const int FILE_DOESNT_EXIST;
extern const int BAD_FILE_TYPE;
}

View File

@ -9,19 +9,19 @@ using FunctionSubtractNanoseconds = FunctionDateOrDateTimeAddInterval<SubtractNa
void registerFunctionSubtractNanoseconds(FunctionFactory & factory)
{
factory.registerFunction<FunctionSubtractNanoseconds>();
};
}
using FunctionSubtractMicroseconds = FunctionDateOrDateTimeAddInterval<SubtractMicrosecondsImpl>;
void registerFunctionSubtractMicroseconds(FunctionFactory & factory)
{
factory.registerFunction<FunctionSubtractMicroseconds>();
};
}
using FunctionSubtractMilliseconds = FunctionDateOrDateTimeAddInterval<SubtractMillisecondsImpl>;
void registerFunctionSubtractMilliseconds(FunctionFactory & factory)
{
factory.registerFunction<FunctionSubtractMilliseconds>();
};
}
}

View File

@ -61,7 +61,7 @@ void fillColumnArray(const Strings & data, IColumn & column)
}
auto & offsets = array.getOffsets();
offsets.push_back(offsets.back() + size);
};
}
}

View File

@ -14,7 +14,7 @@ namespace ErrorCodes
extern const int UNKNOWN_SETTING;
}
IMPLEMENT_SETTINGS_TRAITS(ExecutableSettingsTraits, LIST_OF_EXECUTABLE_SETTINGS);
IMPLEMENT_SETTINGS_TRAITS(ExecutableSettingsTraits, LIST_OF_EXECUTABLE_SETTINGS)
void ExecutableSettings::loadFromQuery(ASTStorage & storage_def)
{

View File

@ -19,7 +19,7 @@ namespace ErrorCodes
{
extern const int INCORRECT_QUERY;
extern const int LOGICAL_ERROR;
};
}
IndexDescription::IndexDescription(const IndexDescription & other)
: definition_ast(other.definition_ast ? other.definition_ast->clone() : nullptr)

View File

@ -84,4 +84,4 @@ ColumnsDescription MeiliSearchColumnDescriptionFetcher::fetchColumnsDescription(
return ColumnsDescription(list);
}
};
}

View File

@ -21,4 +21,4 @@ private:
MeiliSearchConnection connection;
};
};
}

View File

@ -660,7 +660,7 @@ MergeTreeIndexConditionPtr MergeTreeIndexFullText::createIndexCondition(
const SelectQueryInfo & query, ContextPtr context) const
{
return std::make_shared<MergeTreeConditionFullText>(query, context, index.sample_block, params, token_extractor.get());
};
}
bool MergeTreeIndexFullText::mayBenefitFromIndexForIn(const ASTPtr & node) const
{

View File

@ -484,7 +484,7 @@ MergeTreeIndexConditionPtr MergeTreeIndexSet::createIndexCondition(
const SelectQueryInfo & query, ContextPtr context) const
{
return std::make_shared<MergeTreeIndexConditionSet>(index.name, index.sample_block, max_rows, query, context);
};
}
bool MergeTreeIndexSet::mayBenefitFromIndexForIn(const ASTPtr &) const
{

View File

@ -123,14 +123,14 @@ static const ASTFunction * getAsTuple(const ASTPtr & node)
if (const auto * func = node->as<ASTFunction>(); func && func->name == "tuple")
return func;
return {};
};
}
static bool getAsTupleLiteral(const ASTPtr & node, Tuple & tuple)
{
if (const auto * value_tuple = node->as<ASTLiteral>())
return value_tuple && value_tuple->value.tryGet<Tuple>(tuple);
return false;
};
}
bool MergeTreeWhereOptimizer::tryAnalyzeTuple(Conditions & res, const ASTFunction * func, bool is_final) const
{

View File

@ -29,7 +29,7 @@ namespace ErrorCodes
extern const int ILLEGAL_PROJECTION;
extern const int NOT_IMPLEMENTED;
extern const int LOGICAL_ERROR;
};
}
bool ProjectionDescription::isPrimaryKeyColumnPossiblyWrappedInFunctions(const ASTPtr & node) const
{