mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-25 17:12:03 +00:00
Fix clang-tidy-s
This commit is contained in:
parent
ecb11005e3
commit
e5e84419af
@ -17,6 +17,8 @@
|
|||||||
#ifndef METROHASH_METROHASH_128_H
|
#ifndef METROHASH_METROHASH_128_H
|
||||||
#define METROHASH_METROHASH_128_H
|
#define METROHASH_METROHASH_128_H
|
||||||
|
|
||||||
|
// NOLINTBEGIN(readability-avoid-const-params-in-decls)
|
||||||
|
|
||||||
#include <stdint.h>
|
#include <stdint.h>
|
||||||
|
|
||||||
class MetroHash128
|
class MetroHash128
|
||||||
@ -68,5 +70,6 @@ private:
|
|||||||
void metrohash128_1(const uint8_t * key, uint64_t len, uint32_t seed, uint8_t * out);
|
void metrohash128_1(const uint8_t * key, uint64_t len, uint32_t seed, uint8_t * out);
|
||||||
void metrohash128_2(const uint8_t * key, uint64_t len, uint32_t seed, uint8_t * out);
|
void metrohash128_2(const uint8_t * key, uint64_t len, uint32_t seed, uint8_t * out);
|
||||||
|
|
||||||
|
// NOLINTEND(readability-avoid-const-params-in-decls)
|
||||||
|
|
||||||
#endif // #ifndef METROHASH_METROHASH_128_H
|
#endif // #ifndef METROHASH_METROHASH_128_H
|
||||||
|
@ -133,20 +133,20 @@ public:
|
|||||||
/// This function also enables custom prefixes to be used.
|
/// This function also enables custom prefixes to be used.
|
||||||
void setCustomSettingsPrefixes(const Strings & prefixes);
|
void setCustomSettingsPrefixes(const Strings & prefixes);
|
||||||
void setCustomSettingsPrefixes(const String & comma_separated_prefixes);
|
void setCustomSettingsPrefixes(const String & comma_separated_prefixes);
|
||||||
bool isSettingNameAllowed(const std::string_view name) const;
|
bool isSettingNameAllowed(std::string_view name) const;
|
||||||
void checkSettingNameIsAllowed(const std::string_view name) const;
|
void checkSettingNameIsAllowed(std::string_view name) const;
|
||||||
|
|
||||||
/// Allows implicit user creation without password (by default it's allowed).
|
/// Allows implicit user creation without password (by default it's allowed).
|
||||||
/// In other words, allow 'CREATE USER' queries without 'IDENTIFIED WITH' clause.
|
/// In other words, allow 'CREATE USER' queries without 'IDENTIFIED WITH' clause.
|
||||||
void setImplicitNoPasswordAllowed(const bool allow_implicit_no_password_);
|
void setImplicitNoPasswordAllowed(bool allow_implicit_no_password_);
|
||||||
bool isImplicitNoPasswordAllowed() const;
|
bool isImplicitNoPasswordAllowed() const;
|
||||||
|
|
||||||
/// Allows users without password (by default it's allowed).
|
/// Allows users without password (by default it's allowed).
|
||||||
void setNoPasswordAllowed(const bool allow_no_password_);
|
void setNoPasswordAllowed(bool allow_no_password_);
|
||||||
bool isNoPasswordAllowed() const;
|
bool isNoPasswordAllowed() const;
|
||||||
|
|
||||||
/// Allows users with plaintext password (by default it's allowed).
|
/// Allows users with plaintext password (by default it's allowed).
|
||||||
void setPlaintextPasswordAllowed(const bool allow_plaintext_password_);
|
void setPlaintextPasswordAllowed(bool allow_plaintext_password_);
|
||||||
bool isPlaintextPasswordAllowed() const;
|
bool isPlaintextPasswordAllowed() const;
|
||||||
|
|
||||||
/// Default password type when the user does not specify it.
|
/// Default password type when the user does not specify it.
|
||||||
|
@ -616,7 +616,7 @@ UUID IAccessStorage::generateRandomID()
|
|||||||
}
|
}
|
||||||
|
|
||||||
|
|
||||||
void IAccessStorage::clearConflictsInEntitiesList(std::vector<std::pair<UUID, AccessEntityPtr>> & entities, const LoggerPtr log_)
|
void IAccessStorage::clearConflictsInEntitiesList(std::vector<std::pair<UUID, AccessEntityPtr>> & entities, LoggerPtr log_)
|
||||||
{
|
{
|
||||||
std::unordered_map<UUID, size_t> positions_by_id;
|
std::unordered_map<UUID, size_t> positions_by_id;
|
||||||
std::unordered_map<std::string_view, size_t> positions_by_type_and_name[static_cast<size_t>(AccessEntityType::MAX)];
|
std::unordered_map<std::string_view, size_t> positions_by_type_and_name[static_cast<size_t>(AccessEntityType::MAX)];
|
||||||
|
@ -228,7 +228,7 @@ protected:
|
|||||||
static UUID generateRandomID();
|
static UUID generateRandomID();
|
||||||
LoggerPtr getLogger() const;
|
LoggerPtr getLogger() const;
|
||||||
static String formatEntityTypeWithName(AccessEntityType type, const String & name) { return AccessEntityTypeInfo::get(type).formatEntityNameWithType(name); }
|
static String formatEntityTypeWithName(AccessEntityType type, const String & name) { return AccessEntityTypeInfo::get(type).formatEntityNameWithType(name); }
|
||||||
static void clearConflictsInEntitiesList(std::vector<std::pair<UUID, AccessEntityPtr>> & entities, const LoggerPtr log_);
|
static void clearConflictsInEntitiesList(std::vector<std::pair<UUID, AccessEntityPtr>> & entities, LoggerPtr log_);
|
||||||
[[noreturn]] void throwNotFound(const UUID & id) const;
|
[[noreturn]] void throwNotFound(const UUID & id) const;
|
||||||
[[noreturn]] void throwNotFound(AccessEntityType type, const String & name) const;
|
[[noreturn]] void throwNotFound(AccessEntityType type, const String & name) const;
|
||||||
[[noreturn]] static void throwBadCast(const UUID & id, AccessEntityType type, const String & name, AccessEntityType required_type);
|
[[noreturn]] static void throwBadCast(const UUID & id, AccessEntityType type, const String & name, AccessEntityType required_type);
|
||||||
|
@ -47,9 +47,7 @@ private:
|
|||||||
|
|
||||||
std::unique_ptr<MemoryChunk> prev;
|
std::unique_ptr<MemoryChunk> prev;
|
||||||
|
|
||||||
MemoryChunk()
|
MemoryChunk() = default;
|
||||||
{
|
|
||||||
}
|
|
||||||
|
|
||||||
void swap(MemoryChunk & other)
|
void swap(MemoryChunk & other)
|
||||||
{
|
{
|
||||||
|
@ -297,7 +297,7 @@ void DNSResolver::setDisableCacheFlag(bool is_disabled)
|
|||||||
impl->disable_cache = is_disabled;
|
impl->disable_cache = is_disabled;
|
||||||
}
|
}
|
||||||
|
|
||||||
void DNSResolver::setCacheMaxEntries(const UInt64 cache_max_entries)
|
void DNSResolver::setCacheMaxEntries(UInt64 cache_max_entries)
|
||||||
{
|
{
|
||||||
impl->cache_address.setMaxSizeInBytes(cache_max_entries);
|
impl->cache_address.setMaxSizeInBytes(cache_max_entries);
|
||||||
impl->cache_host.setMaxSizeInBytes(cache_max_entries);
|
impl->cache_host.setMaxSizeInBytes(cache_max_entries);
|
||||||
|
@ -56,7 +56,7 @@ public:
|
|||||||
void setDisableCacheFlag(bool is_disabled = true);
|
void setDisableCacheFlag(bool is_disabled = true);
|
||||||
|
|
||||||
/// Set a limit of entries in cache
|
/// Set a limit of entries in cache
|
||||||
void setCacheMaxEntries(const UInt64 cache_max_entries);
|
void setCacheMaxEntries(UInt64 cache_max_entries);
|
||||||
|
|
||||||
/// Drops all caches
|
/// Drops all caches
|
||||||
void dropCache();
|
void dropCache();
|
||||||
|
@ -255,7 +255,7 @@ private:
|
|||||||
|
|
||||||
static LUTIndex toLUTIndex(ExtendedDayNum d)
|
static LUTIndex toLUTIndex(ExtendedDayNum d)
|
||||||
{
|
{
|
||||||
return normalizeLUTIndex(static_cast<Int64>(d + daynum_offset_epoch));
|
return normalizeLUTIndex(static_cast<Int64>(d) + daynum_offset_epoch);
|
||||||
}
|
}
|
||||||
|
|
||||||
LUTIndex toLUTIndex(Time t) const
|
LUTIndex toLUTIndex(Time t) const
|
||||||
|
@ -41,9 +41,9 @@ public:
|
|||||||
}
|
}
|
||||||
|
|
||||||
/// There is no copy constructor because only one MultiVersion should own the same object.
|
/// There is no copy constructor because only one MultiVersion should own the same object.
|
||||||
MultiVersion(MultiVersion && src) { *this = std::move(src); }
|
MultiVersion(MultiVersion && src) { *this = std::move(src); } /// NOLINT
|
||||||
|
|
||||||
MultiVersion & operator=(MultiVersion && src)
|
MultiVersion & operator=(MultiVersion && src) /// NOLINT
|
||||||
{
|
{
|
||||||
if (this != &src)
|
if (this != &src)
|
||||||
{
|
{
|
||||||
|
@ -25,7 +25,7 @@
|
|||||||
*/
|
*/
|
||||||
template <typename T, typename U>
|
template <typename T, typename U>
|
||||||
constexpr bool memcpy_can_be_used_for_assignment = std::is_same_v<T, U>
|
constexpr bool memcpy_can_be_used_for_assignment = std::is_same_v<T, U>
|
||||||
|| (std::is_integral_v<T> && std::is_integral_v<U> && sizeof(T) == sizeof(U));
|
|| (std::is_integral_v<T> && std::is_integral_v<U> && sizeof(T) == sizeof(U)); /// NOLINT(misc-redundant-expression)
|
||||||
|
|
||||||
namespace DB
|
namespace DB
|
||||||
{
|
{
|
||||||
@ -558,7 +558,7 @@ public:
|
|||||||
}
|
}
|
||||||
|
|
||||||
template <typename... TAllocatorParams>
|
template <typename... TAllocatorParams>
|
||||||
void swap(PODArray & rhs, TAllocatorParams &&... allocator_params)
|
void swap(PODArray & rhs, TAllocatorParams &&... allocator_params) /// NOLINT(performance-noexcept-swap)
|
||||||
{
|
{
|
||||||
#ifndef NDEBUG
|
#ifndef NDEBUG
|
||||||
this->unprotect();
|
this->unprotect();
|
||||||
@ -756,7 +756,7 @@ public:
|
|||||||
};
|
};
|
||||||
|
|
||||||
template <typename T, size_t initial_bytes, typename TAllocator, size_t pad_right_, size_t pad_left_>
|
template <typename T, size_t initial_bytes, typename TAllocator, size_t pad_right_, size_t pad_left_>
|
||||||
void swap(PODArray<T, initial_bytes, TAllocator, pad_right_, pad_left_> & lhs, PODArray<T, initial_bytes, TAllocator, pad_right_, pad_left_> & rhs)
|
void swap(PODArray<T, initial_bytes, TAllocator, pad_right_, pad_left_> & lhs, PODArray<T, initial_bytes, TAllocator, pad_right_, pad_left_> & rhs) /// NOLINT
|
||||||
{
|
{
|
||||||
lhs.swap(rhs);
|
lhs.swap(rhs);
|
||||||
}
|
}
|
||||||
|
@ -149,7 +149,7 @@ public:
|
|||||||
|
|
||||||
/// Pad the remainder, which is missing up to an 8-byte word.
|
/// Pad the remainder, which is missing up to an 8-byte word.
|
||||||
current_word = 0;
|
current_word = 0;
|
||||||
switch (end - data)
|
switch (end - data) /// NOLINT(bugprone-switch-missing-default-case)
|
||||||
{
|
{
|
||||||
case 7: current_bytes[CURRENT_BYTES_IDX(6)] = data[6]; [[fallthrough]];
|
case 7: current_bytes[CURRENT_BYTES_IDX(6)] = data[6]; [[fallthrough]];
|
||||||
case 6: current_bytes[CURRENT_BYTES_IDX(5)] = data[5]; [[fallthrough]];
|
case 6: current_bytes[CURRENT_BYTES_IDX(5)] = data[5]; [[fallthrough]];
|
||||||
|
@ -16,7 +16,7 @@ class MergeTreeTransaction;
|
|||||||
/// or transaction object is not needed and not passed intentionally.
|
/// or transaction object is not needed and not passed intentionally.
|
||||||
#ifndef NO_TRANSACTION_PTR
|
#ifndef NO_TRANSACTION_PTR
|
||||||
#define NO_TRANSACTION_PTR std::shared_ptr<MergeTreeTransaction>(nullptr)
|
#define NO_TRANSACTION_PTR std::shared_ptr<MergeTreeTransaction>(nullptr)
|
||||||
#define NO_TRANSACTION_RAW static_cast<MergeTreeTransaction *>(nullptr)
|
#define NO_TRANSACTION_RAW static_cast<MergeTreeTransaction *>(nullptr) /// NOLINT(bugprone-macro-parentheses)
|
||||||
#endif
|
#endif
|
||||||
|
|
||||||
/// Commit Sequence Number
|
/// Commit Sequence Number
|
||||||
|
@ -23,7 +23,7 @@ namespace ProfileEvents
|
|||||||
namespace Coordination
|
namespace Coordination
|
||||||
{
|
{
|
||||||
|
|
||||||
void Exception::incrementErrorMetrics(const Error code_)
|
void Exception::incrementErrorMetrics(Error code_)
|
||||||
{
|
{
|
||||||
if (Coordination::isUserError(code_))
|
if (Coordination::isUserError(code_))
|
||||||
ProfileEvents::increment(ProfileEvents::ZooKeeperUserExceptions);
|
ProfileEvents::increment(ProfileEvents::ZooKeeperUserExceptions);
|
||||||
@ -33,14 +33,14 @@ void Exception::incrementErrorMetrics(const Error code_)
|
|||||||
ProfileEvents::increment(ProfileEvents::ZooKeeperOtherExceptions);
|
ProfileEvents::increment(ProfileEvents::ZooKeeperOtherExceptions);
|
||||||
}
|
}
|
||||||
|
|
||||||
Exception::Exception(const std::string & msg, const Error code_, int)
|
Exception::Exception(const std::string & msg, Error code_, int)
|
||||||
: DB::Exception(msg, DB::ErrorCodes::KEEPER_EXCEPTION)
|
: DB::Exception(msg, DB::ErrorCodes::KEEPER_EXCEPTION)
|
||||||
, code(code_)
|
, code(code_)
|
||||||
{
|
{
|
||||||
incrementErrorMetrics(code);
|
incrementErrorMetrics(code);
|
||||||
}
|
}
|
||||||
|
|
||||||
Exception::Exception(PreformattedMessage && msg, const Error code_)
|
Exception::Exception(PreformattedMessage && msg, Error code_)
|
||||||
: DB::Exception(std::move(msg), DB::ErrorCodes::KEEPER_EXCEPTION)
|
: DB::Exception(std::move(msg), DB::ErrorCodes::KEEPER_EXCEPTION)
|
||||||
, code(code_)
|
, code(code_)
|
||||||
{
|
{
|
||||||
@ -48,7 +48,7 @@ Exception::Exception(PreformattedMessage && msg, const Error code_)
|
|||||||
incrementErrorMetrics(code);
|
incrementErrorMetrics(code);
|
||||||
}
|
}
|
||||||
|
|
||||||
Exception::Exception(const Error code_)
|
Exception::Exception(Error code_)
|
||||||
: Exception(code_, "Coordination error: {}", errorMessage(code_))
|
: Exception(code_, "Coordination error: {}", errorMessage(code_))
|
||||||
{
|
{
|
||||||
}
|
}
|
||||||
|
@ -466,13 +466,13 @@ class Exception : public DB::Exception
|
|||||||
{
|
{
|
||||||
private:
|
private:
|
||||||
/// Delegate constructor, used to minimize repetition; last parameter used for overload resolution.
|
/// Delegate constructor, used to minimize repetition; last parameter used for overload resolution.
|
||||||
Exception(const std::string & msg, const Error code_, int); /// NOLINT
|
Exception(const std::string & msg, Error code_, int); /// NOLINT
|
||||||
Exception(PreformattedMessage && msg, const Error code_);
|
Exception(PreformattedMessage && msg, Error code_);
|
||||||
|
|
||||||
/// Message must be a compile-time constant
|
/// Message must be a compile-time constant
|
||||||
template <typename T>
|
template <typename T>
|
||||||
requires std::is_convertible_v<T, String>
|
requires std::is_convertible_v<T, String>
|
||||||
Exception(T && message, const Error code_) : DB::Exception(std::forward<T>(message), DB::ErrorCodes::KEEPER_EXCEPTION, /* remote_= */ false), code(code_)
|
Exception(T && message, Error code_) : DB::Exception(std::forward<T>(message), DB::ErrorCodes::KEEPER_EXCEPTION, /* remote_= */ false), code(code_)
|
||||||
{
|
{
|
||||||
incrementErrorMetrics(code);
|
incrementErrorMetrics(code);
|
||||||
}
|
}
|
||||||
@ -480,23 +480,23 @@ private:
|
|||||||
static void incrementErrorMetrics(Error code_);
|
static void incrementErrorMetrics(Error code_);
|
||||||
|
|
||||||
public:
|
public:
|
||||||
explicit Exception(const Error code_); /// NOLINT
|
explicit Exception(Error code_); /// NOLINT
|
||||||
Exception(const Exception & exc);
|
Exception(const Exception & exc);
|
||||||
|
|
||||||
template <typename... Args>
|
template <typename... Args>
|
||||||
Exception(const Error code_, FormatStringHelper<Args...> fmt, Args &&... args)
|
Exception(Error code_, FormatStringHelper<Args...> fmt, Args &&... args)
|
||||||
: DB::Exception(DB::ErrorCodes::KEEPER_EXCEPTION, std::move(fmt), std::forward<Args>(args)...)
|
: DB::Exception(DB::ErrorCodes::KEEPER_EXCEPTION, std::move(fmt), std::forward<Args>(args)...)
|
||||||
, code(code_)
|
, code(code_)
|
||||||
{
|
{
|
||||||
incrementErrorMetrics(code);
|
incrementErrorMetrics(code);
|
||||||
}
|
}
|
||||||
|
|
||||||
inline static Exception createDeprecated(const std::string & msg, const Error code_)
|
inline static Exception createDeprecated(const std::string & msg, Error code_)
|
||||||
{
|
{
|
||||||
return Exception(msg, code_, 0);
|
return Exception(msg, code_, 0);
|
||||||
}
|
}
|
||||||
|
|
||||||
inline static Exception fromPath(const Error code_, const std::string & path)
|
inline static Exception fromPath(Error code_, const std::string & path)
|
||||||
{
|
{
|
||||||
return Exception(code_, "Coordination error: {}, path {}", errorMessage(code_), path);
|
return Exception(code_, "Coordination error: {}, path {}", errorMessage(code_), path);
|
||||||
}
|
}
|
||||||
@ -504,7 +504,7 @@ public:
|
|||||||
/// Message must be a compile-time constant
|
/// Message must be a compile-time constant
|
||||||
template <typename T>
|
template <typename T>
|
||||||
requires std::is_convertible_v<T, String>
|
requires std::is_convertible_v<T, String>
|
||||||
inline static Exception fromMessage(const Error code_, T && message)
|
inline static Exception fromMessage(Error code_, T && message)
|
||||||
{
|
{
|
||||||
return Exception(std::forward<T>(message), code_);
|
return Exception(std::forward<T>(message), code_);
|
||||||
}
|
}
|
||||||
|
@ -19,14 +19,14 @@ namespace Poco { class Logger; }
|
|||||||
|
|
||||||
using LogSeriesLimiterPtr = std::shared_ptr<LogSeriesLimiter>;
|
using LogSeriesLimiterPtr = std::shared_ptr<LogSeriesLimiter>;
|
||||||
|
|
||||||
namespace
|
namespace impl
|
||||||
{
|
{
|
||||||
[[maybe_unused]] LoggerPtr getLoggerHelper(const LoggerPtr & logger) { return logger; }
|
[[maybe_unused]] inline LoggerPtr getLoggerHelper(const LoggerPtr & logger) { return logger; }
|
||||||
[[maybe_unused]] LoggerPtr getLoggerHelper(const AtomicLogger & logger) { return logger.load(); }
|
[[maybe_unused]] inline LoggerPtr getLoggerHelper(const AtomicLogger & logger) { return logger.load(); }
|
||||||
[[maybe_unused]] const ::Poco::Logger * getLoggerHelper(const ::Poco::Logger * logger) { return logger; }
|
[[maybe_unused]] inline const ::Poco::Logger * getLoggerHelper(const ::Poco::Logger * logger) { return logger; }
|
||||||
[[maybe_unused]] std::unique_ptr<LogToStrImpl> getLoggerHelper(std::unique_ptr<LogToStrImpl> && logger) { return logger; }
|
[[maybe_unused]] inline std::unique_ptr<LogToStrImpl> getLoggerHelper(std::unique_ptr<LogToStrImpl> && logger) { return logger; }
|
||||||
[[maybe_unused]] std::unique_ptr<LogFrequencyLimiterIml> getLoggerHelper(std::unique_ptr<LogFrequencyLimiterIml> && logger) { return logger; }
|
[[maybe_unused]] inline std::unique_ptr<LogFrequencyLimiterIml> getLoggerHelper(std::unique_ptr<LogFrequencyLimiterIml> && logger) { return logger; }
|
||||||
[[maybe_unused]] LogSeriesLimiterPtr getLoggerHelper(LogSeriesLimiterPtr & logger) { return logger; }
|
[[maybe_unused]] inline LogSeriesLimiterPtr getLoggerHelper(LogSeriesLimiterPtr & logger) { return logger; }
|
||||||
}
|
}
|
||||||
|
|
||||||
#define LOG_IMPL_FIRST_ARG(X, ...) X
|
#define LOG_IMPL_FIRST_ARG(X, ...) X
|
||||||
@ -65,7 +65,7 @@ namespace
|
|||||||
|
|
||||||
#define LOG_IMPL(logger, priority, PRIORITY, ...) do \
|
#define LOG_IMPL(logger, priority, PRIORITY, ...) do \
|
||||||
{ \
|
{ \
|
||||||
auto _logger = ::getLoggerHelper(logger); \
|
auto _logger = ::impl::getLoggerHelper(logger); \
|
||||||
const bool _is_clients_log = (DB::CurrentThread::getGroup() != nullptr) && \
|
const bool _is_clients_log = (DB::CurrentThread::getGroup() != nullptr) && \
|
||||||
(DB::CurrentThread::get().getClientLogsLevel() >= (priority)); \
|
(DB::CurrentThread::get().getClientLogsLevel() >= (priority)); \
|
||||||
if (!_is_clients_log && !_logger->is((PRIORITY))) \
|
if (!_is_clients_log && !_logger->is((PRIORITY))) \
|
||||||
|
@ -36,7 +36,7 @@ void insertDefaultPostgreSQLValue(IColumn & column, const IColumn & sample_colum
|
|||||||
|
|
||||||
void insertPostgreSQLValue(
|
void insertPostgreSQLValue(
|
||||||
IColumn & column, std::string_view value,
|
IColumn & column, std::string_view value,
|
||||||
const ExternalResultDescription::ValueType type, const DataTypePtr data_type,
|
ExternalResultDescription::ValueType type, DataTypePtr data_type,
|
||||||
const std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t idx)
|
const std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t idx)
|
||||||
{
|
{
|
||||||
switch (type)
|
switch (type)
|
||||||
@ -170,7 +170,7 @@ void insertPostgreSQLValue(
|
|||||||
|
|
||||||
|
|
||||||
void preparePostgreSQLArrayInfo(
|
void preparePostgreSQLArrayInfo(
|
||||||
std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t column_idx, const DataTypePtr data_type)
|
std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t column_idx, DataTypePtr data_type)
|
||||||
{
|
{
|
||||||
const auto * array_type = typeid_cast<const DataTypeArray *>(data_type.get());
|
const auto * array_type = typeid_cast<const DataTypeArray *>(data_type.get());
|
||||||
auto nested = array_type->getNestedType();
|
auto nested = array_type->getNestedType();
|
||||||
|
@ -22,11 +22,11 @@ struct PostgreSQLArrayInfo
|
|||||||
|
|
||||||
void insertPostgreSQLValue(
|
void insertPostgreSQLValue(
|
||||||
IColumn & column, std::string_view value,
|
IColumn & column, std::string_view value,
|
||||||
const ExternalResultDescription::ValueType type, const DataTypePtr data_type,
|
ExternalResultDescription::ValueType type, DataTypePtr data_type,
|
||||||
const std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t idx);
|
const std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t idx);
|
||||||
|
|
||||||
void preparePostgreSQLArrayInfo(
|
void preparePostgreSQLArrayInfo(
|
||||||
std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t column_idx, const DataTypePtr data_type);
|
std::unordered_map<size_t, PostgreSQLArrayInfo> & array_info, size_t column_idx, DataTypePtr data_type);
|
||||||
|
|
||||||
void insertDefaultPostgreSQLValue(IColumn & column, const IColumn & sample_column);
|
void insertDefaultPostgreSQLValue(IColumn & column, const IColumn & sample_column);
|
||||||
|
|
||||||
|
@ -1192,6 +1192,7 @@ class IColumn;
|
|||||||
FORMAT_FACTORY_SETTINGS(M, ALIAS) \
|
FORMAT_FACTORY_SETTINGS(M, ALIAS) \
|
||||||
OBSOLETE_FORMAT_SETTINGS(M, ALIAS) \
|
OBSOLETE_FORMAT_SETTINGS(M, ALIAS) \
|
||||||
|
|
||||||
|
/// NOLINTNEXTLINE(clang-analyzer-optin.performance.Padding)
|
||||||
DECLARE_SETTINGS_TRAITS_ALLOW_CUSTOM_SETTINGS(SettingsTraits, LIST_OF_SETTINGS)
|
DECLARE_SETTINGS_TRAITS_ALLOW_CUSTOM_SETTINGS(SettingsTraits, LIST_OF_SETTINGS)
|
||||||
|
|
||||||
|
|
||||||
@ -1236,6 +1237,7 @@ private:
|
|||||||
/*
|
/*
|
||||||
* User-specified file format settings for File and URL engines.
|
* User-specified file format settings for File and URL engines.
|
||||||
*/
|
*/
|
||||||
|
/// NOLINTNEXTLINE(clang-analyzer-optin.performance.Padding)
|
||||||
DECLARE_SETTINGS_TRAITS(FormatFactorySettingsTraits, LIST_OF_ALL_FORMAT_SETTINGS)
|
DECLARE_SETTINGS_TRAITS(FormatFactorySettingsTraits, LIST_OF_ALL_FORMAT_SETTINGS)
|
||||||
|
|
||||||
struct FormatFactorySettings : public BaseSettings<FormatFactorySettingsTraits>
|
struct FormatFactorySettings : public BaseSettings<FormatFactorySettingsTraits>
|
||||||
|
@ -423,7 +423,7 @@ MutableColumns CacheDictionary<dictionary_key_type>::aggregateColumnsInOrderOfKe
|
|||||||
const DictionaryStorageFetchRequest & request,
|
const DictionaryStorageFetchRequest & request,
|
||||||
const MutableColumns & fetched_columns,
|
const MutableColumns & fetched_columns,
|
||||||
const PaddedPODArray<KeyState> & key_index_to_state,
|
const PaddedPODArray<KeyState> & key_index_to_state,
|
||||||
IColumn::Filter * const default_mask) const
|
IColumn::Filter * default_mask) const
|
||||||
{
|
{
|
||||||
MutableColumns aggregated_columns = request.makeAttributesResultColumns();
|
MutableColumns aggregated_columns = request.makeAttributesResultColumns();
|
||||||
|
|
||||||
@ -473,7 +473,7 @@ MutableColumns CacheDictionary<dictionary_key_type>::aggregateColumns(
|
|||||||
const PaddedPODArray<KeyState> & key_index_to_fetched_columns_from_storage_result,
|
const PaddedPODArray<KeyState> & key_index_to_fetched_columns_from_storage_result,
|
||||||
const MutableColumns & fetched_columns_during_update,
|
const MutableColumns & fetched_columns_during_update,
|
||||||
const HashMap<KeyType, size_t> & found_keys_to_fetched_columns_during_update_index,
|
const HashMap<KeyType, size_t> & found_keys_to_fetched_columns_during_update_index,
|
||||||
IColumn::Filter * const default_mask) const
|
IColumn::Filter * default_mask) const
|
||||||
{
|
{
|
||||||
/**
|
/**
|
||||||
* Aggregation of columns fetched from storage and from source during update.
|
* Aggregation of columns fetched from storage and from source during update.
|
||||||
|
@ -162,7 +162,7 @@ private:
|
|||||||
const DictionaryStorageFetchRequest & request,
|
const DictionaryStorageFetchRequest & request,
|
||||||
const MutableColumns & fetched_columns,
|
const MutableColumns & fetched_columns,
|
||||||
const PaddedPODArray<KeyState> & key_index_to_state,
|
const PaddedPODArray<KeyState> & key_index_to_state,
|
||||||
IColumn::Filter * const default_mask = nullptr) const;
|
IColumn::Filter * default_mask = nullptr) const;
|
||||||
|
|
||||||
MutableColumns aggregateColumns(
|
MutableColumns aggregateColumns(
|
||||||
const PaddedPODArray<KeyType> & keys,
|
const PaddedPODArray<KeyType> & keys,
|
||||||
|
@ -14,7 +14,7 @@ class IRegionsHierarchyReader
|
|||||||
public:
|
public:
|
||||||
virtual bool readNext(RegionEntry & entry) = 0;
|
virtual bool readNext(RegionEntry & entry) = 0;
|
||||||
|
|
||||||
virtual ~IRegionsHierarchyReader() {}
|
virtual ~IRegionsHierarchyReader() = default;
|
||||||
};
|
};
|
||||||
|
|
||||||
using IRegionsHierarchyReaderPtr = std::unique_ptr<IRegionsHierarchyReader>;
|
using IRegionsHierarchyReaderPtr = std::unique_ptr<IRegionsHierarchyReader>;
|
||||||
|
@ -568,7 +568,7 @@ bool RegExpTreeDictionary::setAttributesShortCircuit(
|
|||||||
const String & data,
|
const String & data,
|
||||||
std::unordered_set<UInt64> & visited_nodes,
|
std::unordered_set<UInt64> & visited_nodes,
|
||||||
const std::unordered_map<String, const DictionaryAttribute &> & attributes,
|
const std::unordered_map<String, const DictionaryAttribute &> & attributes,
|
||||||
std::unordered_set<String> * const defaults) const
|
std::unordered_set<String> * defaults) const
|
||||||
{
|
{
|
||||||
if (visited_nodes.contains(id))
|
if (visited_nodes.contains(id))
|
||||||
return attributes_to_set.attributesFull() == attributes.size();
|
return attributes_to_set.attributesFull() == attributes.size();
|
||||||
|
@ -210,7 +210,7 @@ private:
|
|||||||
const String & data,
|
const String & data,
|
||||||
std::unordered_set<UInt64> & visited_nodes,
|
std::unordered_set<UInt64> & visited_nodes,
|
||||||
const std::unordered_map<String, const DictionaryAttribute &> & attributes,
|
const std::unordered_map<String, const DictionaryAttribute &> & attributes,
|
||||||
std::unordered_set<String> * const defaults) const;
|
std::unordered_set<String> * defaults) const;
|
||||||
|
|
||||||
struct RegexTreeNode;
|
struct RegexTreeNode;
|
||||||
using RegexTreeNodePtr = std::shared_ptr<RegexTreeNode>;
|
using RegexTreeNodePtr = std::shared_ptr<RegexTreeNode>;
|
||||||
|
@ -13,10 +13,6 @@
|
|||||||
|
|
||||||
#include <memory>
|
#include <memory>
|
||||||
|
|
||||||
#if USE_EMBEDDED_COMPILER
|
|
||||||
# include <Core/ValuesWithType.h>
|
|
||||||
#endif
|
|
||||||
|
|
||||||
/// This file contains user interface for functions.
|
/// This file contains user interface for functions.
|
||||||
|
|
||||||
namespace llvm
|
namespace llvm
|
||||||
|
@ -63,6 +63,7 @@ enum class RemoteFSReadMethod
|
|||||||
class MMappedFileCache;
|
class MMappedFileCache;
|
||||||
class PageCache;
|
class PageCache;
|
||||||
|
|
||||||
|
/// NOLINTNEXTLINE(clang-analyzer-optin.performance.Padding)
|
||||||
struct ReadSettings
|
struct ReadSettings
|
||||||
{
|
{
|
||||||
/// Method to use reading from local filesystem.
|
/// Method to use reading from local filesystem.
|
||||||
|
@ -905,7 +905,7 @@ Chunk AsynchronousInsertQueue::processEntriesWithParsing(
|
|||||||
const InsertDataPtr & data,
|
const InsertDataPtr & data,
|
||||||
const Block & header,
|
const Block & header,
|
||||||
const ContextPtr & insert_context,
|
const ContextPtr & insert_context,
|
||||||
const LoggerPtr logger,
|
LoggerPtr logger,
|
||||||
LogFunc && add_to_async_insert_log)
|
LogFunc && add_to_async_insert_log)
|
||||||
{
|
{
|
||||||
size_t total_rows = 0;
|
size_t total_rows = 0;
|
||||||
|
@ -265,7 +265,7 @@ private:
|
|||||||
const InsertDataPtr & data,
|
const InsertDataPtr & data,
|
||||||
const Block & header,
|
const Block & header,
|
||||||
const ContextPtr & insert_context,
|
const ContextPtr & insert_context,
|
||||||
const LoggerPtr logger,
|
LoggerPtr logger,
|
||||||
LogFunc && add_to_async_insert_log);
|
LogFunc && add_to_async_insert_log);
|
||||||
|
|
||||||
template <typename LogFunc>
|
template <typename LogFunc>
|
||||||
|
@ -330,7 +330,7 @@ protected:
|
|||||||
return *this;
|
return *this;
|
||||||
}
|
}
|
||||||
|
|
||||||
void swap(QueryAccessInfo & rhs)
|
void swap(QueryAccessInfo & rhs) noexcept
|
||||||
{
|
{
|
||||||
std::swap(databases, rhs.databases);
|
std::swap(databases, rhs.databases);
|
||||||
std::swap(tables, rhs.tables);
|
std::swap(tables, rhs.tables);
|
||||||
@ -680,7 +680,7 @@ public:
|
|||||||
void addSpecialScalar(const String & name, const Block & block);
|
void addSpecialScalar(const String & name, const Block & block);
|
||||||
|
|
||||||
const QueryAccessInfo & getQueryAccessInfo() const { return *getQueryAccessInfoPtr(); }
|
const QueryAccessInfo & getQueryAccessInfo() const { return *getQueryAccessInfoPtr(); }
|
||||||
const QueryAccessInfoPtr getQueryAccessInfoPtr() const { return query_access_info; }
|
QueryAccessInfoPtr getQueryAccessInfoPtr() const { return query_access_info; }
|
||||||
void setQueryAccessInfo(QueryAccessInfoPtr other) { query_access_info = other; }
|
void setQueryAccessInfo(QueryAccessInfoPtr other) { query_access_info = other; }
|
||||||
|
|
||||||
void addQueryAccessInfo(
|
void addQueryAccessInfo(
|
||||||
|
@ -23,7 +23,7 @@ struct ExternalLoadableLifetime
|
|||||||
UInt64 max_sec = 0;
|
UInt64 max_sec = 0;
|
||||||
|
|
||||||
ExternalLoadableLifetime(const Poco::Util::AbstractConfiguration & config, const std::string & config_prefix);
|
ExternalLoadableLifetime(const Poco::Util::AbstractConfiguration & config, const std::string & config_prefix);
|
||||||
ExternalLoadableLifetime() {}
|
ExternalLoadableLifetime() = default;
|
||||||
};
|
};
|
||||||
|
|
||||||
/// Get delay before trying to load again after error.
|
/// Get delay before trying to load again after error.
|
||||||
|
@ -318,7 +318,7 @@ public:
|
|||||||
~ProcessListEntry();
|
~ProcessListEntry();
|
||||||
|
|
||||||
QueryStatusPtr getQueryStatus() { return *it; }
|
QueryStatusPtr getQueryStatus() { return *it; }
|
||||||
const QueryStatusPtr getQueryStatus() const { return *it; }
|
QueryStatusPtr getQueryStatus() const { return *it; }
|
||||||
};
|
};
|
||||||
|
|
||||||
|
|
||||||
|
@ -59,7 +59,7 @@ public:
|
|||||||
|
|
||||||
Chunk clone() const;
|
Chunk clone() const;
|
||||||
|
|
||||||
void swap(Chunk & other)
|
void swap(Chunk & other) noexcept
|
||||||
{
|
{
|
||||||
columns.swap(other.columns);
|
columns.swap(other.columns);
|
||||||
chunk_info.swap(other.chunk_info);
|
chunk_info.swap(other.chunk_info);
|
||||||
|
@ -126,7 +126,7 @@ static void postprocessChunk(Chunk & chunk, const AggregatingSortedAlgorithm::Co
|
|||||||
|
|
||||||
|
|
||||||
AggregatingSortedAlgorithm::SimpleAggregateDescription::SimpleAggregateDescription(
|
AggregatingSortedAlgorithm::SimpleAggregateDescription::SimpleAggregateDescription(
|
||||||
AggregateFunctionPtr function_, const size_t column_number_,
|
AggregateFunctionPtr function_, size_t column_number_,
|
||||||
DataTypePtr nested_type_, DataTypePtr real_type_)
|
DataTypePtr nested_type_, DataTypePtr real_type_)
|
||||||
: function(std::move(function_)), column_number(column_number_)
|
: function(std::move(function_)), column_number(column_number_)
|
||||||
, nested_type(std::move(nested_type_)), real_type(std::move(real_type_))
|
, nested_type(std::move(nested_type_)), real_type(std::move(real_type_))
|
||||||
|
@ -110,7 +110,7 @@ protected:
|
|||||||
return result;
|
return result;
|
||||||
}
|
}
|
||||||
|
|
||||||
uintptr_t ALWAYS_INLINE swap(std::atomic<Data *> & value, std::uintptr_t flags, std::uintptr_t mask)
|
uintptr_t ALWAYS_INLINE swap(std::atomic<Data *> & value, std::uintptr_t flags, std::uintptr_t mask) /// NOLINT
|
||||||
{
|
{
|
||||||
Data * expected = nullptr;
|
Data * expected = nullptr;
|
||||||
Data * desired = getPtr(flags | getUInt(data));
|
Data * desired = getPtr(flags | getUInt(data));
|
||||||
|
@ -6,8 +6,8 @@ namespace DB
|
|||||||
TTLUpdateInfoAlgorithm::TTLUpdateInfoAlgorithm(
|
TTLUpdateInfoAlgorithm::TTLUpdateInfoAlgorithm(
|
||||||
const TTLExpressions & ttl_expressions_,
|
const TTLExpressions & ttl_expressions_,
|
||||||
const TTLDescription & description_,
|
const TTLDescription & description_,
|
||||||
const TTLUpdateField ttl_update_field_,
|
TTLUpdateField ttl_update_field_,
|
||||||
const String ttl_update_key_,
|
String ttl_update_key_,
|
||||||
const TTLInfo & old_ttl_info_,
|
const TTLInfo & old_ttl_info_,
|
||||||
time_t current_time_,
|
time_t current_time_,
|
||||||
bool force_)
|
bool force_)
|
||||||
|
@ -22,8 +22,8 @@ public:
|
|||||||
TTLUpdateInfoAlgorithm(
|
TTLUpdateInfoAlgorithm(
|
||||||
const TTLExpressions & ttl_expressions_,
|
const TTLExpressions & ttl_expressions_,
|
||||||
const TTLDescription & description_,
|
const TTLDescription & description_,
|
||||||
const TTLUpdateField ttl_update_field_,
|
TTLUpdateField ttl_update_field_,
|
||||||
const String ttl_update_key_,
|
String ttl_update_key_,
|
||||||
const TTLInfo & old_ttl_info_,
|
const TTLInfo & old_ttl_info_,
|
||||||
time_t current_time_, bool force_
|
time_t current_time_, bool force_
|
||||||
);
|
);
|
||||||
|
@ -72,8 +72,8 @@ struct StorageInMemoryMetadata
|
|||||||
StorageInMemoryMetadata(const StorageInMemoryMetadata & other);
|
StorageInMemoryMetadata(const StorageInMemoryMetadata & other);
|
||||||
StorageInMemoryMetadata & operator=(const StorageInMemoryMetadata & other);
|
StorageInMemoryMetadata & operator=(const StorageInMemoryMetadata & other);
|
||||||
|
|
||||||
StorageInMemoryMetadata(StorageInMemoryMetadata && other) = default;
|
StorageInMemoryMetadata(StorageInMemoryMetadata && other) = default; /// NOLINT
|
||||||
StorageInMemoryMetadata & operator=(StorageInMemoryMetadata && other) = default;
|
StorageInMemoryMetadata & operator=(StorageInMemoryMetadata && other) = default; /// NOLINT
|
||||||
|
|
||||||
/// NOTE: Thread unsafe part. You should not modify same StorageInMemoryMetadata
|
/// NOTE: Thread unsafe part. You should not modify same StorageInMemoryMetadata
|
||||||
/// structure from different threads. It should be used as MultiVersion
|
/// structure from different threads. It should be used as MultiVersion
|
||||||
|
Loading…
Reference in New Issue
Block a user