mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-21 15:12:02 +00:00
Improve Arcadia
This commit is contained in:
parent
36cbf7af37
commit
b56486510f
@ -35,25 +35,25 @@ PEERDIR(
|
||||
CFLAGS(-g0)
|
||||
|
||||
SRCS(
|
||||
argsToConfig.cpp
|
||||
coverage.cpp
|
||||
DateLUT.cpp
|
||||
DateLUTImpl.cpp
|
||||
JSON.cpp
|
||||
LineReader.cpp
|
||||
StringRef.cpp
|
||||
argsToConfig.cpp
|
||||
coverage.cpp
|
||||
demangle.cpp
|
||||
errnoToString.cpp
|
||||
getFQDNOrHostName.cpp
|
||||
getMemoryAmount.cpp
|
||||
getResource.cpp
|
||||
getThreadId.cpp
|
||||
JSON.cpp
|
||||
LineReader.cpp
|
||||
mremap.cpp
|
||||
phdr_cache.cpp
|
||||
preciseExp10.cpp
|
||||
setTerminalEcho.cpp
|
||||
shift10.cpp
|
||||
sleep.cpp
|
||||
StringRef.cpp
|
||||
terminalColors.cpp
|
||||
|
||||
)
|
||||
|
@ -27,14 +27,14 @@ SRCS(
|
||||
LDAPClient.cpp
|
||||
MemoryAccessStorage.cpp
|
||||
MultipleAccessStorage.cpp
|
||||
QuotaCache.cpp
|
||||
Quota.cpp
|
||||
QuotaCache.cpp
|
||||
QuotaUsage.cpp
|
||||
RoleCache.cpp
|
||||
Role.cpp
|
||||
RoleCache.cpp
|
||||
RolesOrUsersSet.cpp
|
||||
RowPolicyCache.cpp
|
||||
RowPolicy.cpp
|
||||
RowPolicyCache.cpp
|
||||
SettingsConstraints.cpp
|
||||
SettingsProfile.cpp
|
||||
SettingsProfileElement.cpp
|
||||
|
@ -26,10 +26,10 @@ SRCS(
|
||||
AggregateFunctionGroupUniqArray.cpp
|
||||
AggregateFunctionHistogram.cpp
|
||||
AggregateFunctionIf.cpp
|
||||
AggregateFunctionMLMethod.cpp
|
||||
AggregateFunctionMaxIntersections.cpp
|
||||
AggregateFunctionMerge.cpp
|
||||
AggregateFunctionMinMaxAny.cpp
|
||||
AggregateFunctionMLMethod.cpp
|
||||
AggregateFunctionNull.cpp
|
||||
AggregateFunctionOrFill.cpp
|
||||
AggregateFunctionQuantile.cpp
|
||||
@ -45,14 +45,14 @@ SRCS(
|
||||
AggregateFunctionSumMap.cpp
|
||||
AggregateFunctionTimeSeriesGroupSum.cpp
|
||||
AggregateFunctionTopK.cpp
|
||||
AggregateFunctionUniqCombined.cpp
|
||||
AggregateFunctionUniq.cpp
|
||||
AggregateFunctionUniqCombined.cpp
|
||||
AggregateFunctionUniqUpTo.cpp
|
||||
AggregateFunctionWindowFunnel.cpp
|
||||
parseAggregateFunctionParameters.cpp
|
||||
registerAggregateFunctions.cpp
|
||||
UniqCombinedBiasData.cpp
|
||||
UniqVariadicHash.cpp
|
||||
parseAggregateFunctionParameters.cpp
|
||||
registerAggregateFunctions.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -13,7 +13,6 @@ PEERDIR(
|
||||
contrib/libs/pdqsort
|
||||
)
|
||||
|
||||
|
||||
SRCS(
|
||||
Collator.cpp
|
||||
ColumnAggregateFunction.cpp
|
||||
@ -24,13 +23,13 @@ SRCS(
|
||||
ColumnFunction.cpp
|
||||
ColumnLowCardinality.cpp
|
||||
ColumnNullable.cpp
|
||||
ColumnsCommon.cpp
|
||||
ColumnString.cpp
|
||||
ColumnTuple.cpp
|
||||
ColumnVector.cpp
|
||||
ColumnsCommon.cpp
|
||||
FilterDescription.cpp
|
||||
getLeastSuperColumn.cpp
|
||||
IColumn.cpp
|
||||
getLeastSuperColumn.cpp
|
||||
|
||||
)
|
||||
|
||||
|
19
src/Columns/ya.make.in
Normal file
19
src/Columns/ya.make.in
Normal file
@ -0,0 +1,19 @@
|
||||
LIBRARY()
|
||||
|
||||
ADDINCL(
|
||||
contrib/libs/icu/common
|
||||
contrib/libs/icu/i18n
|
||||
contrib/libs/pdqsort
|
||||
)
|
||||
|
||||
PEERDIR(
|
||||
clickhouse/src/Common
|
||||
contrib/libs/icu
|
||||
contrib/libs/pdqsort
|
||||
)
|
||||
|
||||
SRCS(
|
||||
<? find . -name '*.cpp' | grep -v -F tests | sed 's/^\.\// /' | sort ?>
|
||||
)
|
||||
|
||||
END()
|
@ -26,60 +26,36 @@ SRCS(
|
||||
ActionLock.cpp
|
||||
AlignedBuffer.cpp
|
||||
Allocator.cpp
|
||||
checkStackSize.cpp
|
||||
clearPasswordFromCommandLine.cpp
|
||||
ClickHouseRevision.cpp
|
||||
Config/AbstractConfigurationComparison.cpp
|
||||
Config/ConfigProcessor.cpp
|
||||
Config/configReadClient.cpp
|
||||
Config/ConfigReloader.cpp
|
||||
createHardLink.cpp
|
||||
Config/configReadClient.cpp
|
||||
CurrentMetrics.cpp
|
||||
CurrentThread.cpp
|
||||
DNSResolver.cpp
|
||||
Dwarf.cpp
|
||||
Elf.cpp
|
||||
ErrorCodes.cpp
|
||||
escapeForFileName.cpp
|
||||
Exception.cpp
|
||||
ExternalLoaderStatus.cpp
|
||||
FieldVisitors.cpp
|
||||
FileChecker.cpp
|
||||
filesystemHelpers.cpp
|
||||
formatIPv6.cpp
|
||||
formatReadable.cpp
|
||||
getExecutablePath.cpp
|
||||
getMappedArea.cpp
|
||||
getMultipleKeysFromConfig.cpp
|
||||
getNumberOfPhysicalCPUCores.cpp
|
||||
hasLinuxCapability.cpp
|
||||
hex.cpp
|
||||
IntervalKind.cpp
|
||||
IPv6ToBinary.cpp
|
||||
isLocalAddress.cpp
|
||||
IntervalKind.cpp
|
||||
Macros.cpp
|
||||
malloc.cpp
|
||||
MemoryStatisticsOS.cpp
|
||||
MemoryTracker.cpp
|
||||
new_delete.cpp
|
||||
OpenSSLHelpers.cpp
|
||||
OptimizedRegularExpression.cpp
|
||||
parseAddress.cpp
|
||||
parseGlobs.cpp
|
||||
parseRemoteDescription.cpp
|
||||
PipeFDs.cpp
|
||||
PODArray.cpp
|
||||
PipeFDs.cpp
|
||||
ProcfsMetricsProvider.cpp
|
||||
ProfileEvents.cpp
|
||||
QueryProfiler.cpp
|
||||
quoteString.cpp
|
||||
randomSeed.cpp
|
||||
remapExecutable.cpp
|
||||
RemoteHostFilter.cpp
|
||||
renameat2.cpp
|
||||
RWLock.cpp
|
||||
RemoteHostFilter.cpp
|
||||
SensitiveDataMasker.cpp
|
||||
setThreadName.cpp
|
||||
SettingsChanges.cpp
|
||||
SharedLibrary.cpp
|
||||
ShellCommand.cpp
|
||||
@ -93,19 +69,43 @@ SRCS(
|
||||
TaskStatsInfoGetter.cpp
|
||||
TerminalSize.cpp
|
||||
ThreadFuzzer.cpp
|
||||
thread_local_rng.cpp
|
||||
ThreadPool.cpp
|
||||
ThreadProfileEvents.cpp
|
||||
ThreadStatus.cpp
|
||||
TraceCollector.cpp
|
||||
UnicodeBar.cpp
|
||||
UTF8Helpers.cpp
|
||||
UnicodeBar.cpp
|
||||
WeakHash.cpp
|
||||
ZooKeeper/IKeeper.cpp
|
||||
ZooKeeper/TestKeeper.cpp
|
||||
ZooKeeper/ZooKeeper.cpp
|
||||
ZooKeeper/ZooKeeperImpl.cpp
|
||||
ZooKeeper/ZooKeeperNodeCache.cpp
|
||||
checkStackSize.cpp
|
||||
clearPasswordFromCommandLine.cpp
|
||||
createHardLink.cpp
|
||||
escapeForFileName.cpp
|
||||
filesystemHelpers.cpp
|
||||
formatIPv6.cpp
|
||||
formatReadable.cpp
|
||||
getExecutablePath.cpp
|
||||
getMappedArea.cpp
|
||||
getMultipleKeysFromConfig.cpp
|
||||
getNumberOfPhysicalCPUCores.cpp
|
||||
hasLinuxCapability.cpp
|
||||
hex.cpp
|
||||
isLocalAddress.cpp
|
||||
malloc.cpp
|
||||
new_delete.cpp
|
||||
parseAddress.cpp
|
||||
parseGlobs.cpp
|
||||
parseRemoteDescription.cpp
|
||||
quoteString.cpp
|
||||
randomSeed.cpp
|
||||
remapExecutable.cpp
|
||||
renameat2.cpp
|
||||
setThreadName.cpp
|
||||
thread_local_rng.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -15,8 +15,8 @@ PEERDIR(
|
||||
|
||||
SRCS(
|
||||
CachedCompressedReadBuffer.cpp
|
||||
CompressedReadBufferBase.cpp
|
||||
CompressedReadBuffer.cpp
|
||||
CompressedReadBufferBase.cpp
|
||||
CompressedReadBufferFromFile.cpp
|
||||
CompressedWriteBuffer.cpp
|
||||
CompressionCodecDelta.cpp
|
||||
@ -28,9 +28,9 @@ SRCS(
|
||||
CompressionCodecT64.cpp
|
||||
CompressionCodecZSTD.cpp
|
||||
CompressionFactory.cpp
|
||||
getCompressionCodecForFile.cpp
|
||||
ICompressionCodec.cpp
|
||||
LZ4_decompress_faster.cpp
|
||||
getCompressionCodecForFile.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -17,7 +17,6 @@ SRCS(
|
||||
ExternalResultDescription.cpp
|
||||
ExternalTable.cpp
|
||||
Field.cpp
|
||||
iostream_debug_helpers.cpp
|
||||
MySQL/Authentication.cpp
|
||||
MySQL/IMySQLReadPacket.cpp
|
||||
MySQL/IMySQLWritePacket.cpp
|
||||
@ -35,6 +34,7 @@ SRCS(
|
||||
SettingsEnums.cpp
|
||||
SettingsFields.cpp
|
||||
SortDescription.cpp
|
||||
iostream_debug_helpers.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -19,21 +19,17 @@ SRCS(
|
||||
CheckSortedBlockInputStream.cpp
|
||||
ColumnGathererStream.cpp
|
||||
ConvertingBlockInputStream.cpp
|
||||
copyData.cpp
|
||||
CountingBlockOutputStream.cpp
|
||||
DistinctSortedBlockInputStream.cpp
|
||||
ExecutionSpeedLimits.cpp
|
||||
ExpressionBlockInputStream.cpp
|
||||
finalizeBlock.cpp
|
||||
IBlockInputStream.cpp
|
||||
InputStreamFromASTInsertQuery.cpp
|
||||
InternalTextLogsRowOutputStream.cpp
|
||||
LimitBlockInputStream.cpp
|
||||
materializeBlock.cpp
|
||||
MaterializingBlockInputStream.cpp
|
||||
MergingSortedBlockInputStream.cpp
|
||||
MongoDBBlockInputStream.cpp
|
||||
narrowBlockInputStreams.cpp
|
||||
NativeBlockInputStream.cpp
|
||||
NativeBlockOutputStream.cpp
|
||||
ParallelParsingBlockInputStream.cpp
|
||||
@ -46,6 +42,10 @@ SRCS(
|
||||
SquashingBlockOutputStream.cpp
|
||||
SquashingTransform.cpp
|
||||
TTLBlockInputStream.cpp
|
||||
copyData.cpp
|
||||
finalizeBlock.cpp
|
||||
materializeBlock.cpp
|
||||
narrowBlockInputStreams.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -8,7 +8,6 @@ PEERDIR(
|
||||
|
||||
|
||||
SRCS(
|
||||
convertMySQLDataType.cpp
|
||||
DataTypeAggregateFunction.cpp
|
||||
DataTypeArray.cpp
|
||||
DataTypeCustomGeo.cpp
|
||||
@ -16,8 +15,8 @@ SRCS(
|
||||
DataTypeCustomSimpleAggregateFunction.cpp
|
||||
DataTypeCustomSimpleTextSerialization.cpp
|
||||
DataTypeDate.cpp
|
||||
DataTypeDateTime64.cpp
|
||||
DataTypeDateTime.cpp
|
||||
DataTypeDateTime64.cpp
|
||||
DataTypeDecimalBase.cpp
|
||||
DataTypeEnum.cpp
|
||||
DataTypeFactory.cpp
|
||||
@ -29,16 +28,17 @@ SRCS(
|
||||
DataTypeNothing.cpp
|
||||
DataTypeNullable.cpp
|
||||
DataTypeNumberBase.cpp
|
||||
DataTypesDecimal.cpp
|
||||
DataTypesNumber.cpp
|
||||
DataTypeString.cpp
|
||||
DataTypeTuple.cpp
|
||||
DataTypeUUID.cpp
|
||||
DataTypesDecimal.cpp
|
||||
DataTypesNumber.cpp
|
||||
FieldToDataType.cpp
|
||||
getLeastSupertype.cpp
|
||||
getMostSubtype.cpp
|
||||
IDataType.cpp
|
||||
NestedUtils.cpp
|
||||
convertMySQLDataType.cpp
|
||||
getLeastSupertype.cpp
|
||||
getMostSubtype.cpp
|
||||
registerDataTypeDateTime.cpp
|
||||
|
||||
)
|
||||
|
@ -14,8 +14,8 @@ SRCS(
|
||||
DatabaseMemory.cpp
|
||||
DatabaseOnDisk.cpp
|
||||
DatabaseOrdinary.cpp
|
||||
DatabasesCommon.cpp
|
||||
DatabaseWithDictionaries.cpp
|
||||
DatabasesCommon.cpp
|
||||
MySQL/ConnectionMySQLSettings.cpp
|
||||
MySQL/DatabaseConnectionMySQL.cpp
|
||||
MySQL/DatabaseMaterializeMySQL.cpp
|
||||
|
@ -37,11 +37,11 @@ SRCS(
|
||||
DictionarySourceHelpers.cpp
|
||||
DictionaryStructure.cpp
|
||||
DirectDictionary.cpp
|
||||
Embedded/GeoDictionariesLoader.cpp
|
||||
Embedded/GeodataProviders/HierarchiesProvider.cpp
|
||||
Embedded/GeodataProviders/HierarchyFormatReader.cpp
|
||||
Embedded/GeodataProviders/NamesFormatReader.cpp
|
||||
Embedded/GeodataProviders/NamesProvider.cpp
|
||||
Embedded/GeoDictionariesLoader.cpp
|
||||
Embedded/RegionsHierarchies.cpp
|
||||
Embedded/RegionsHierarchy.cpp
|
||||
Embedded/RegionsNames.cpp
|
||||
@ -49,9 +49,8 @@ SRCS(
|
||||
ExternalQueryBuilder.cpp
|
||||
FileDictionarySource.cpp
|
||||
FlatDictionary.cpp
|
||||
getDictionaryConfigurationFromAST.cpp
|
||||
HashedDictionary.cpp
|
||||
HTTPDictionarySource.cpp
|
||||
HashedDictionary.cpp
|
||||
LibraryDictionarySource.cpp
|
||||
LibraryDictionarySourceExternal.cpp
|
||||
MongoDBDictionarySource.cpp
|
||||
@ -60,14 +59,15 @@ SRCS(
|
||||
PolygonDictionaryImplementations.cpp
|
||||
PolygonDictionaryUtils.cpp
|
||||
RangeHashedDictionary.cpp
|
||||
readInvalidateQuery.cpp
|
||||
RedisBlockInputStream.cpp
|
||||
RedisDictionarySource.cpp
|
||||
registerDictionaries.cpp
|
||||
SSDCacheDictionary.cpp
|
||||
SSDComplexKeyCacheDictionary.cpp
|
||||
writeParenthesisedString.cpp
|
||||
XDBCDictionarySource.cpp
|
||||
getDictionaryConfigurationFromAST.cpp
|
||||
readInvalidateQuery.cpp
|
||||
registerDictionaries.cpp
|
||||
writeParenthesisedString.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -7,7 +7,6 @@ PEERDIR(
|
||||
|
||||
|
||||
SRCS(
|
||||
createVolume.cpp
|
||||
DiskCacheWrapper.cpp
|
||||
DiskDecorator.cpp
|
||||
DiskFactory.cpp
|
||||
@ -16,11 +15,12 @@ SRCS(
|
||||
DiskSelector.cpp
|
||||
IDisk.cpp
|
||||
IVolume.cpp
|
||||
registerDisks.cpp
|
||||
SingleDiskVolume.cpp
|
||||
StoragePolicy.cpp
|
||||
VolumeJBOD.cpp
|
||||
VolumeRAID1.cpp
|
||||
createVolume.cpp
|
||||
registerDisks.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -34,6 +34,70 @@ PEERDIR(
|
||||
# "Arcadia" build is slightly deficient. It lacks many libraries that we need.
|
||||
|
||||
SRCS(
|
||||
CRC.cpp
|
||||
FunctionFQDN.cpp
|
||||
FunctionFactory.cpp
|
||||
FunctionHelpers.cpp
|
||||
FunctionJoinGet.cpp
|
||||
FunctionsAES.cpp
|
||||
FunctionsCoding.cpp
|
||||
FunctionsConversion.cpp
|
||||
FunctionsEmbeddedDictionaries.cpp
|
||||
FunctionsExternalDictionaries.cpp
|
||||
FunctionsExternalModels.cpp
|
||||
FunctionsHashing.cpp
|
||||
FunctionsJSON.cpp
|
||||
FunctionsLogical.cpp
|
||||
FunctionsRandom.cpp
|
||||
FunctionsRound.cpp
|
||||
FunctionsStringArray.cpp
|
||||
FunctionsStringSimilarity.cpp
|
||||
GatherUtils/concat.cpp
|
||||
GatherUtils/createArraySink.cpp
|
||||
GatherUtils/createArraySource.cpp
|
||||
GatherUtils/createValueSource.cpp
|
||||
GatherUtils/has_all.cpp
|
||||
GatherUtils/has_any.cpp
|
||||
GatherUtils/has_substr.cpp
|
||||
GatherUtils/push.cpp
|
||||
GatherUtils/resizeConstantSize.cpp
|
||||
GatherUtils/resizeDynamicSize.cpp
|
||||
GatherUtils/sliceDynamicOffsetBounded.cpp
|
||||
GatherUtils/sliceDynamicOffsetUnbounded.cpp
|
||||
GatherUtils/sliceFromLeftConstantOffsetBounded.cpp
|
||||
GatherUtils/sliceFromLeftConstantOffsetUnbounded.cpp
|
||||
GatherUtils/sliceFromRightConstantOffsetBounded.cpp
|
||||
GatherUtils/sliceFromRightConstantOffsetUnbounded.cpp
|
||||
GeoHash.cpp
|
||||
IFunction.cpp
|
||||
TargetSpecific.cpp
|
||||
URL/URLHierarchy.cpp
|
||||
URL/URLPathHierarchy.cpp
|
||||
URL/basename.cpp
|
||||
URL/cutFragment.cpp
|
||||
URL/cutQueryString.cpp
|
||||
URL/cutQueryStringAndFragment.cpp
|
||||
URL/cutToFirstSignificantSubdomain.cpp
|
||||
URL/cutURLParameter.cpp
|
||||
URL/cutWWW.cpp
|
||||
URL/decodeURLComponent.cpp
|
||||
URL/domain.cpp
|
||||
URL/domainWithoutWWW.cpp
|
||||
URL/extractURLParameter.cpp
|
||||
URL/extractURLParameterNames.cpp
|
||||
URL/extractURLParameters.cpp
|
||||
URL/firstSignificantSubdomain.cpp
|
||||
URL/fragment.cpp
|
||||
URL/netloc.cpp
|
||||
URL/path.cpp
|
||||
URL/pathFull.cpp
|
||||
URL/port.cpp
|
||||
URL/protocol.cpp
|
||||
URL/queryString.cpp
|
||||
URL/queryStringAndFragment.cpp
|
||||
URL/registerFunctionsURL.cpp
|
||||
URL/tldLookup.generated.cpp
|
||||
URL/topLevelDomain.cpp
|
||||
abs.cpp
|
||||
acos.cpp
|
||||
addDays.cpp
|
||||
@ -41,20 +105,20 @@ SRCS(
|
||||
addMinutes.cpp
|
||||
addMonths.cpp
|
||||
addQuarters.cpp
|
||||
addressToLine.cpp
|
||||
addressToSymbol.cpp
|
||||
addSeconds.cpp
|
||||
addWeeks.cpp
|
||||
addYears.cpp
|
||||
addressToLine.cpp
|
||||
addressToSymbol.cpp
|
||||
aes_decrypt_mysql.cpp
|
||||
aes_encrypt_mysql.cpp
|
||||
appendTrailingCharIfAbsent.cpp
|
||||
array/arrayAll.cpp
|
||||
array/array.cpp
|
||||
array/arrayAUC.cpp
|
||||
array/arrayAll.cpp
|
||||
array/arrayCompact.cpp
|
||||
array/arrayConcat.cpp
|
||||
array/arrayCount.cpp
|
||||
array/array.cpp
|
||||
array/arrayCumSum.cpp
|
||||
array/arrayCumSumNonNegative.cpp
|
||||
array/arrayDifference.cpp
|
||||
@ -93,9 +157,9 @@ SRCS(
|
||||
array/countEqual.cpp
|
||||
array/emptyArray.cpp
|
||||
array/emptyArrayToSingle.cpp
|
||||
array/has.cpp
|
||||
array/hasAll.cpp
|
||||
array/hasAny.cpp
|
||||
array/has.cpp
|
||||
array/hasSubstr.cpp
|
||||
array/indexOf.cpp
|
||||
array/length.cpp
|
||||
@ -113,7 +177,6 @@ SRCS(
|
||||
bitBoolMaskAnd.cpp
|
||||
bitBoolMaskOr.cpp
|
||||
bitCount.cpp
|
||||
bitmaskToList.cpp
|
||||
bitNot.cpp
|
||||
bitOr.cpp
|
||||
bitRotateLeft.cpp
|
||||
@ -121,11 +184,12 @@ SRCS(
|
||||
bitShiftLeft.cpp
|
||||
bitShiftRight.cpp
|
||||
bitSwapLastTwo.cpp
|
||||
bitTest.cpp
|
||||
bitTestAll.cpp
|
||||
bitTestAny.cpp
|
||||
bitTest.cpp
|
||||
bitWrapperFunc.cpp
|
||||
bitXor.cpp
|
||||
bitmaskToList.cpp
|
||||
blockNumber.cpp
|
||||
blockSerializedSize.cpp
|
||||
blockSize.cpp
|
||||
@ -137,7 +201,6 @@ SRCS(
|
||||
convertCharset.cpp
|
||||
cos.cpp
|
||||
countDigits.cpp
|
||||
CRC.cpp
|
||||
currentDatabase.cpp
|
||||
currentUser.cpp
|
||||
dateDiff.cpp
|
||||
@ -153,16 +216,16 @@ SRCS(
|
||||
encrypt.cpp
|
||||
endsWith.cpp
|
||||
equals.cpp
|
||||
erfc.cpp
|
||||
erf.cpp
|
||||
erfc.cpp
|
||||
errorCodeToName.cpp
|
||||
evalMLMethod.cpp
|
||||
exp.cpp
|
||||
exp10.cpp
|
||||
exp2.cpp
|
||||
exp.cpp
|
||||
extract.cpp
|
||||
extractAllGroupsHorizontal.cpp
|
||||
extractAllGroupsVertical.cpp
|
||||
extract.cpp
|
||||
extractGroups.cpp
|
||||
extractTimeZoneFromFunctionArguments.cpp
|
||||
filesystem.cpp
|
||||
@ -176,47 +239,13 @@ SRCS(
|
||||
fromUnixTimestamp64Micro.cpp
|
||||
fromUnixTimestamp64Milli.cpp
|
||||
fromUnixTimestamp64Nano.cpp
|
||||
FunctionFactory.cpp
|
||||
FunctionFQDN.cpp
|
||||
FunctionHelpers.cpp
|
||||
FunctionJoinGet.cpp
|
||||
FunctionsAES.cpp
|
||||
FunctionsCoding.cpp
|
||||
FunctionsConversion.cpp
|
||||
FunctionsEmbeddedDictionaries.cpp
|
||||
FunctionsExternalDictionaries.cpp
|
||||
FunctionsExternalModels.cpp
|
||||
FunctionsHashing.cpp
|
||||
FunctionsJSON.cpp
|
||||
FunctionsLogical.cpp
|
||||
FunctionsRandom.cpp
|
||||
FunctionsRound.cpp
|
||||
FunctionsStringArray.cpp
|
||||
FunctionsStringSimilarity.cpp
|
||||
fuzzBits.cpp
|
||||
GatherUtils/concat.cpp
|
||||
GatherUtils/createArraySink.cpp
|
||||
GatherUtils/createArraySource.cpp
|
||||
GatherUtils/createValueSource.cpp
|
||||
GatherUtils/has_all.cpp
|
||||
GatherUtils/has_any.cpp
|
||||
GatherUtils/has_substr.cpp
|
||||
GatherUtils/push.cpp
|
||||
GatherUtils/resizeConstantSize.cpp
|
||||
GatherUtils/resizeDynamicSize.cpp
|
||||
GatherUtils/sliceDynamicOffsetBounded.cpp
|
||||
GatherUtils/sliceDynamicOffsetUnbounded.cpp
|
||||
GatherUtils/sliceFromLeftConstantOffsetBounded.cpp
|
||||
GatherUtils/sliceFromLeftConstantOffsetUnbounded.cpp
|
||||
GatherUtils/sliceFromRightConstantOffsetBounded.cpp
|
||||
GatherUtils/sliceFromRightConstantOffsetUnbounded.cpp
|
||||
gcd.cpp
|
||||
generateUUIDv4.cpp
|
||||
GeoHash.cpp
|
||||
geoToH3.cpp
|
||||
geohashDecode.cpp
|
||||
geohashEncode.cpp
|
||||
geohashesInBox.cpp
|
||||
geoToH3.cpp
|
||||
getMacro.cpp
|
||||
getScalar.cpp
|
||||
getSetting.cpp
|
||||
@ -233,20 +262,19 @@ SRCS(
|
||||
h3HexAreaM2.cpp
|
||||
h3IndexesAreNeighbors.cpp
|
||||
h3IsValid.cpp
|
||||
h3kRing.cpp
|
||||
h3ToChildren.cpp
|
||||
h3ToParent.cpp
|
||||
h3ToString.cpp
|
||||
h3kRing.cpp
|
||||
hasColumnInTable.cpp
|
||||
hasThreadFuzzer.cpp
|
||||
hasTokenCaseInsensitive.cpp
|
||||
hasToken.cpp
|
||||
hasTokenCaseInsensitive.cpp
|
||||
hostName.cpp
|
||||
identity.cpp
|
||||
if.cpp
|
||||
ifNotFinite.cpp
|
||||
ifNull.cpp
|
||||
IFunction.cpp
|
||||
ignore.cpp
|
||||
ilike.cpp
|
||||
in.cpp
|
||||
@ -272,9 +300,9 @@ SRCS(
|
||||
lessOrEquals.cpp
|
||||
lgamma.cpp
|
||||
like.cpp
|
||||
log.cpp
|
||||
log10.cpp
|
||||
log2.cpp
|
||||
log.cpp
|
||||
logTrace.cpp
|
||||
lowCardinalityIndices.cpp
|
||||
lowCardinalityKeys.cpp
|
||||
@ -292,56 +320,56 @@ SRCS(
|
||||
multiMatchAllIndices.cpp
|
||||
multiMatchAny.cpp
|
||||
multiMatchAnyIndex.cpp
|
||||
multiply.cpp
|
||||
multiSearchAllPositions.cpp
|
||||
multiSearchAllPositionsCaseInsensitive.cpp
|
||||
multiSearchAllPositionsCaseInsensitiveUTF8.cpp
|
||||
multiSearchAllPositions.cpp
|
||||
multiSearchAllPositionsUTF8.cpp
|
||||
multiSearchAny.cpp
|
||||
multiSearchAnyCaseInsensitive.cpp
|
||||
multiSearchAnyCaseInsensitiveUTF8.cpp
|
||||
multiSearchAny.cpp
|
||||
multiSearchAnyUTF8.cpp
|
||||
multiSearchFirstIndex.cpp
|
||||
multiSearchFirstIndexCaseInsensitive.cpp
|
||||
multiSearchFirstIndexCaseInsensitiveUTF8.cpp
|
||||
multiSearchFirstIndex.cpp
|
||||
multiSearchFirstIndexUTF8.cpp
|
||||
multiSearchFirstPosition.cpp
|
||||
multiSearchFirstPositionCaseInsensitive.cpp
|
||||
multiSearchFirstPositionCaseInsensitiveUTF8.cpp
|
||||
multiSearchFirstPosition.cpp
|
||||
multiSearchFirstPositionUTF8.cpp
|
||||
multiply.cpp
|
||||
negate.cpp
|
||||
neighbor.cpp
|
||||
normalizedQueryHash.cpp
|
||||
normalizeQuery.cpp
|
||||
normalizedQueryHash.cpp
|
||||
notEmpty.cpp
|
||||
notEquals.cpp
|
||||
notILike.cpp
|
||||
notLike.cpp
|
||||
now64.cpp
|
||||
now.cpp
|
||||
now64.cpp
|
||||
nullIf.cpp
|
||||
pi.cpp
|
||||
plus.cpp
|
||||
pointInEllipses.cpp
|
||||
pointInPolygon.cpp
|
||||
position.cpp
|
||||
positionCaseInsensitive.cpp
|
||||
positionCaseInsensitiveUTF8.cpp
|
||||
position.cpp
|
||||
positionUTF8.cpp
|
||||
pow.cpp
|
||||
rand.cpp
|
||||
rand64.cpp
|
||||
randConstant.cpp
|
||||
rand.cpp
|
||||
randomFixedString.cpp
|
||||
randomPrintableASCII.cpp
|
||||
randomString.cpp
|
||||
randomStringUTF8.cpp
|
||||
regexpQuoteMeta.cpp
|
||||
registerFunctions.cpp
|
||||
registerFunctionsArithmetic.cpp
|
||||
registerFunctionsComparison.cpp
|
||||
registerFunctionsConditional.cpp
|
||||
registerFunctionsConsistentHashing.cpp
|
||||
registerFunctions.cpp
|
||||
registerFunctionsDateTime.cpp
|
||||
registerFunctionsFormatting.cpp
|
||||
registerFunctionsGeo.cpp
|
||||
@ -395,7 +423,6 @@ SRCS(
|
||||
subtractYears.cpp
|
||||
tan.cpp
|
||||
tanh.cpp
|
||||
TargetSpecific.cpp
|
||||
tgamma.cpp
|
||||
throwIf.cpp
|
||||
tid.cpp
|
||||
@ -404,7 +431,6 @@ SRCS(
|
||||
timezone.cpp
|
||||
toColumnTypeName.cpp
|
||||
toCustomWeek.cpp
|
||||
today.cpp
|
||||
toDayOfMonth.cpp
|
||||
toDayOfWeek.cpp
|
||||
toDayOfYear.cpp
|
||||
@ -431,8 +457,8 @@ SRCS(
|
||||
toStartOfFifteenMinutes.cpp
|
||||
toStartOfFiveMinute.cpp
|
||||
toStartOfHour.cpp
|
||||
toStartOfInterval.cpp
|
||||
toStartOfISOYear.cpp
|
||||
toStartOfInterval.cpp
|
||||
toStartOfMinute.cpp
|
||||
toStartOfMonth.cpp
|
||||
toStartOfQuarter.cpp
|
||||
@ -446,10 +472,11 @@ SRCS(
|
||||
toUnixTimestamp64Milli.cpp
|
||||
toUnixTimestamp64Nano.cpp
|
||||
toValidUTF8.cpp
|
||||
toYear.cpp
|
||||
toYYYYMM.cpp
|
||||
toYYYYMMDD.cpp
|
||||
toYYYYMMDDhhmmss.cpp
|
||||
toYear.cpp
|
||||
today.cpp
|
||||
transform.cpp
|
||||
trap.cpp
|
||||
trim.cpp
|
||||
@ -459,33 +486,6 @@ SRCS(
|
||||
upper.cpp
|
||||
upperUTF8.cpp
|
||||
uptime.cpp
|
||||
URL/basename.cpp
|
||||
URL/cutFragment.cpp
|
||||
URL/cutQueryStringAndFragment.cpp
|
||||
URL/cutQueryString.cpp
|
||||
URL/cutToFirstSignificantSubdomain.cpp
|
||||
URL/cutURLParameter.cpp
|
||||
URL/cutWWW.cpp
|
||||
URL/decodeURLComponent.cpp
|
||||
URL/domain.cpp
|
||||
URL/domainWithoutWWW.cpp
|
||||
URL/extractURLParameter.cpp
|
||||
URL/extractURLParameterNames.cpp
|
||||
URL/extractURLParameters.cpp
|
||||
URL/firstSignificantSubdomain.cpp
|
||||
URL/fragment.cpp
|
||||
URL/netloc.cpp
|
||||
URL/path.cpp
|
||||
URL/pathFull.cpp
|
||||
URL/port.cpp
|
||||
URL/protocol.cpp
|
||||
URL/queryStringAndFragment.cpp
|
||||
URL/queryString.cpp
|
||||
URL/registerFunctionsURL.cpp
|
||||
URL/tldLookup.generated.cpp
|
||||
URL/topLevelDomain.cpp
|
||||
URL/URLHierarchy.cpp
|
||||
URL/URLPathHierarchy.cpp
|
||||
version.cpp
|
||||
visibleWidth.cpp
|
||||
visitParamExtractBool.cpp
|
||||
|
@ -10,45 +10,40 @@ PEERDIR(
|
||||
|
||||
|
||||
SRCS(
|
||||
AIOContextPool.cpp
|
||||
AIO.cpp
|
||||
AIOContextPool.cpp
|
||||
BrotliReadBuffer.cpp
|
||||
BrotliWriteBuffer.cpp
|
||||
CascadeWriteBuffer.cpp
|
||||
CompressionMethod.cpp
|
||||
copyData.cpp
|
||||
createReadBufferFromFileBase.cpp
|
||||
createWriteBufferFromFileBase.cpp
|
||||
DoubleConverter.cpp
|
||||
HTTPCommon.cpp
|
||||
HashingWriteBuffer.cpp
|
||||
HexWriteBuffer.cpp
|
||||
HTTPCommon.cpp
|
||||
LimitReadBuffer.cpp
|
||||
MemoryReadWriteBuffer.cpp
|
||||
MMapReadBufferFromFile.cpp
|
||||
MMapReadBufferFromFileDescriptor.cpp
|
||||
MemoryReadWriteBuffer.cpp
|
||||
MySQLBinlogEventReadBuffer.cpp
|
||||
MySQLPacketPayloadReadBuffer.cpp
|
||||
MySQLPacketPayloadWriteBuffer.cpp
|
||||
NullWriteBuffer.cpp
|
||||
parseDateTimeBestEffort.cpp
|
||||
PeekableReadBuffer.cpp
|
||||
Progress.cpp
|
||||
ReadBufferAIO.cpp
|
||||
ReadBufferFromFileBase.cpp
|
||||
ReadBufferFromFile.cpp
|
||||
ReadBufferFromFileBase.cpp
|
||||
ReadBufferFromFileDescriptor.cpp
|
||||
ReadBufferFromIStream.cpp
|
||||
ReadBufferFromMemory.cpp
|
||||
ReadBufferFromPocoSocket.cpp
|
||||
readFloatText.cpp
|
||||
ReadHelpers.cpp
|
||||
ReadWriteBufferFromHTTP.cpp
|
||||
SeekAvoidingReadBuffer.cpp
|
||||
UseSSL.cpp
|
||||
WriteBufferAIO.cpp
|
||||
WriteBufferFromFileBase.cpp
|
||||
WriteBufferFromFile.cpp
|
||||
WriteBufferFromFileBase.cpp
|
||||
WriteBufferFromFileDescriptor.cpp
|
||||
WriteBufferFromFileDescriptorDiscardOnFailure.cpp
|
||||
WriteBufferFromHTTP.cpp
|
||||
@ -60,6 +55,11 @@ SRCS(
|
||||
WriteHelpers.cpp
|
||||
ZlibDeflatingWriteBuffer.cpp
|
||||
ZlibInflatingReadBuffer.cpp
|
||||
copyData.cpp
|
||||
createReadBufferFromFileBase.cpp
|
||||
createWriteBufferFromFileBase.cpp
|
||||
parseDateTimeBestEffort.cpp
|
||||
readFloatText.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -18,8 +18,6 @@ NO_COMPILER_WARNINGS()
|
||||
SRCS(
|
||||
ActionLocksManager.cpp
|
||||
ActionsVisitor.cpp
|
||||
addMissingDefaults.cpp
|
||||
addTypeConversionToAST.cpp
|
||||
AggregateDescription.cpp
|
||||
Aggregator.cpp
|
||||
ApplyWithAliasVisitor.cpp
|
||||
@ -30,26 +28,21 @@ SRCS(
|
||||
AsynchronousMetricLog.cpp
|
||||
AsynchronousMetrics.cpp
|
||||
BloomFilter.cpp
|
||||
castColumn.cpp
|
||||
CatBoostModel.cpp
|
||||
ClientInfo.cpp
|
||||
Cluster.cpp
|
||||
ClusterProxy/executeQuery.cpp
|
||||
ClusterProxy/SelectStreamFactory.cpp
|
||||
ClusterProxy/executeQuery.cpp
|
||||
CollectJoinOnKeysVisitor.cpp
|
||||
Context.cpp
|
||||
convertFieldToType.cpp
|
||||
CrashLog.cpp
|
||||
createBlockSelector.cpp
|
||||
CrossToInnerJoinVisitor.cpp
|
||||
DDLWorker.cpp
|
||||
DNSCacheUpdater.cpp
|
||||
DatabaseAndTableWithAlias.cpp
|
||||
DatabaseCatalog.cpp
|
||||
DDLWorker.cpp
|
||||
DictionaryReader.cpp
|
||||
DNSCacheUpdater.cpp
|
||||
EmbeddedDictionaries.cpp
|
||||
evaluateConstantExpression.cpp
|
||||
executeQuery.cpp
|
||||
ExecuteScalarSubqueriesVisitor.cpp
|
||||
ExpressionActions.cpp
|
||||
ExpressionAnalyzer.cpp
|
||||
@ -61,14 +54,10 @@ SRCS(
|
||||
ExternalModelsLoader.cpp
|
||||
ExtractExpressionInfoVisitor.cpp
|
||||
FillingRow.cpp
|
||||
getClusterName.cpp
|
||||
getHeaderForProcessingStage.cpp
|
||||
getTableExpressions.cpp
|
||||
HashJoin.cpp
|
||||
IdentifierSemantic.cpp
|
||||
IExternalLoadable.cpp
|
||||
IdentifierSemantic.cpp
|
||||
InJoinSubqueriesPreprocessor.cpp
|
||||
inplaceBlockConversions.cpp
|
||||
InternalTextLogsQueue.cpp
|
||||
InterpreterAlterQuery.cpp
|
||||
InterpreterCheckQuery.cpp
|
||||
@ -105,12 +94,9 @@ SRCS(
|
||||
InterpreterSystemQuery.cpp
|
||||
InterpreterUseQuery.cpp
|
||||
InterpreterWatchQuery.cpp
|
||||
interpretSubquery.cpp
|
||||
join_common.cpp
|
||||
JoinedTables.cpp
|
||||
JoinSwitcher.cpp
|
||||
JoinToSubqueryTransformVisitor.cpp
|
||||
loadMetadata.cpp
|
||||
JoinedTables.cpp
|
||||
LogicalExpressionsOptimizer.cpp
|
||||
MarkTableIdentifiersVisitor.cpp
|
||||
MergeJoin.cpp
|
||||
@ -140,7 +126,6 @@ SRCS(
|
||||
RowRefs.cpp
|
||||
Set.cpp
|
||||
SetVariants.cpp
|
||||
sortBlock.cpp
|
||||
SortedBlocksWriter.cpp
|
||||
StorageID.cpp
|
||||
SubqueryForSet.cpp
|
||||
@ -153,6 +138,21 @@ SRCS(
|
||||
TranslateQualifiedNamesVisitor.cpp
|
||||
TreeOptimizer.cpp
|
||||
TreeRewriter.cpp
|
||||
addMissingDefaults.cpp
|
||||
addTypeConversionToAST.cpp
|
||||
castColumn.cpp
|
||||
convertFieldToType.cpp
|
||||
createBlockSelector.cpp
|
||||
evaluateConstantExpression.cpp
|
||||
executeQuery.cpp
|
||||
getClusterName.cpp
|
||||
getHeaderForProcessingStage.cpp
|
||||
getTableExpressions.cpp
|
||||
inplaceBlockConversions.cpp
|
||||
interpretSubquery.cpp
|
||||
join_common.cpp
|
||||
loadMetadata.cpp
|
||||
sortBlock.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -19,8 +19,8 @@ SRCS(
|
||||
ASTCreateRowPolicyQuery.cpp
|
||||
ASTCreateSettingsProfileQuery.cpp
|
||||
ASTCreateUserQuery.cpp
|
||||
ASTDictionaryAttributeDeclaration.cpp
|
||||
ASTDictionary.cpp
|
||||
ASTDictionaryAttributeDeclaration.cpp
|
||||
ASTDropAccessEntityQuery.cpp
|
||||
ASTDropQuery.cpp
|
||||
ASTExpressionList.cpp
|
||||
@ -56,21 +56,17 @@ SRCS(
|
||||
ASTShowTablesQuery.cpp
|
||||
ASTSubquery.cpp
|
||||
ASTSystemQuery.cpp
|
||||
ASTTablesInSelectQuery.cpp
|
||||
ASTTTLElement.cpp
|
||||
ASTTablesInSelectQuery.cpp
|
||||
ASTUserNameWithHost.cpp
|
||||
ASTWithAlias.cpp
|
||||
ASTWithElement.cpp
|
||||
CommonParsers.cpp
|
||||
ExpressionElementParsers.cpp
|
||||
ExpressionListParsers.cpp
|
||||
formatAST.cpp
|
||||
formatSettingName.cpp
|
||||
IAST.cpp
|
||||
iostream_debug_helpers.cpp
|
||||
IParserBase.cpp
|
||||
Lexer.cpp
|
||||
makeASTForLogicalFunction.cpp
|
||||
MySQL/ASTAlterCommand.cpp
|
||||
MySQL/ASTAlterQuery.cpp
|
||||
MySQL/ASTCreateDefines.cpp
|
||||
@ -84,11 +80,6 @@ SRCS(
|
||||
MySQL/ASTDeclareReference.cpp
|
||||
MySQL/ASTDeclareSubPartition.cpp
|
||||
MySQL/ASTDeclareTableOptions.cpp
|
||||
obfuscateQueries.cpp
|
||||
parseDatabaseAndTableName.cpp
|
||||
parseIdentifierOrStringLiteral.cpp
|
||||
parseIntervalKind.cpp
|
||||
parseQuery.cpp
|
||||
ParserAlterQuery.cpp
|
||||
ParserCase.cpp
|
||||
ParserCheckQuery.cpp
|
||||
@ -100,8 +91,8 @@ SRCS(
|
||||
ParserCreateUserQuery.cpp
|
||||
ParserDataType.cpp
|
||||
ParserDescribeTableQuery.cpp
|
||||
ParserDictionaryAttributeDeclaration.cpp
|
||||
ParserDictionary.cpp
|
||||
ParserDictionaryAttributeDeclaration.cpp
|
||||
ParserDropAccessEntityQuery.cpp
|
||||
ParserDropQuery.cpp
|
||||
ParserExplainQuery.cpp
|
||||
@ -135,10 +126,19 @@ SRCS(
|
||||
ParserUserNameWithHost.cpp
|
||||
ParserWatchQuery.cpp
|
||||
ParserWithElement.cpp
|
||||
parseUserName.cpp
|
||||
queryToString.cpp
|
||||
QueryWithOutputSettingsPushDownVisitor.cpp
|
||||
TokenIterator.cpp
|
||||
formatAST.cpp
|
||||
formatSettingName.cpp
|
||||
iostream_debug_helpers.cpp
|
||||
makeASTForLogicalFunction.cpp
|
||||
obfuscateQueries.cpp
|
||||
parseDatabaseAndTableName.cpp
|
||||
parseIdentifierOrStringLiteral.cpp
|
||||
parseIntervalKind.cpp
|
||||
parseQuery.cpp
|
||||
parseUserName.cpp
|
||||
queryToString.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -19,11 +19,14 @@ SRCS(
|
||||
Executors/PullingPipelineExecutor.cpp
|
||||
ForkProcessor.cpp
|
||||
Formats/IInputFormat.cpp
|
||||
Formats/IOutputFormat.cpp
|
||||
Formats/IRowInputFormat.cpp
|
||||
Formats/IRowOutputFormat.cpp
|
||||
Formats/Impl/BinaryRowInputFormat.cpp
|
||||
Formats/Impl/BinaryRowOutputFormat.cpp
|
||||
Formats/Impl/ConstantExpressionTemplate.cpp
|
||||
Formats/Impl/CSVRowInputFormat.cpp
|
||||
Formats/Impl/CSVRowOutputFormat.cpp
|
||||
Formats/Impl/ConstantExpressionTemplate.cpp
|
||||
Formats/Impl/JSONAsStringRowInputFormat.cpp
|
||||
Formats/Impl/JSONCompactEachRowRowInputFormat.cpp
|
||||
Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp
|
||||
@ -49,19 +52,16 @@ SRCS(
|
||||
Formats/Impl/RawBLOBRowInputFormat.cpp
|
||||
Formats/Impl/RawBLOBRowOutputFormat.cpp
|
||||
Formats/Impl/RegexpRowInputFormat.cpp
|
||||
Formats/Impl/TSKVRowInputFormat.cpp
|
||||
Formats/Impl/TSKVRowOutputFormat.cpp
|
||||
Formats/Impl/TabSeparatedRowInputFormat.cpp
|
||||
Formats/Impl/TabSeparatedRowOutputFormat.cpp
|
||||
Formats/Impl/TemplateBlockOutputFormat.cpp
|
||||
Formats/Impl/TemplateRowInputFormat.cpp
|
||||
Formats/Impl/TSKVRowInputFormat.cpp
|
||||
Formats/Impl/TSKVRowOutputFormat.cpp
|
||||
Formats/Impl/ValuesBlockInputFormat.cpp
|
||||
Formats/Impl/ValuesRowOutputFormat.cpp
|
||||
Formats/Impl/VerticalRowOutputFormat.cpp
|
||||
Formats/Impl/XMLRowOutputFormat.cpp
|
||||
Formats/IOutputFormat.cpp
|
||||
Formats/IRowInputFormat.cpp
|
||||
Formats/IRowOutputFormat.cpp
|
||||
Formats/LazyOutputFormat.cpp
|
||||
Formats/OutputStreamToOutputFormat.cpp
|
||||
Formats/PullingOutputFormat.cpp
|
||||
@ -87,7 +87,6 @@ SRCS(
|
||||
OffsetTransform.cpp
|
||||
Pipe.cpp
|
||||
Port.cpp
|
||||
printPipeline.cpp
|
||||
QueryPipeline.cpp
|
||||
QueryPlan/AddingDelayedSourceStep.cpp
|
||||
QueryPlan/AggregatingStep.cpp
|
||||
@ -151,6 +150,7 @@ SRCS(
|
||||
Transforms/RollupTransform.cpp
|
||||
Transforms/SortingTransform.cpp
|
||||
Transforms/TotalsHavingTransform.cpp
|
||||
printPipeline.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -15,10 +15,8 @@ SRCS(
|
||||
ConstraintsDescription.cpp
|
||||
Distributed/DirectoryMonitor.cpp
|
||||
Distributed/DistributedBlockOutputStream.cpp
|
||||
extractKeyExpressionList.cpp
|
||||
getStructureOfRemoteTable.cpp
|
||||
IndicesDescription.cpp
|
||||
IStorage.cpp
|
||||
IndicesDescription.cpp
|
||||
JoinSettings.cpp
|
||||
KeyDescription.cpp
|
||||
LiveView/StorageLiveView.cpp
|
||||
@ -27,19 +25,15 @@ SRCS(
|
||||
MergeTree/AllMergeSelector.cpp
|
||||
MergeTree/BackgroundProcessingPool.cpp
|
||||
MergeTree/BoolMask.cpp
|
||||
MergeTree/checkDataPart.cpp
|
||||
MergeTree/DataPartsExchange.cpp
|
||||
MergeTree/EphemeralLockInZooKeeper.cpp
|
||||
MergeTree/IMergedBlockOutputStream.cpp
|
||||
MergeTree/IMergeTreeDataPart.cpp
|
||||
MergeTree/IMergeTreeDataPartWriter.cpp
|
||||
MergeTree/IMergeTreeReader.cpp
|
||||
MergeTree/IMergedBlockOutputStream.cpp
|
||||
MergeTree/KeyCondition.cpp
|
||||
MergeTree/LevelMergeSelector.cpp
|
||||
MergeTree/localBackup.cpp
|
||||
MergeTree/MergeAlgorithm.cpp
|
||||
MergeTree/MergedBlockOutputStream.cpp
|
||||
MergeTree/MergedColumnOnlyOutputStream.cpp
|
||||
MergeTree/MergeList.cpp
|
||||
MergeTree/MergeTreeBaseSelectProcessor.cpp
|
||||
MergeTree/MergeTreeBlockOutputStream.cpp
|
||||
@ -76,11 +70,11 @@ SRCS(
|
||||
MergeTree/MergeTreePartition.cpp
|
||||
MergeTree/MergeTreePartsMover.cpp
|
||||
MergeTree/MergeTreeRangeReader.cpp
|
||||
MergeTree/MergeTreeReadPool.cpp
|
||||
MergeTree/MergeTreeReaderCompact.cpp
|
||||
MergeTree/MergeTreeReaderInMemory.cpp
|
||||
MergeTree/MergeTreeReaderStream.cpp
|
||||
MergeTree/MergeTreeReaderWide.cpp
|
||||
MergeTree/MergeTreeReadPool.cpp
|
||||
MergeTree/MergeTreeReverseSelectProcessor.cpp
|
||||
MergeTree/MergeTreeSelectProcessor.cpp
|
||||
MergeTree/MergeTreeSequentialSource.cpp
|
||||
@ -89,7 +83,8 @@ SRCS(
|
||||
MergeTree/MergeTreeWhereOptimizer.cpp
|
||||
MergeTree/MergeTreeWriteAheadLog.cpp
|
||||
MergeTree/MergeType.cpp
|
||||
MergeTree/registerStorageMergeTree.cpp
|
||||
MergeTree/MergedBlockOutputStream.cpp
|
||||
MergeTree/MergedColumnOnlyOutputStream.cpp
|
||||
MergeTree/ReplicatedFetchList.cpp
|
||||
MergeTree/ReplicatedMergeTreeAddress.cpp
|
||||
MergeTree/ReplicatedMergeTreeAltersSequence.cpp
|
||||
@ -104,10 +99,12 @@ SRCS(
|
||||
MergeTree/ReplicatedMergeTreeTableMetadata.cpp
|
||||
MergeTree/SimpleMergeSelector.cpp
|
||||
MergeTree/TTLMergeSelector.cpp
|
||||
MergeTree/checkDataPart.cpp
|
||||
MergeTree/localBackup.cpp
|
||||
MergeTree/registerStorageMergeTree.cpp
|
||||
MutationCommands.cpp
|
||||
PartitionCommands.cpp
|
||||
ReadInOrderOptimizer.cpp
|
||||
registerStorages.cpp
|
||||
SelectQueryDescription.cpp
|
||||
SetSettings.cpp
|
||||
StorageBuffer.cpp
|
||||
@ -121,8 +118,8 @@ SRCS(
|
||||
StorageJoin.cpp
|
||||
StorageLog.cpp
|
||||
StorageLogSettings.cpp
|
||||
StorageMaterializedView.cpp
|
||||
StorageMaterializeMySQL.cpp
|
||||
StorageMaterializedView.cpp
|
||||
StorageMemory.cpp
|
||||
StorageMerge.cpp
|
||||
StorageMergeTree.cpp
|
||||
@ -137,7 +134,6 @@ SRCS(
|
||||
StorageValues.cpp
|
||||
StorageView.cpp
|
||||
StorageXDBC.cpp
|
||||
System/attachSystemTables.cpp
|
||||
System/StorageSystemAggregateFunctionCombinators.cpp
|
||||
System/StorageSystemAsynchronousMetrics.cpp
|
||||
System/StorageSystemBuildOptions.cpp
|
||||
@ -147,8 +143,8 @@ SRCS(
|
||||
System/StorageSystemContributors.cpp
|
||||
System/StorageSystemContributors.generated.cpp
|
||||
System/StorageSystemCurrentRoles.cpp
|
||||
System/StorageSystemDatabases.cpp
|
||||
System/StorageSystemDataTypeFamilies.cpp
|
||||
System/StorageSystemDatabases.cpp
|
||||
System/StorageSystemDetachedParts.cpp
|
||||
System/StorageSystemDictionaries.cpp
|
||||
System/StorageSystemDisks.cpp
|
||||
@ -161,22 +157,22 @@ SRCS(
|
||||
System/StorageSystemGrants.cpp
|
||||
System/StorageSystemGraphite.cpp
|
||||
System/StorageSystemMacros.cpp
|
||||
System/StorageSystemMerges.cpp
|
||||
System/StorageSystemMergeTreeSettings.cpp
|
||||
System/StorageSystemMerges.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/StorageSystemParts.cpp
|
||||
System/StorageSystemPrivileges.cpp
|
||||
System/StorageSystemProcesses.cpp
|
||||
System/StorageSystemQuotaLimits.cpp
|
||||
System/StorageSystemQuotaUsage.cpp
|
||||
System/StorageSystemQuotas.cpp
|
||||
System/StorageSystemQuotasUsage.cpp
|
||||
System/StorageSystemQuotaUsage.cpp
|
||||
System/StorageSystemReplicas.cpp
|
||||
System/StorageSystemReplicatedFetches.cpp
|
||||
System/StorageSystemReplicationQueue.cpp
|
||||
@ -195,9 +191,13 @@ SRCS(
|
||||
System/StorageSystemUsers.cpp
|
||||
System/StorageSystemZeros.cpp
|
||||
System/StorageSystemZooKeeper.cpp
|
||||
transformQueryForExternalDatabase.cpp
|
||||
System/attachSystemTables.cpp
|
||||
TTLDescription.cpp
|
||||
VirtualColumnUtils.cpp
|
||||
extractKeyExpressionList.cpp
|
||||
getStructureOfRemoteTable.cpp
|
||||
registerStorages.cpp
|
||||
transformQueryForExternalDatabase.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -10,8 +10,6 @@ SRCS(
|
||||
ITableFunction.cpp
|
||||
ITableFunctionFileLike.cpp
|
||||
ITableFunctionXDBC.cpp
|
||||
parseColumnsListForTableFunction.cpp
|
||||
registerTableFunctions.cpp
|
||||
TableFunctionFactory.cpp
|
||||
TableFunctionFile.cpp
|
||||
TableFunctionGenerateRandom.cpp
|
||||
@ -25,6 +23,8 @@ SRCS(
|
||||
TableFunctionValues.cpp
|
||||
TableFunctionView.cpp
|
||||
TableFunctionZeros.cpp
|
||||
parseColumnsListForTableFunction.cpp
|
||||
registerTableFunctions.cpp
|
||||
|
||||
)
|
||||
|
||||
|
@ -7,6 +7,9 @@
|
||||
ROOT_PATH=$(git rev-parse --show-toplevel)
|
||||
EXCLUDE_DIRS='build/|integration/|widechar_width/|glibc-compatibility/|memcpy/|consistent-hashing'
|
||||
|
||||
# Otherwise 'sort' behaves differently on Mac OS and also depends on locale.
|
||||
export LC_ALL=C
|
||||
|
||||
find "${ROOT_PATH}" -name 'ya.make.in' | while read path; do
|
||||
echo "# This file is generated automatically, do not edit. See 'ya.make.in' and use 'utils/generate-ya-make' to regenerate it." > "${path/.in/}"
|
||||
(cd $(dirname "${path}") && perl -pne 's/<\?(.+?)\?>/`$1`/e' < "${path}" >> "${path/.in/}")
|
||||
|
Loading…
Reference in New Issue
Block a user