Remove excessive empty lines

This commit is contained in:
Alexey Milovidov 2020-03-03 05:43:59 +03:00
parent 7f9449062f
commit 5b06842723
64 changed files with 0 additions and 74 deletions

View File

@ -80,7 +80,6 @@ dumpImpl(Out & out, T && x)
}
/// Tuple, pair
template <size_t N, typename Out, typename T>
Out & dumpTupleImpl(Out & out, T && x)

View File

@ -39,7 +39,6 @@ typedef __attribute__((__aligned__(1))) uint32_t uint32_unaligned_t;
typedef __attribute__((__aligned__(1))) uint64_t uint64_unaligned_t;
//---------------------------------------------------------------------
// fast copy for different sizes
//---------------------------------------------------------------------
@ -694,4 +693,3 @@ static INLINE void* memcpy_fast(void *destination, const void *source, size_t si
#endif

View File

@ -131,7 +131,6 @@ struct TaskStateWithOwner
};
struct ShardPriority
{
UInt8 is_remote = 1;

View File

@ -60,5 +60,4 @@ void StopConditionsSet::report(UInt64 value, StopConditionsSet::StopCondition &
}
}

View File

@ -72,7 +72,6 @@ bool IAccessStorage::exists(const UUID & id) const
}
AccessEntityPtr IAccessStorage::tryReadBase(const UUID & id) const
{
try

View File

@ -5,7 +5,6 @@
#include <chrono>
namespace DB
{
/** Quota for resources consumption for specific interval.

View File

@ -86,7 +86,6 @@ struct MovingAvgData
};
template <typename T, typename Tlimit_num_elems, typename Data>
class MovingImpl final
: public IAggregateFunctionDataHelper<Data, MovingImpl<T, Tlimit_num_elems, Data>>

View File

@ -287,5 +287,4 @@ private:
};
}

View File

@ -6,7 +6,6 @@
#include <map>
namespace Poco
{
namespace Util

View File

@ -71,7 +71,6 @@ static void logMemoryUsage(Int64 amount)
}
void MemoryTracker::alloc(Int64 size)
{
if (blocker.isCancelled())

View File

@ -109,7 +109,6 @@ struct RadixSortIdentityTransform
};
template <typename TElement>
struct RadixSortUIntTraits
{

View File

@ -109,7 +109,6 @@ struct UInt128TrivialHash
};
/** Used for aggregation, for putting a large number of constant-length keys in a hash table.
*/
struct UInt256

View File

@ -88,7 +88,6 @@ using namespace DB;
struct ZooKeeperRequest;
/** Usage scenario: look at the documentation for IKeeper class.
*/
class ZooKeeper : public IKeeper

View File

@ -200,4 +200,3 @@ TEST(zkutil, multi_create_sequential)
}

View File

@ -10,7 +10,6 @@
#endif
unsigned getNumberOfPhysicalCPUCores()
{
#if USE_CPUID

View File

@ -50,7 +50,6 @@ static bool parseNumber(const String & description, size_t l, size_t r, size_t &
}
/* Parse a string that generates shards and replicas. Separator - one of two characters | or ,
* depending on whether shards or replicas are generated.
* For example:

View File

@ -7,7 +7,6 @@
#include <Common/HashTable/HashSet.h>
int main(int, char **)
{
{

View File

@ -22,7 +22,6 @@ using Key = UInt64;
using Value = UInt64;
/// Various hash functions to test
namespace Hashes
@ -336,7 +335,6 @@ static void NO_INLINE testForEachMapAndHash(const Key * data, size_t size)
}
int main(int argc, char ** argv)
{
if (argc < 2)

View File

@ -244,7 +244,6 @@ void aggregate5(Map & local_map, MapSmallLocks & global_map, Source::const_itera
}*/
int main(int argc, char ** argv)
{
size_t n = atoi(argv[1]);

View File

@ -283,7 +283,6 @@ struct Merger
};
int main(int argc, char ** argv)
{
size_t n = atoi(argv[1]);

View File

@ -6,7 +6,6 @@
#include <Common/HashTable/SmallTable.h>
int main(int, char **)
{
{

View File

@ -358,7 +358,6 @@ void Block::setColumns(const Columns & columns)
}
Block Block::cloneWithColumns(MutableColumns && columns) const
{
Block res;

View File

@ -12,7 +12,6 @@
#include <Core/ColumnsWithTypeAndName.h>
namespace DB
{

View File

@ -391,7 +391,6 @@ void SettingEnum<EnumType, Tag>::set(const Field & x)
}
String SettingURI::toString() const
{
return value.toString();

View File

@ -15,7 +15,6 @@ struct TypePair
};
template <typename T, bool _int, bool _float, bool _decimal, bool _datetime, typename F>
bool callOnBasicType(TypeIndex number, F && f)
{

View File

@ -25,7 +25,6 @@ VersionedCollapsingSortedBlockInputStream::VersionedCollapsingSortedBlockInputSt
}
inline ALWAYS_INLINE static void writeRowSourcePart(WriteBuffer & buffer, RowSourcePart row_source)
{
if constexpr (sizeof(RowSourcePart) == 1)

View File

@ -66,7 +66,6 @@ DataTypeTuple::DataTypeTuple(const DataTypes & elems_, const Strings & names_)
}
std::string DataTypeTuple::doGetName() const
{
size_t size = elems.size();

View File

@ -42,7 +42,6 @@ std::string DataTypeDecimal<T>::doGetName() const
}
template <typename T>
bool DataTypeDecimal<T>::equals(const IDataType & rhs) const
{

View File

@ -27,7 +27,6 @@ namespace ErrorCodes
}
DatabaseLazy::DatabaseLazy(const String & name_, const String & metadata_path_, time_t expiration_time_, const Context & context_)
: DatabaseOnDisk(name_, metadata_path_, "DatabaseLazy (" + name_ + ")")
, expiration_time(expiration_time_)

View File

@ -25,7 +25,6 @@
#include <Poco/DirectoryIterator.h>
namespace DB
{

View File

@ -19,7 +19,6 @@
#include <Poco/DirectoryIterator.h>
namespace DB
{

View File

@ -553,7 +553,6 @@ protected:
};
class ProtobufReader::ConverterFromString : public ConverterBaseImpl
{
public:
@ -864,7 +863,6 @@ PROTOBUF_READER_CREATE_CONVERTER_SPECIALIZATION_FOR_NUMBERS(google::protobuf::Fi
#undef PROTOBUF_READER_CREATE_CONVERTER_SPECIALIZATION_FOR_NUMBERS
class ProtobufReader::ConverterFromBool : public ConverterBaseImpl
{
public:

View File

@ -158,7 +158,6 @@ struct FixedStringOperationImpl
};
template <typename A, typename B, typename Op, typename ResultType = typename Op::ResultType>
struct BinaryOperationImpl : BinaryOperationImplBase<A, B, Op, ResultType>
{

View File

@ -18,7 +18,6 @@
#endif
/** Logical functions AND, OR, XOR and NOT support three-valued (or ternary) logic
* https://en.wikibooks.org/wiki/Structured_Query_Language/NULLs_and_the_Three_Valued_Logic
*

View File

@ -162,7 +162,6 @@ inline ALWAYS_INLINE void writeSlice(const NumericValueSlice<T> & slice, Generic
}
template <typename SourceA, typename SourceB, typename Sink>
void NO_INLINE concat(SourceA && src_a, SourceB && src_b, Sink && sink)
{

View File

@ -124,5 +124,3 @@ void registerFunctionCaseWithExpression(FunctionFactory & factory)
}

View File

@ -54,4 +54,3 @@ void registerFunctionGenerateUUIDv4(FunctionFactory & factory)
}

View File

@ -242,4 +242,3 @@ void registerFunctionMultiIf(FunctionFactory & factory)
}

View File

@ -152,4 +152,3 @@ void registerFunctionsReinterpretStringAs(FunctionFactory & factory)
}

View File

@ -18,4 +18,3 @@ void registerFunctionTimeSlot(FunctionFactory & factory)
}

View File

@ -464,7 +464,6 @@ void writeAnyQuotedString(const char * begin, const char * end, WriteBuffer & bu
}
template <char quote_character>
void writeAnyQuotedString(const String & s, WriteBuffer & buf)
{
@ -1020,7 +1019,6 @@ void writeText(const std::vector<T> & x, WriteBuffer & buf)
}
/// Serialize exception (so that it can be transferred over the network)
void writeException(const Exception & e, WriteBuffer & buf, bool with_stack_trace);

View File

@ -61,5 +61,4 @@ using BloomFilterPtr = std::shared_ptr<BloomFilter>;
bool operator== (const BloomFilter & a, const BloomFilter & b);
}

View File

@ -29,4 +29,3 @@ using InternalTextLogsQueuePtr = std::shared_ptr<InternalTextLogsQueue>;
}

View File

@ -109,7 +109,6 @@ static QueryDescriptors extractQueriesExceptMeAndCheckAccess(const Block & proce
}
class SyncKillQueryInputStream : public IBlockInputStream
{
public:

View File

@ -56,4 +56,3 @@ class QueryThreadLog : public SystemLog<QueryThreadLogElement>
}

View File

@ -178,7 +178,6 @@ inline bool operator==(StringRef_Compare8_1_byUInt64 lhs, StringRef_Compare8_1_b
}
inline bool compare_byMemcmp(const char * p1, const char * p2)
{
return 0 == memcmp(p1, p2, 16);
@ -576,7 +575,6 @@ inline bool operator==(StringRef_CompareAlmostAlwaysTrue lhs, StringRef_CompareA
}
using Value = UInt64;

View File

@ -4,7 +4,6 @@
#include <re2/re2.h>
namespace DB
{
namespace ErrorCodes

View File

@ -32,7 +32,6 @@ void ASTDictionaryRange::formatImpl(const FormatSettings & settings,
}
ASTPtr ASTDictionaryLifetime::clone() const
{
auto res = std::make_shared<ASTDictionaryLifetime>(*this);

View File

@ -35,6 +35,4 @@ String ASTSampleRatio::toString(Rational ratio)
}
}

View File

@ -74,7 +74,6 @@ const char * ParserTupleElementExpression::operators[] =
};
bool ParserList::parseImpl(Pos & pos, ASTPtr & node, Expected & expected)
{
bool first = true;

View File

@ -273,7 +273,6 @@ TEST(ParserDictionaryDDL, NestedSource)
}
TEST(ParserDictionaryDDL, Formatting)
{
String input = " CREATE DICTIONARY test.dict5"

View File

@ -78,4 +78,3 @@ ForkProcessor::Status ForkProcessor::prepare()
}

View File

@ -70,7 +70,6 @@ void CSVRowOutputFormat::writeBeforeExtremes()
}
void registerOutputFormatProcessorCSV(FormatFactory & factory)
{
for (bool with_names : {false, true})

View File

@ -208,7 +208,6 @@ private:
};
/// Expression template is a sequence of tokens and data types of literals.
/// E.g. template of "position('some string', 'other string') != 0" is
/// ["position", "(", DataTypeString, ",", DataTypeString, ")", "!=", DataTypeUInt64]
@ -288,7 +287,6 @@ size_t ConstantExpressionTemplate::TemplateStructure::getTemplateHash(const ASTP
}
ConstantExpressionTemplate::TemplateStructurePtr
ConstantExpressionTemplate::Cache::getFromCacheOrConstruct(const DataTypePtr & result_column_type,
bool null_as_default,

View File

@ -51,5 +51,4 @@ private:
};
}

View File

@ -10,7 +10,6 @@
#include <google/protobuf/descriptor.h>
namespace DB
{
namespace ErrorCodes

View File

@ -4,7 +4,6 @@
#include <Formats/FormatFactory.h>
namespace DB
{

View File

@ -298,6 +298,4 @@ private:
};
}

View File

@ -37,7 +37,6 @@
#include <mutex>
namespace CurrentMetrics
{
extern const Metric DistributedSend;

View File

@ -32,7 +32,6 @@ public:
}
bool supportsIndexForIn() const override { return true; }
bool mayBenefitFromIndexForIn(const ASTPtr & left_in_operand, const Context & query_context) const override

View File

@ -2623,7 +2623,6 @@ String StorageReplicatedMergeTree::findReplicaHavingCoveringPart(
}
/** If a quorum is tracked for a part, update information about it in ZK.
*/
void StorageReplicatedMergeTree::updateQuorum(const String & part_name)

View File

@ -79,7 +79,6 @@ void SetOrJoinBlockOutputStream::writeSuffix()
}
BlockOutputStreamPtr StorageSetOrJoinBase::write(const ASTPtr & /*query*/, const Context & /*context*/)
{
UInt64 id = ++increment;
@ -106,7 +105,6 @@ StorageSetOrJoinBase::StorageSetOrJoinBase(
}
StorageSet::StorageSet(
const String & relative_path_,
const StorageID & table_id_,

View File

@ -91,7 +91,6 @@ ASTPtr StorageView::getRuntimeViewQuery(const ASTSelectQuery & outer_query, cons
}
ASTPtr StorageView::getRuntimeViewQuery(ASTSelectQuery * outer_query, const Context & context, bool normalize)
{
auto runtime_view_query = inner_query->clone();

View File

@ -17,7 +17,6 @@ namespace DB
{
NamesAndTypesList StorageSystemReplicationQueue::getNamesAndTypes()
{
return {