mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-23 16:12:01 +00:00
Normalize ya.make files, fix "Arcadia" build
This commit is contained in:
parent
18b21511a9
commit
6f690b7c0d
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -24,20 +25,21 @@ SRCS(
|
||||
LDAPClient.cpp
|
||||
MemoryAccessStorage.cpp
|
||||
MultipleAccessStorage.cpp
|
||||
Quota.cpp
|
||||
QuotaCache.cpp
|
||||
Quota.cpp
|
||||
QuotaUsage.cpp
|
||||
Role.cpp
|
||||
RoleCache.cpp
|
||||
Role.cpp
|
||||
RolesOrUsersSet.cpp
|
||||
RowPolicy.cpp
|
||||
RowPolicyCache.cpp
|
||||
RowPolicy.cpp
|
||||
SettingsConstraints.cpp
|
||||
SettingsProfile.cpp
|
||||
SettingsProfileElement.cpp
|
||||
SettingsProfilesCache.cpp
|
||||
User.cpp
|
||||
UsersConfigAccessStorage.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
11
src/Access/ya.make.in
Normal file
11
src/Access/ya.make.in
Normal file
@ -0,0 +1,11 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -42,14 +43,15 @@ SRCS(
|
||||
AggregateFunctionSumMap.cpp
|
||||
AggregateFunctionTimeSeriesGroupSum.cpp
|
||||
AggregateFunctionTopK.cpp
|
||||
AggregateFunctionUniq.cpp
|
||||
AggregateFunctionUniqCombined.cpp
|
||||
AggregateFunctionUniq.cpp
|
||||
AggregateFunctionUniqUpTo.cpp
|
||||
AggregateFunctionWindowFunnel.cpp
|
||||
parseAggregateFunctionParameters.cpp
|
||||
registerAggregateFunctions.cpp
|
||||
UniqCombinedBiasData.cpp
|
||||
UniqVariadicHash.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
11
src/AggregateFunctions/ya.make.in
Normal file
11
src/AggregateFunctions/ya.make.in
Normal file
@ -0,0 +1,11 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | grep -v -F GroupBitmap | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -10,6 +11,7 @@ SRCS(
|
||||
ConnectionPoolWithFailover.cpp
|
||||
MultiplexedConnections.cpp
|
||||
TimeoutSetter.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
12
src/Client/ya.make.in
Normal file
12
src/Client/ya.make.in
Normal file
@ -0,0 +1,12 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/poco/NetSSL_OpenSSL
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL(
|
||||
@ -29,6 +30,7 @@ SRCS(
|
||||
FilterDescription.cpp
|
||||
getLeastSuperColumn.cpp
|
||||
IColumn.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL (
|
||||
@ -25,13 +26,13 @@ SRCS(
|
||||
AlignedBuffer.cpp
|
||||
Allocator.cpp
|
||||
checkStackSize.cpp
|
||||
clearPasswordFromCommandLine.cpp
|
||||
ClickHouseRevision.cpp
|
||||
Config/AbstractConfigurationComparison.cpp
|
||||
Config/ConfigProcessor.cpp
|
||||
Config/configReadClient.cpp
|
||||
Config/ConfigReloader.cpp
|
||||
createHardLink.cpp
|
||||
clearPasswordFromCommandLine.cpp
|
||||
CurrentMetrics.cpp
|
||||
CurrentThread.cpp
|
||||
DNSResolver.cpp
|
||||
@ -47,6 +48,7 @@ SRCS(
|
||||
formatIPv6.cpp
|
||||
formatReadable.cpp
|
||||
getExecutablePath.cpp
|
||||
getMemoryUsage.cpp
|
||||
getMultipleKeysFromConfig.cpp
|
||||
getNumberOfPhysicalCPUCores.cpp
|
||||
hasLinuxCapability.cpp
|
||||
@ -59,6 +61,7 @@ SRCS(
|
||||
MemoryStatisticsOS.cpp
|
||||
MemoryTracker.cpp
|
||||
new_delete.cpp
|
||||
OpenSSLHelpers.cpp
|
||||
OptimizedRegularExpression.cpp
|
||||
parseAddress.cpp
|
||||
parseGlobs.cpp
|
||||
@ -87,10 +90,10 @@ SRCS(
|
||||
SymbolIndex.cpp
|
||||
TaskStatsInfoGetter.cpp
|
||||
TerminalSize.cpp
|
||||
thread_local_rng.cpp
|
||||
ThreadFuzzer.cpp
|
||||
ThreadProfileEvents.cpp
|
||||
thread_local_rng.cpp
|
||||
ThreadPool.cpp
|
||||
ThreadProfileEvents.cpp
|
||||
ThreadStatus.cpp
|
||||
TraceCollector.cpp
|
||||
UTF8Helpers.cpp
|
||||
@ -102,6 +105,7 @@ SRCS(
|
||||
ZooKeeper/ZooKeeperHolder.cpp
|
||||
ZooKeeper/ZooKeeperImpl.cpp
|
||||
ZooKeeper/ZooKeeperNodeCache.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
27
src/Common/ya.make.in
Normal file
27
src/Common/ya.make.in
Normal file
@ -0,0 +1,27 @@
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL (
|
||||
GLOBAL clickhouse/src
|
||||
contrib/libs/libcpuid
|
||||
contrib/libs/libunwind/include
|
||||
GLOBAL contrib/restricted/ryu
|
||||
)
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/base/common
|
||||
clickhouse/base/pcg-random
|
||||
clickhouse/base/widechar_width
|
||||
contrib/libs/libcpuid/libcpuid
|
||||
contrib/libs/openssl
|
||||
contrib/libs/poco/NetSSL_OpenSSL
|
||||
contrib/libs/re2
|
||||
contrib/restricted/ryu
|
||||
)
|
||||
|
||||
INCLUDE(${ARCADIA_ROOT}/clickhouse/cmake/yandex/ya.make.versions.inc)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL(
|
||||
@ -13,8 +14,8 @@ PEERDIR(
|
||||
|
||||
SRCS(
|
||||
CachedCompressedReadBuffer.cpp
|
||||
CompressedReadBuffer.cpp
|
||||
CompressedReadBufferBase.cpp
|
||||
CompressedReadBuffer.cpp
|
||||
CompressedReadBufferFromFile.cpp
|
||||
CompressedWriteBuffer.cpp
|
||||
CompressionCodecDelta.cpp
|
||||
@ -28,6 +29,7 @@ SRCS(
|
||||
CompressionFactory.cpp
|
||||
ICompressionCodec.cpp
|
||||
LZ4_decompress_faster.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
18
src/Compression/ya.make.in
Normal file
18
src/Compression/ya.make.in
Normal file
@ -0,0 +1,18 @@
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL(
|
||||
contrib/libs/lz4
|
||||
contrib/libs/zstd
|
||||
)
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/lz4
|
||||
contrib/libs/zstd
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -17,12 +18,13 @@ SRCS(
|
||||
Field.cpp
|
||||
iostream_debug_helpers.cpp
|
||||
MySQLProtocol.cpp
|
||||
PostgreSQLProtocol.cpp
|
||||
NamesAndTypes.cpp
|
||||
PostgreSQLProtocol.cpp
|
||||
Settings.cpp
|
||||
SettingsEnums.cpp
|
||||
SettingsFields.cpp
|
||||
SortDescription.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
13
src/Core/ya.make.in
Normal file
13
src/Core/ya.make.in
Normal file
@ -0,0 +1,13 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/sparsehash
|
||||
contrib/restricted/boost/libs
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -32,6 +33,7 @@ SRCS(
|
||||
materializeBlock.cpp
|
||||
MaterializingBlockInputStream.cpp
|
||||
MergingSortedBlockInputStream.cpp
|
||||
MongoDBBlockInputStream.cpp
|
||||
narrowBlockInputStreams.cpp
|
||||
NativeBlockInputStream.cpp
|
||||
NativeBlockOutputStream.cpp
|
||||
@ -45,7 +47,7 @@ SRCS(
|
||||
SquashingBlockOutputStream.cpp
|
||||
SquashingTransform.cpp
|
||||
TTLBlockInputStream.cpp
|
||||
MongoDBBlockInputStream.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
14
src/DataStreams/ya.make.in
Normal file
14
src/DataStreams/ya.make.in
Normal file
@ -0,0 +1,14 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/poco/MongoDB
|
||||
)
|
||||
|
||||
NO_COMPILER_WARNINGS()
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -15,6 +16,7 @@ SRCS(
|
||||
DatabaseOrdinary.cpp
|
||||
DatabasesCommon.cpp
|
||||
DatabaseWithDictionaries.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
11
src/Databases/ya.make.in
Normal file
11
src/Databases/ya.make.in
Normal file
@ -0,0 +1,11 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -17,6 +18,7 @@ SRCS(
|
||||
StoragePolicy.cpp
|
||||
VolumeJBOD.cpp
|
||||
VolumeRAID1.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
11
src/Disks/ya.make.in
Normal file
11
src/Disks/ya.make.in
Normal file
@ -0,0 +1,11 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | grep -v -F S3 | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -21,6 +22,7 @@ SRCS(
|
||||
ProtobufSchemas.cpp
|
||||
ProtobufWriter.cpp
|
||||
verbosePrintString.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
13
src/Formats/ya.make.in
Normal file
13
src/Formats/ya.make.in
Normal file
@ -0,0 +1,13 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/protobuf
|
||||
contrib/libs/protoc
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -8,8 +9,8 @@ PEERDIR(
|
||||
)
|
||||
|
||||
SRCS(
|
||||
AIO.cpp
|
||||
AIOContextPool.cpp
|
||||
AIO.cpp
|
||||
BrotliReadBuffer.cpp
|
||||
BrotliWriteBuffer.cpp
|
||||
CascadeWriteBuffer.cpp
|
||||
@ -30,8 +31,8 @@ SRCS(
|
||||
PeekableReadBuffer.cpp
|
||||
Progress.cpp
|
||||
ReadBufferAIO.cpp
|
||||
ReadBufferFromFile.cpp
|
||||
ReadBufferFromFileBase.cpp
|
||||
ReadBufferFromFile.cpp
|
||||
ReadBufferFromFileDescriptor.cpp
|
||||
ReadBufferFromIStream.cpp
|
||||
ReadBufferFromMemory.cpp
|
||||
@ -42,8 +43,8 @@ SRCS(
|
||||
SeekAvoidingReadBuffer.cpp
|
||||
UseSSL.cpp
|
||||
WriteBufferAIO.cpp
|
||||
WriteBufferFromFile.cpp
|
||||
WriteBufferFromFileBase.cpp
|
||||
WriteBufferFromFile.cpp
|
||||
WriteBufferFromFileDescriptor.cpp
|
||||
WriteBufferFromFileDescriptorDiscardOnFailure.cpp
|
||||
WriteBufferFromHTTP.cpp
|
||||
@ -55,6 +56,7 @@ SRCS(
|
||||
WriteHelpers.cpp
|
||||
ZlibDeflatingWriteBuffer.cpp
|
||||
ZlibInflatingReadBuffer.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
14
src/IO/ya.make.in
Normal file
14
src/IO/ya.make.in
Normal file
@ -0,0 +1,14 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/brotli/dec
|
||||
contrib/libs/brotli/enc
|
||||
contrib/libs/poco/NetSSL_OpenSSL
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | grep -v -P 'S3|HDFS' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL(
|
||||
@ -21,8 +22,8 @@ SRCS(
|
||||
AggregateDescription.cpp
|
||||
Aggregator.cpp
|
||||
ArithmeticOperationsInAgrFuncOptimize.cpp
|
||||
ArithmeticOperationsInAgrFuncOptimize.h
|
||||
ArrayJoinAction.cpp
|
||||
AsynchronousMetricLog.cpp
|
||||
AsynchronousMetrics.cpp
|
||||
BloomFilter.cpp
|
||||
castColumn.cpp
|
||||
@ -34,6 +35,7 @@ SRCS(
|
||||
CollectJoinOnKeysVisitor.cpp
|
||||
Context.cpp
|
||||
convertFieldToType.cpp
|
||||
CrashLog.cpp
|
||||
createBlockSelector.cpp
|
||||
CrossToInnerJoinVisitor.cpp
|
||||
DatabaseAndTableWithAlias.cpp
|
||||
@ -60,7 +62,6 @@ SRCS(
|
||||
HashJoin.cpp
|
||||
IdentifierSemantic.cpp
|
||||
IExternalLoadable.cpp
|
||||
RemoveInjectiveFunctionsVisitor.cpp
|
||||
InJoinSubqueriesPreprocessor.cpp
|
||||
inplaceBlockConversions.cpp
|
||||
InternalTextLogsQueue.cpp
|
||||
@ -87,8 +88,8 @@ SRCS(
|
||||
InterpreterSelectWithUnionQuery.cpp
|
||||
InterpreterSetQuery.cpp
|
||||
InterpreterSetRoleQuery.cpp
|
||||
InterpreterShowAccessQuery.cpp
|
||||
InterpreterShowAccessEntitiesQuery.cpp
|
||||
InterpreterShowAccessQuery.cpp
|
||||
InterpreterShowCreateAccessEntityQuery.cpp
|
||||
InterpreterShowCreateQuery.cpp
|
||||
InterpreterShowGrantsQuery.cpp
|
||||
@ -108,7 +109,6 @@ SRCS(
|
||||
MarkTableIdentifiersVisitor.cpp
|
||||
MergeJoin.cpp
|
||||
MetricLog.cpp
|
||||
AsynchronousMetricLog.cpp
|
||||
MutationsInterpreter.cpp
|
||||
NullableUtils.cpp
|
||||
OptimizeIfChains.cpp
|
||||
@ -122,6 +122,7 @@ SRCS(
|
||||
QueryLog.cpp
|
||||
QueryNormalizer.cpp
|
||||
QueryThreadLog.cpp
|
||||
RemoveInjectiveFunctionsVisitor.cpp
|
||||
RenameColumnVisitor.cpp
|
||||
ReplaceQueryParameterVisitor.cpp
|
||||
RequiredSourceColumnsData.cpp
|
||||
@ -143,6 +144,7 @@ SRCS(
|
||||
TranslateQualifiedNamesVisitor.cpp
|
||||
TreeOptimizer.cpp
|
||||
TreeRewriter.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
20
src/Interpreters/ya.make.in
Normal file
20
src/Interpreters/ya.make.in
Normal file
@ -0,0 +1,20 @@
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL(
|
||||
contrib/libs/libdivide
|
||||
contrib/libs/pdqsort
|
||||
)
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Core
|
||||
contrib/libs/libdivide
|
||||
contrib/libs/pdqsort
|
||||
)
|
||||
|
||||
NO_COMPILER_WARNINGS()
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | grep -v -F JIT | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -16,8 +17,8 @@ SRCS(
|
||||
ASTCreateRowPolicyQuery.cpp
|
||||
ASTCreateSettingsProfileQuery.cpp
|
||||
ASTCreateUserQuery.cpp
|
||||
ASTDictionary.cpp
|
||||
ASTDictionaryAttributeDeclaration.cpp
|
||||
ASTDictionary.cpp
|
||||
ASTDropAccessEntityQuery.cpp
|
||||
ASTDropQuery.cpp
|
||||
ASTExpressionList.cpp
|
||||
@ -78,10 +79,10 @@ SRCS(
|
||||
ParserCreateRowPolicyQuery.cpp
|
||||
ParserCreateSettingsProfileQuery.cpp
|
||||
ParserCreateUserQuery.cpp
|
||||
ParserDescribeTableQuery.cpp
|
||||
ParserDataType.cpp
|
||||
ParserDictionary.cpp
|
||||
ParserDescribeTableQuery.cpp
|
||||
ParserDictionaryAttributeDeclaration.cpp
|
||||
ParserDictionary.cpp
|
||||
ParserDropAccessEntityQuery.cpp
|
||||
ParserDropQuery.cpp
|
||||
ParserExplainQuery.cpp
|
||||
@ -115,8 +116,9 @@ SRCS(
|
||||
ParserWatchQuery.cpp
|
||||
parseUserName.cpp
|
||||
queryToString.cpp
|
||||
TokenIterator.cpp
|
||||
QueryWithOutputSettingsPushDownVisitor.cpp
|
||||
TokenIterator.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
11
src/Parsers/ya.make.in
Normal file
11
src/Parsers/ya.make.in
Normal file
@ -0,0 +1,11 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -69,52 +70,59 @@ SRCS(
|
||||
ISink.cpp
|
||||
ISource.cpp
|
||||
LimitTransform.cpp
|
||||
Merges/AggregatingSortedTransform.h
|
||||
Merges/Algorithms/AggregatingSortedAlgorithm.cpp
|
||||
Merges/Algorithms/AggregatingSortedAlgorithm.h
|
||||
Merges/Algorithms/CollapsingSortedAlgorithm.cpp
|
||||
Merges/Algorithms/CollapsingSortedAlgorithm.h
|
||||
Merges/Algorithms/FixedSizeDequeWithGaps.h
|
||||
Merges/Algorithms/Graphite.h
|
||||
Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp
|
||||
Merges/Algorithms/GraphiteRollupSortedAlgorithm.h
|
||||
Merges/Algorithms/IMergingAlgorithm.h
|
||||
Merges/Algorithms/IMergingAlgorithmWithDelayedChunk.cpp
|
||||
Merges/Algorithms/IMergingAlgorithmWithDelayedChunk.h
|
||||
Merges/Algorithms/IMergingAlgorithmWithSharedChunks.cpp
|
||||
Merges/Algorithms/IMergingAlgorithmWithSharedChunks.h
|
||||
Merges/Algorithms/MergedData.h
|
||||
Merges/Algorithms/MergingSortedAlgorithm.cpp
|
||||
Merges/Algorithms/MergingSortedAlgorithm.h
|
||||
Merges/Algorithms/ReplacingSortedAlgorithm.cpp
|
||||
Merges/Algorithms/ReplacingSortedAlgorithm.h
|
||||
Merges/Algorithms/RowRef.h
|
||||
Merges/Algorithms/SummingSortedAlgorithm.cpp
|
||||
Merges/Algorithms/SummingSortedAlgorithm.h
|
||||
Merges/Algorithms/VersionedCollapsingAlgorithm.cpp
|
||||
Merges/Algorithms/VersionedCollapsingAlgorithm.h
|
||||
Merges/CollapsingSortedTransform.h
|
||||
Merges/GraphiteRollupSortedTransform.h
|
||||
Merges/IMergingTransform.cpp
|
||||
Merges/IMergingTransform.h
|
||||
Merges/MergingSortedTransform.cpp
|
||||
Merges/MergingSortedTransform.h
|
||||
Merges/ReplacingSortedTransform.h
|
||||
Merges/SummingSortedTransform.h
|
||||
Merges/VersionedCollapsingTransform.h
|
||||
OffsetTransform.cpp
|
||||
Pipe.cpp
|
||||
Port.cpp
|
||||
printPipeline.cpp
|
||||
QueryPipeline.cpp
|
||||
QueryPlan/AddingDelayedSourceStep.cpp
|
||||
QueryPlan/AggregatingStep.cpp
|
||||
QueryPlan/ConvertingStep.cpp
|
||||
QueryPlan/CreatingSetsStep.cpp
|
||||
QueryPlan/CubeStep.cpp
|
||||
QueryPlan/DistinctStep.cpp
|
||||
QueryPlan/ExpressionStep.cpp
|
||||
QueryPlan/ExtremesStep.cpp
|
||||
QueryPlan/FillingStep.cpp
|
||||
QueryPlan/FilterStep.cpp
|
||||
QueryPlan/FinishSortingStep.cpp
|
||||
QueryPlan/IQueryPlanStep.cpp
|
||||
QueryPlan/ISourceStep.cpp
|
||||
QueryPlan/ITransformingStep.cpp
|
||||
QueryPlan/LimitByStep.cpp
|
||||
QueryPlan/LimitStep.cpp
|
||||
QueryPlan/MergeSortingStep.cpp
|
||||
QueryPlan/MergingAggregatedStep.cpp
|
||||
QueryPlan/MergingSortedStep.cpp
|
||||
QueryPlan/OffsetStep.cpp
|
||||
QueryPlan/PartialSortingStep.cpp
|
||||
QueryPlan/QueryPlan.cpp
|
||||
QueryPlan/ReadFromPreparedSource.cpp
|
||||
QueryPlan/ReadFromStorageStep.cpp
|
||||
QueryPlan/ReadNothingStep.cpp
|
||||
QueryPlan/RollupStep.cpp
|
||||
QueryPlan/TotalsHavingStep.cpp
|
||||
QueryPlan/UnionStep.cpp
|
||||
ResizeProcessor.cpp
|
||||
Sources/DelayedSource.cpp
|
||||
Sources/RemoteSource.cpp
|
||||
Sources/SinkToOutputStream.cpp
|
||||
Sources/SourceFromInputStream.cpp
|
||||
Sources/SourceWithProgress.cpp
|
||||
Sources/RemoteSource.cpp
|
||||
Transforms/AddingMissedTransform.cpp
|
||||
Transforms/AddingSelectorTransform.cpp
|
||||
Transforms/AggregatingInOrderTransform.cpp
|
||||
Transforms/AggregatingTransform.cpp
|
||||
Transforms/ConvertingTransform.cpp
|
||||
Transforms/CopyTransform.cpp
|
||||
@ -138,35 +146,7 @@ SRCS(
|
||||
Transforms/RollupTransform.cpp
|
||||
Transforms/SortingTransform.cpp
|
||||
Transforms/TotalsHavingTransform.cpp
|
||||
Transforms/AggregatingInOrderTransform.cpp
|
||||
QueryPlan/AddingDelayedSourceStep.cpp
|
||||
QueryPlan/AggregatingStep.cpp
|
||||
QueryPlan/ConvertingStep.cpp
|
||||
QueryPlan/CreatingSetsStep.cpp
|
||||
QueryPlan/CubeStep.cpp
|
||||
QueryPlan/DistinctStep.cpp
|
||||
QueryPlan/ExpressionStep.cpp
|
||||
QueryPlan/ExtremesStep.cpp
|
||||
QueryPlan/FillingStep.cpp
|
||||
QueryPlan/FilterStep.cpp
|
||||
QueryPlan/FinishSortingStep.cpp
|
||||
QueryPlan/ISourceStep.cpp
|
||||
QueryPlan/ITransformingStep.cpp
|
||||
QueryPlan/IQueryPlanStep.cpp
|
||||
QueryPlan/LimitByStep.cpp
|
||||
QueryPlan/LimitStep.cpp
|
||||
QueryPlan/MergeSortingStep.cpp
|
||||
QueryPlan/MergingAggregatedStep.cpp
|
||||
QueryPlan/MergingSortedStep.cpp
|
||||
QueryPlan/OffsetStep.cpp
|
||||
QueryPlan/PartialSortingStep.cpp
|
||||
QueryPlan/UnionStep.cpp
|
||||
QueryPlan/ReadFromPreparedSource.cpp
|
||||
QueryPlan/ReadFromStorageStep.cpp
|
||||
QueryPlan/ReadNothingStep.cpp
|
||||
QueryPlan/RollupStep.cpp
|
||||
QueryPlan/TotalsHavingStep.cpp
|
||||
QueryPlan/QueryPlan.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
13
src/Processors/ya.make.in
Normal file
13
src/Processors/ya.make.in
Normal file
@ -0,0 +1,13 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/msgpack
|
||||
contrib/libs/protobuf
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | grep -v -P 'Arrow|Avro|ORC|Parquet|CapnProto' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -11,14 +12,15 @@ SRCS(
|
||||
InterserverIOHTTPHandler.cpp
|
||||
MySQLHandler.cpp
|
||||
MySQLHandlerFactory.cpp
|
||||
NotFoundHandler.cpp
|
||||
PostgreSQLHandler.cpp
|
||||
PostgreSQLHandlerFactory.cpp
|
||||
NotFoundHandler.cpp
|
||||
PrometheusMetricsWriter.cpp
|
||||
PrometheusRequestHandler.cpp
|
||||
ReplicasStatusHandler.cpp
|
||||
StaticRequestHandler.cpp
|
||||
TCPHandler.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
12
src/Server/ya.make.in
Normal file
12
src/Server/ya.make.in
Normal file
@ -0,0 +1,12 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/poco/Util
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -7,8 +8,17 @@ PEERDIR(
|
||||
)
|
||||
|
||||
SRCS(
|
||||
AlterCommands.cpp
|
||||
ColumnDefault.cpp
|
||||
ColumnsDescription.cpp
|
||||
ConstraintsDescription.cpp
|
||||
Distributed/DirectoryMonitor.cpp
|
||||
Distributed/DistributedBlockOutputStream.cpp
|
||||
extractKeyExpressionList.cpp
|
||||
getStructureOfRemoteTable.cpp
|
||||
IndicesDescription.cpp
|
||||
IStorage.cpp
|
||||
KeyDescription.cpp
|
||||
LiveView/StorageLiveView.cpp
|
||||
MergeTree/ActiveDataPartSet.cpp
|
||||
MergeTree/AllMergeSelector.cpp
|
||||
@ -34,10 +44,13 @@ SRCS(
|
||||
MergeTree/MergeTreeDataMergerMutator.cpp
|
||||
MergeTree/MergeTreeDataPartChecksum.cpp
|
||||
MergeTree/MergeTreeDataPartCompact.cpp
|
||||
MergeTree/MergeTreeDataPartInMemory.cpp
|
||||
MergeTree/MergeTreeDataPartTTLInfo.cpp
|
||||
MergeTree/MergeTreeDataPartType.cpp
|
||||
MergeTree/MergeTreeDataPartWide.cpp
|
||||
MergeTree/MergeTreeDataPartWriterCompact.cpp
|
||||
MergeTree/MergeTreeDataPartWriterInMemory.cpp
|
||||
MergeTree/MergeTreeDataPartWriterOnDisk.cpp
|
||||
MergeTree/MergeTreeDataPartWriterWide.cpp
|
||||
MergeTree/MergeTreeDataSelectExecutor.cpp
|
||||
MergeTree/MergeTreeDataWriter.cpp
|
||||
@ -54,11 +67,13 @@ SRCS(
|
||||
MergeTree/MergeTreeIndices.cpp
|
||||
MergeTree/MergeTreeMarksLoader.cpp
|
||||
MergeTree/MergeTreeMutationEntry.cpp
|
||||
MergeTree/MergeTreeMutationStatus.cpp
|
||||
MergeTree/MergeTreePartInfo.cpp
|
||||
MergeTree/MergeTreePartition.cpp
|
||||
MergeTree/MergeTreePartsMover.cpp
|
||||
MergeTree/MergeTreeRangeReader.cpp
|
||||
MergeTree/MergeTreeReaderCompact.cpp
|
||||
MergeTree/MergeTreeReaderInMemory.cpp
|
||||
MergeTree/MergeTreeReaderStream.cpp
|
||||
MergeTree/MergeTreeReaderWide.cpp
|
||||
MergeTree/MergeTreeReadPool.cpp
|
||||
@ -68,6 +83,7 @@ SRCS(
|
||||
MergeTree/MergeTreeSettings.cpp
|
||||
MergeTree/MergeTreeThreadSelectBlockInputProcessor.cpp
|
||||
MergeTree/MergeTreeWhereOptimizer.cpp
|
||||
MergeTree/MergeTreeWriteAheadLog.cpp
|
||||
MergeTree/registerStorageMergeTree.cpp
|
||||
MergeTree/ReplicatedMergeTreeAddress.cpp
|
||||
MergeTree/ReplicatedMergeTreeAltersSequence.cpp
|
||||
@ -82,78 +98,11 @@ SRCS(
|
||||
MergeTree/ReplicatedMergeTreeTableMetadata.cpp
|
||||
MergeTree/SimpleMergeSelector.cpp
|
||||
MergeTree/TTLMergeSelector.cpp
|
||||
MergeTree/MergeTreeDataPartInMemory.cpp
|
||||
MergeTree/MergeTreeDataPartWriterInMemory.cpp
|
||||
MergeTree/MergeTreeDataPartWriterOnDisk.cpp
|
||||
MergeTree/MergeTreeReaderInMemory.cpp
|
||||
MergeTree/MergeTreeWriteAheadLog.cpp
|
||||
MergeTree/MergeTreeMutationStatus.cpp
|
||||
System/attachSystemTables.cpp
|
||||
System/StorageSystemAggregateFunctionCombinators.cpp
|
||||
System/StorageSystemAsynchronousMetrics.cpp
|
||||
System/StorageSystemBuildOptions.cpp
|
||||
System/StorageSystemClusters.cpp
|
||||
System/StorageSystemCurrentRoles.cpp
|
||||
System/StorageSystemCollations.cpp
|
||||
System/StorageSystemColumns.cpp
|
||||
System/StorageSystemContributors.cpp
|
||||
System/StorageSystemContributors.generated.cpp
|
||||
System/StorageSystemDatabases.cpp
|
||||
System/StorageSystemDataTypeFamilies.cpp
|
||||
System/StorageSystemDetachedParts.cpp
|
||||
System/StorageSystemDictionaries.cpp
|
||||
System/StorageSystemDisks.cpp
|
||||
System/StorageSystemEnabledRoles.cpp
|
||||
System/StorageSystemEvents.cpp
|
||||
System/StorageSystemFormats.cpp
|
||||
System/StorageSystemFunctions.cpp
|
||||
System/StorageSystemGrants.cpp
|
||||
System/StorageSystemGraphite.cpp
|
||||
System/StorageSystemMacros.cpp
|
||||
System/StorageSystemMerges.cpp
|
||||
System/StorageSystemMergeTreeSettings.cpp
|
||||
System/StorageSystemMetrics.cpp
|
||||
System/StorageSystemModels.cpp
|
||||
System/StorageSystemMutations.cpp
|
||||
System/StorageSystemNumbers.cpp
|
||||
System/StorageSystemOne.cpp
|
||||
System/StorageSystemParts.cpp
|
||||
System/StorageSystemPartsBase.cpp
|
||||
System/StorageSystemPartsColumns.cpp
|
||||
System/StorageSystemPrivileges.cpp
|
||||
System/StorageSystemProcesses.cpp
|
||||
System/StorageSystemQuotaLimits.cpp
|
||||
System/StorageSystemQuotaUsage.cpp
|
||||
System/StorageSystemQuotas.cpp
|
||||
System/StorageSystemQuotasUsage.cpp
|
||||
System/StorageSystemReplicas.cpp
|
||||
System/StorageSystemReplicationQueue.cpp
|
||||
System/StorageSystemDistributionQueue.cpp
|
||||
System/StorageSystemRoleGrants.cpp
|
||||
System/StorageSystemRoles.cpp
|
||||
System/StorageSystemRowPolicies.cpp
|
||||
System/StorageSystemSettings.cpp
|
||||
System/StorageSystemSettingsProfileElements.cpp
|
||||
System/StorageSystemSettingsProfiles.cpp
|
||||
System/StorageSystemStackTrace.cpp
|
||||
System/StorageSystemStoragePolicies.cpp
|
||||
System/StorageSystemTableEngines.cpp
|
||||
System/StorageSystemTableFunctions.cpp
|
||||
System/StorageSystemTables.cpp
|
||||
System/StorageSystemUsers.cpp
|
||||
System/StorageSystemZeros.cpp
|
||||
System/StorageSystemZooKeeper.cpp
|
||||
AlterCommands.cpp
|
||||
ColumnDefault.cpp
|
||||
ColumnsDescription.cpp
|
||||
ConstraintsDescription.cpp
|
||||
getStructureOfRemoteTable.cpp
|
||||
IndicesDescription.cpp
|
||||
IStorage.cpp
|
||||
MutationCommands.cpp
|
||||
PartitionCommands.cpp
|
||||
ReadInOrderOptimizer.cpp
|
||||
registerStorages.cpp
|
||||
SelectQueryDescription.cpp
|
||||
StorageBuffer.cpp
|
||||
StorageDictionary.cpp
|
||||
StorageDistributed.cpp
|
||||
@ -169,10 +118,10 @@ SRCS(
|
||||
StorageMemory.cpp
|
||||
StorageMerge.cpp
|
||||
StorageMergeTree.cpp
|
||||
StorageMongoDB.cpp
|
||||
StorageMySQL.cpp
|
||||
StorageNull.cpp
|
||||
StorageReplicatedMergeTree.cpp
|
||||
StorageS3Settings.cpp
|
||||
StorageSet.cpp
|
||||
StorageStripeLog.cpp
|
||||
StorageTinyLog.cpp
|
||||
@ -180,13 +129,65 @@ SRCS(
|
||||
StorageValues.cpp
|
||||
StorageView.cpp
|
||||
StorageXDBC.cpp
|
||||
System/attachSystemTables.cpp
|
||||
System/StorageSystemAggregateFunctionCombinators.cpp
|
||||
System/StorageSystemAsynchronousMetrics.cpp
|
||||
System/StorageSystemBuildOptions.cpp
|
||||
System/StorageSystemClusters.cpp
|
||||
System/StorageSystemCollations.cpp
|
||||
System/StorageSystemColumns.cpp
|
||||
System/StorageSystemContributors.cpp
|
||||
System/StorageSystemContributors.generated.cpp
|
||||
System/StorageSystemCurrentRoles.cpp
|
||||
System/StorageSystemDatabases.cpp
|
||||
System/StorageSystemDataTypeFamilies.cpp
|
||||
System/StorageSystemDetachedParts.cpp
|
||||
System/StorageSystemDictionaries.cpp
|
||||
System/StorageSystemDisks.cpp
|
||||
System/StorageSystemDistributionQueue.cpp
|
||||
System/StorageSystemEnabledRoles.cpp
|
||||
System/StorageSystemEvents.cpp
|
||||
System/StorageSystemFormats.cpp
|
||||
System/StorageSystemFunctions.cpp
|
||||
System/StorageSystemGrants.cpp
|
||||
System/StorageSystemGraphite.cpp
|
||||
System/StorageSystemMacros.cpp
|
||||
System/StorageSystemMerges.cpp
|
||||
System/StorageSystemMergeTreeSettings.cpp
|
||||
System/StorageSystemMetrics.cpp
|
||||
System/StorageSystemModels.cpp
|
||||
System/StorageSystemMutations.cpp
|
||||
System/StorageSystemNumbers.cpp
|
||||
System/StorageSystemOne.cpp
|
||||
System/StorageSystemPartsBase.cpp
|
||||
System/StorageSystemPartsColumns.cpp
|
||||
System/StorageSystemParts.cpp
|
||||
System/StorageSystemPrivileges.cpp
|
||||
System/StorageSystemProcesses.cpp
|
||||
System/StorageSystemQuotaLimits.cpp
|
||||
System/StorageSystemQuotas.cpp
|
||||
System/StorageSystemQuotasUsage.cpp
|
||||
System/StorageSystemQuotaUsage.cpp
|
||||
System/StorageSystemReplicas.cpp
|
||||
System/StorageSystemReplicationQueue.cpp
|
||||
System/StorageSystemRoleGrants.cpp
|
||||
System/StorageSystemRoles.cpp
|
||||
System/StorageSystemRowPolicies.cpp
|
||||
System/StorageSystemSettings.cpp
|
||||
System/StorageSystemSettingsProfileElements.cpp
|
||||
System/StorageSystemSettingsProfiles.cpp
|
||||
System/StorageSystemStackTrace.cpp
|
||||
System/StorageSystemStoragePolicies.cpp
|
||||
System/StorageSystemTableEngines.cpp
|
||||
System/StorageSystemTableFunctions.cpp
|
||||
System/StorageSystemTables.cpp
|
||||
System/StorageSystemUsers.cpp
|
||||
System/StorageSystemZeros.cpp
|
||||
System/StorageSystemZooKeeper.cpp
|
||||
transformQueryForExternalDatabase.cpp
|
||||
VirtualColumnUtils.cpp
|
||||
extractKeyExpressionList.cpp
|
||||
TTLDescription.cpp
|
||||
KeyDescription.cpp
|
||||
SelectQueryDescription.cpp
|
||||
StorageMongoDB.cpp
|
||||
VirtualColumnUtils.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
13
src/Storages/ya.make.in
Normal file
13
src/Storages/ya.make.in
Normal file
@ -0,0 +1,13 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/sparsehash
|
||||
contrib/libs/poco/MongoDB
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | grep -v -P 'Kafka|RabbitMQ|S3|HDFS|Licenses' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -1,3 +1,4 @@
|
||||
# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it.
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
@ -21,6 +22,7 @@ SRCS(
|
||||
TableFunctionURL.cpp
|
||||
TableFunctionValues.cpp
|
||||
TableFunctionZeros.cpp
|
||||
|
||||
)
|
||||
|
||||
END()
|
||||
|
11
src/TableFunctions/ya.make.in
Normal file
11
src/TableFunctions/ya.make.in
Normal file
@ -0,0 +1,11 @@
|
||||
LIBRARY()
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -P 'S3|HDFS' | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
Loading…
Reference in New Issue
Block a user