Merge pull request #16700 from ClickHouse/better-arcadia

Improve Arcadia
This commit is contained in:
alexey-milovidov 2020-11-05 15:34:34 +03:00 committed by GitHub
commit 39cd1c0371
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
21 changed files with 250 additions and 229 deletions

View File

@ -35,25 +35,25 @@ PEERDIR(
CFLAGS(-g0) CFLAGS(-g0)
SRCS( SRCS(
argsToConfig.cpp
coverage.cpp
DateLUT.cpp DateLUT.cpp
DateLUTImpl.cpp DateLUTImpl.cpp
JSON.cpp
LineReader.cpp
StringRef.cpp
argsToConfig.cpp
coverage.cpp
demangle.cpp demangle.cpp
errnoToString.cpp errnoToString.cpp
getFQDNOrHostName.cpp getFQDNOrHostName.cpp
getMemoryAmount.cpp getMemoryAmount.cpp
getResource.cpp getResource.cpp
getThreadId.cpp getThreadId.cpp
JSON.cpp
LineReader.cpp
mremap.cpp mremap.cpp
phdr_cache.cpp phdr_cache.cpp
preciseExp10.cpp preciseExp10.cpp
setTerminalEcho.cpp setTerminalEcho.cpp
shift10.cpp shift10.cpp
sleep.cpp sleep.cpp
StringRef.cpp
terminalColors.cpp terminalColors.cpp
) )

View File

@ -27,14 +27,14 @@ SRCS(
LDAPClient.cpp LDAPClient.cpp
MemoryAccessStorage.cpp MemoryAccessStorage.cpp
MultipleAccessStorage.cpp MultipleAccessStorage.cpp
QuotaCache.cpp
Quota.cpp Quota.cpp
QuotaCache.cpp
QuotaUsage.cpp QuotaUsage.cpp
RoleCache.cpp
Role.cpp Role.cpp
RoleCache.cpp
RolesOrUsersSet.cpp RolesOrUsersSet.cpp
RowPolicyCache.cpp
RowPolicy.cpp RowPolicy.cpp
RowPolicyCache.cpp
SettingsConstraints.cpp SettingsConstraints.cpp
SettingsProfile.cpp SettingsProfile.cpp
SettingsProfileElement.cpp SettingsProfileElement.cpp

View File

@ -26,10 +26,10 @@ SRCS(
AggregateFunctionGroupUniqArray.cpp AggregateFunctionGroupUniqArray.cpp
AggregateFunctionHistogram.cpp AggregateFunctionHistogram.cpp
AggregateFunctionIf.cpp AggregateFunctionIf.cpp
AggregateFunctionMLMethod.cpp
AggregateFunctionMaxIntersections.cpp AggregateFunctionMaxIntersections.cpp
AggregateFunctionMerge.cpp AggregateFunctionMerge.cpp
AggregateFunctionMinMaxAny.cpp AggregateFunctionMinMaxAny.cpp
AggregateFunctionMLMethod.cpp
AggregateFunctionNull.cpp AggregateFunctionNull.cpp
AggregateFunctionOrFill.cpp AggregateFunctionOrFill.cpp
AggregateFunctionQuantile.cpp AggregateFunctionQuantile.cpp
@ -45,14 +45,14 @@ SRCS(
AggregateFunctionSumMap.cpp AggregateFunctionSumMap.cpp
AggregateFunctionTimeSeriesGroupSum.cpp AggregateFunctionTimeSeriesGroupSum.cpp
AggregateFunctionTopK.cpp AggregateFunctionTopK.cpp
AggregateFunctionUniqCombined.cpp
AggregateFunctionUniq.cpp AggregateFunctionUniq.cpp
AggregateFunctionUniqCombined.cpp
AggregateFunctionUniqUpTo.cpp AggregateFunctionUniqUpTo.cpp
AggregateFunctionWindowFunnel.cpp AggregateFunctionWindowFunnel.cpp
parseAggregateFunctionParameters.cpp
registerAggregateFunctions.cpp
UniqCombinedBiasData.cpp UniqCombinedBiasData.cpp
UniqVariadicHash.cpp UniqVariadicHash.cpp
parseAggregateFunctionParameters.cpp
registerAggregateFunctions.cpp
) )

View File

@ -13,7 +13,6 @@ PEERDIR(
contrib/libs/pdqsort contrib/libs/pdqsort
) )
SRCS( SRCS(
Collator.cpp Collator.cpp
ColumnAggregateFunction.cpp ColumnAggregateFunction.cpp
@ -24,13 +23,13 @@ SRCS(
ColumnFunction.cpp ColumnFunction.cpp
ColumnLowCardinality.cpp ColumnLowCardinality.cpp
ColumnNullable.cpp ColumnNullable.cpp
ColumnsCommon.cpp
ColumnString.cpp ColumnString.cpp
ColumnTuple.cpp ColumnTuple.cpp
ColumnVector.cpp ColumnVector.cpp
ColumnsCommon.cpp
FilterDescription.cpp FilterDescription.cpp
getLeastSuperColumn.cpp
IColumn.cpp IColumn.cpp
getLeastSuperColumn.cpp
) )

19
src/Columns/ya.make.in Normal file
View 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()

View File

@ -26,60 +26,36 @@ SRCS(
ActionLock.cpp ActionLock.cpp
AlignedBuffer.cpp AlignedBuffer.cpp
Allocator.cpp Allocator.cpp
checkStackSize.cpp
clearPasswordFromCommandLine.cpp
ClickHouseRevision.cpp ClickHouseRevision.cpp
Config/AbstractConfigurationComparison.cpp Config/AbstractConfigurationComparison.cpp
Config/ConfigProcessor.cpp Config/ConfigProcessor.cpp
Config/configReadClient.cpp
Config/ConfigReloader.cpp Config/ConfigReloader.cpp
createHardLink.cpp Config/configReadClient.cpp
CurrentMetrics.cpp CurrentMetrics.cpp
CurrentThread.cpp CurrentThread.cpp
DNSResolver.cpp DNSResolver.cpp
Dwarf.cpp Dwarf.cpp
Elf.cpp Elf.cpp
ErrorCodes.cpp ErrorCodes.cpp
escapeForFileName.cpp
Exception.cpp Exception.cpp
ExternalLoaderStatus.cpp ExternalLoaderStatus.cpp
FieldVisitors.cpp FieldVisitors.cpp
FileChecker.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 IPv6ToBinary.cpp
isLocalAddress.cpp IntervalKind.cpp
Macros.cpp Macros.cpp
malloc.cpp
MemoryStatisticsOS.cpp MemoryStatisticsOS.cpp
MemoryTracker.cpp MemoryTracker.cpp
new_delete.cpp
OpenSSLHelpers.cpp OpenSSLHelpers.cpp
OptimizedRegularExpression.cpp OptimizedRegularExpression.cpp
parseAddress.cpp
parseGlobs.cpp
parseRemoteDescription.cpp
PipeFDs.cpp
PODArray.cpp PODArray.cpp
PipeFDs.cpp
ProcfsMetricsProvider.cpp ProcfsMetricsProvider.cpp
ProfileEvents.cpp ProfileEvents.cpp
QueryProfiler.cpp QueryProfiler.cpp
quoteString.cpp
randomSeed.cpp
remapExecutable.cpp
RemoteHostFilter.cpp
renameat2.cpp
RWLock.cpp RWLock.cpp
RemoteHostFilter.cpp
SensitiveDataMasker.cpp SensitiveDataMasker.cpp
setThreadName.cpp
SettingsChanges.cpp SettingsChanges.cpp
SharedLibrary.cpp SharedLibrary.cpp
ShellCommand.cpp ShellCommand.cpp
@ -93,19 +69,43 @@ SRCS(
TaskStatsInfoGetter.cpp TaskStatsInfoGetter.cpp
TerminalSize.cpp TerminalSize.cpp
ThreadFuzzer.cpp ThreadFuzzer.cpp
thread_local_rng.cpp
ThreadPool.cpp ThreadPool.cpp
ThreadProfileEvents.cpp ThreadProfileEvents.cpp
ThreadStatus.cpp ThreadStatus.cpp
TraceCollector.cpp TraceCollector.cpp
UnicodeBar.cpp
UTF8Helpers.cpp UTF8Helpers.cpp
UnicodeBar.cpp
WeakHash.cpp WeakHash.cpp
ZooKeeper/IKeeper.cpp ZooKeeper/IKeeper.cpp
ZooKeeper/TestKeeper.cpp ZooKeeper/TestKeeper.cpp
ZooKeeper/ZooKeeper.cpp ZooKeeper/ZooKeeper.cpp
ZooKeeper/ZooKeeperImpl.cpp ZooKeeper/ZooKeeperImpl.cpp
ZooKeeper/ZooKeeperNodeCache.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
) )

View File

@ -15,8 +15,8 @@ PEERDIR(
SRCS( SRCS(
CachedCompressedReadBuffer.cpp CachedCompressedReadBuffer.cpp
CompressedReadBufferBase.cpp
CompressedReadBuffer.cpp CompressedReadBuffer.cpp
CompressedReadBufferBase.cpp
CompressedReadBufferFromFile.cpp CompressedReadBufferFromFile.cpp
CompressedWriteBuffer.cpp CompressedWriteBuffer.cpp
CompressionCodecDelta.cpp CompressionCodecDelta.cpp
@ -28,9 +28,9 @@ SRCS(
CompressionCodecT64.cpp CompressionCodecT64.cpp
CompressionCodecZSTD.cpp CompressionCodecZSTD.cpp
CompressionFactory.cpp CompressionFactory.cpp
getCompressionCodecForFile.cpp
ICompressionCodec.cpp ICompressionCodec.cpp
LZ4_decompress_faster.cpp LZ4_decompress_faster.cpp
getCompressionCodecForFile.cpp
) )

View File

@ -17,7 +17,6 @@ SRCS(
ExternalResultDescription.cpp ExternalResultDescription.cpp
ExternalTable.cpp ExternalTable.cpp
Field.cpp Field.cpp
iostream_debug_helpers.cpp
MySQL/Authentication.cpp MySQL/Authentication.cpp
MySQL/IMySQLReadPacket.cpp MySQL/IMySQLReadPacket.cpp
MySQL/IMySQLWritePacket.cpp MySQL/IMySQLWritePacket.cpp
@ -35,6 +34,7 @@ SRCS(
SettingsEnums.cpp SettingsEnums.cpp
SettingsFields.cpp SettingsFields.cpp
SortDescription.cpp SortDescription.cpp
iostream_debug_helpers.cpp
) )

View File

@ -19,21 +19,17 @@ SRCS(
CheckSortedBlockInputStream.cpp CheckSortedBlockInputStream.cpp
ColumnGathererStream.cpp ColumnGathererStream.cpp
ConvertingBlockInputStream.cpp ConvertingBlockInputStream.cpp
copyData.cpp
CountingBlockOutputStream.cpp CountingBlockOutputStream.cpp
DistinctSortedBlockInputStream.cpp DistinctSortedBlockInputStream.cpp
ExecutionSpeedLimits.cpp ExecutionSpeedLimits.cpp
ExpressionBlockInputStream.cpp ExpressionBlockInputStream.cpp
finalizeBlock.cpp
IBlockInputStream.cpp IBlockInputStream.cpp
InputStreamFromASTInsertQuery.cpp InputStreamFromASTInsertQuery.cpp
InternalTextLogsRowOutputStream.cpp InternalTextLogsRowOutputStream.cpp
LimitBlockInputStream.cpp LimitBlockInputStream.cpp
materializeBlock.cpp
MaterializingBlockInputStream.cpp MaterializingBlockInputStream.cpp
MergingSortedBlockInputStream.cpp MergingSortedBlockInputStream.cpp
MongoDBBlockInputStream.cpp MongoDBBlockInputStream.cpp
narrowBlockInputStreams.cpp
NativeBlockInputStream.cpp NativeBlockInputStream.cpp
NativeBlockOutputStream.cpp NativeBlockOutputStream.cpp
ParallelParsingBlockInputStream.cpp ParallelParsingBlockInputStream.cpp
@ -46,6 +42,10 @@ SRCS(
SquashingBlockOutputStream.cpp SquashingBlockOutputStream.cpp
SquashingTransform.cpp SquashingTransform.cpp
TTLBlockInputStream.cpp TTLBlockInputStream.cpp
copyData.cpp
finalizeBlock.cpp
materializeBlock.cpp
narrowBlockInputStreams.cpp
) )

View File

@ -8,7 +8,6 @@ PEERDIR(
SRCS( SRCS(
convertMySQLDataType.cpp
DataTypeAggregateFunction.cpp DataTypeAggregateFunction.cpp
DataTypeArray.cpp DataTypeArray.cpp
DataTypeCustomGeo.cpp DataTypeCustomGeo.cpp
@ -16,8 +15,8 @@ SRCS(
DataTypeCustomSimpleAggregateFunction.cpp DataTypeCustomSimpleAggregateFunction.cpp
DataTypeCustomSimpleTextSerialization.cpp DataTypeCustomSimpleTextSerialization.cpp
DataTypeDate.cpp DataTypeDate.cpp
DataTypeDateTime64.cpp
DataTypeDateTime.cpp DataTypeDateTime.cpp
DataTypeDateTime64.cpp
DataTypeDecimalBase.cpp DataTypeDecimalBase.cpp
DataTypeEnum.cpp DataTypeEnum.cpp
DataTypeFactory.cpp DataTypeFactory.cpp
@ -29,16 +28,17 @@ SRCS(
DataTypeNothing.cpp DataTypeNothing.cpp
DataTypeNullable.cpp DataTypeNullable.cpp
DataTypeNumberBase.cpp DataTypeNumberBase.cpp
DataTypesDecimal.cpp
DataTypesNumber.cpp
DataTypeString.cpp DataTypeString.cpp
DataTypeTuple.cpp DataTypeTuple.cpp
DataTypeUUID.cpp DataTypeUUID.cpp
DataTypesDecimal.cpp
DataTypesNumber.cpp
FieldToDataType.cpp FieldToDataType.cpp
getLeastSupertype.cpp
getMostSubtype.cpp
IDataType.cpp IDataType.cpp
NestedUtils.cpp NestedUtils.cpp
convertMySQLDataType.cpp
getLeastSupertype.cpp
getMostSubtype.cpp
registerDataTypeDateTime.cpp registerDataTypeDateTime.cpp
) )

View File

@ -14,8 +14,8 @@ SRCS(
DatabaseMemory.cpp DatabaseMemory.cpp
DatabaseOnDisk.cpp DatabaseOnDisk.cpp
DatabaseOrdinary.cpp DatabaseOrdinary.cpp
DatabasesCommon.cpp
DatabaseWithDictionaries.cpp DatabaseWithDictionaries.cpp
DatabasesCommon.cpp
MySQL/ConnectionMySQLSettings.cpp MySQL/ConnectionMySQLSettings.cpp
MySQL/DatabaseConnectionMySQL.cpp MySQL/DatabaseConnectionMySQL.cpp
MySQL/DatabaseMaterializeMySQL.cpp MySQL/DatabaseMaterializeMySQL.cpp

View File

@ -37,11 +37,11 @@ SRCS(
DictionarySourceHelpers.cpp DictionarySourceHelpers.cpp
DictionaryStructure.cpp DictionaryStructure.cpp
DirectDictionary.cpp DirectDictionary.cpp
Embedded/GeoDictionariesLoader.cpp
Embedded/GeodataProviders/HierarchiesProvider.cpp Embedded/GeodataProviders/HierarchiesProvider.cpp
Embedded/GeodataProviders/HierarchyFormatReader.cpp Embedded/GeodataProviders/HierarchyFormatReader.cpp
Embedded/GeodataProviders/NamesFormatReader.cpp Embedded/GeodataProviders/NamesFormatReader.cpp
Embedded/GeodataProviders/NamesProvider.cpp Embedded/GeodataProviders/NamesProvider.cpp
Embedded/GeoDictionariesLoader.cpp
Embedded/RegionsHierarchies.cpp Embedded/RegionsHierarchies.cpp
Embedded/RegionsHierarchy.cpp Embedded/RegionsHierarchy.cpp
Embedded/RegionsNames.cpp Embedded/RegionsNames.cpp
@ -49,9 +49,8 @@ SRCS(
ExternalQueryBuilder.cpp ExternalQueryBuilder.cpp
FileDictionarySource.cpp FileDictionarySource.cpp
FlatDictionary.cpp FlatDictionary.cpp
getDictionaryConfigurationFromAST.cpp
HashedDictionary.cpp
HTTPDictionarySource.cpp HTTPDictionarySource.cpp
HashedDictionary.cpp
LibraryDictionarySource.cpp LibraryDictionarySource.cpp
LibraryDictionarySourceExternal.cpp LibraryDictionarySourceExternal.cpp
MongoDBDictionarySource.cpp MongoDBDictionarySource.cpp
@ -60,14 +59,15 @@ SRCS(
PolygonDictionaryImplementations.cpp PolygonDictionaryImplementations.cpp
PolygonDictionaryUtils.cpp PolygonDictionaryUtils.cpp
RangeHashedDictionary.cpp RangeHashedDictionary.cpp
readInvalidateQuery.cpp
RedisBlockInputStream.cpp RedisBlockInputStream.cpp
RedisDictionarySource.cpp RedisDictionarySource.cpp
registerDictionaries.cpp
SSDCacheDictionary.cpp SSDCacheDictionary.cpp
SSDComplexKeyCacheDictionary.cpp SSDComplexKeyCacheDictionary.cpp
writeParenthesisedString.cpp
XDBCDictionarySource.cpp XDBCDictionarySource.cpp
getDictionaryConfigurationFromAST.cpp
readInvalidateQuery.cpp
registerDictionaries.cpp
writeParenthesisedString.cpp
) )

View File

@ -7,7 +7,6 @@ PEERDIR(
SRCS( SRCS(
createVolume.cpp
DiskCacheWrapper.cpp DiskCacheWrapper.cpp
DiskDecorator.cpp DiskDecorator.cpp
DiskFactory.cpp DiskFactory.cpp
@ -16,11 +15,12 @@ SRCS(
DiskSelector.cpp DiskSelector.cpp
IDisk.cpp IDisk.cpp
IVolume.cpp IVolume.cpp
registerDisks.cpp
SingleDiskVolume.cpp SingleDiskVolume.cpp
StoragePolicy.cpp StoragePolicy.cpp
VolumeJBOD.cpp VolumeJBOD.cpp
VolumeRAID1.cpp VolumeRAID1.cpp
createVolume.cpp
registerDisks.cpp
) )

View File

@ -34,6 +34,70 @@ PEERDIR(
# "Arcadia" build is slightly deficient. It lacks many libraries that we need. # "Arcadia" build is slightly deficient. It lacks many libraries that we need.
SRCS( 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 abs.cpp
acos.cpp acos.cpp
addDays.cpp addDays.cpp
@ -41,20 +105,20 @@ SRCS(
addMinutes.cpp addMinutes.cpp
addMonths.cpp addMonths.cpp
addQuarters.cpp addQuarters.cpp
addressToLine.cpp
addressToSymbol.cpp
addSeconds.cpp addSeconds.cpp
addWeeks.cpp addWeeks.cpp
addYears.cpp addYears.cpp
addressToLine.cpp
addressToSymbol.cpp
aes_decrypt_mysql.cpp aes_decrypt_mysql.cpp
aes_encrypt_mysql.cpp aes_encrypt_mysql.cpp
appendTrailingCharIfAbsent.cpp appendTrailingCharIfAbsent.cpp
array/arrayAll.cpp array/array.cpp
array/arrayAUC.cpp array/arrayAUC.cpp
array/arrayAll.cpp
array/arrayCompact.cpp array/arrayCompact.cpp
array/arrayConcat.cpp array/arrayConcat.cpp
array/arrayCount.cpp array/arrayCount.cpp
array/array.cpp
array/arrayCumSum.cpp array/arrayCumSum.cpp
array/arrayCumSumNonNegative.cpp array/arrayCumSumNonNegative.cpp
array/arrayDifference.cpp array/arrayDifference.cpp
@ -93,9 +157,9 @@ SRCS(
array/countEqual.cpp array/countEqual.cpp
array/emptyArray.cpp array/emptyArray.cpp
array/emptyArrayToSingle.cpp array/emptyArrayToSingle.cpp
array/has.cpp
array/hasAll.cpp array/hasAll.cpp
array/hasAny.cpp array/hasAny.cpp
array/has.cpp
array/hasSubstr.cpp array/hasSubstr.cpp
array/indexOf.cpp array/indexOf.cpp
array/length.cpp array/length.cpp
@ -113,7 +177,6 @@ SRCS(
bitBoolMaskAnd.cpp bitBoolMaskAnd.cpp
bitBoolMaskOr.cpp bitBoolMaskOr.cpp
bitCount.cpp bitCount.cpp
bitmaskToList.cpp
bitNot.cpp bitNot.cpp
bitOr.cpp bitOr.cpp
bitRotateLeft.cpp bitRotateLeft.cpp
@ -121,11 +184,12 @@ SRCS(
bitShiftLeft.cpp bitShiftLeft.cpp
bitShiftRight.cpp bitShiftRight.cpp
bitSwapLastTwo.cpp bitSwapLastTwo.cpp
bitTest.cpp
bitTestAll.cpp bitTestAll.cpp
bitTestAny.cpp bitTestAny.cpp
bitTest.cpp
bitWrapperFunc.cpp bitWrapperFunc.cpp
bitXor.cpp bitXor.cpp
bitmaskToList.cpp
blockNumber.cpp blockNumber.cpp
blockSerializedSize.cpp blockSerializedSize.cpp
blockSize.cpp blockSize.cpp
@ -137,7 +201,6 @@ SRCS(
convertCharset.cpp convertCharset.cpp
cos.cpp cos.cpp
countDigits.cpp countDigits.cpp
CRC.cpp
currentDatabase.cpp currentDatabase.cpp
currentUser.cpp currentUser.cpp
dateDiff.cpp dateDiff.cpp
@ -153,16 +216,16 @@ SRCS(
encrypt.cpp encrypt.cpp
endsWith.cpp endsWith.cpp
equals.cpp equals.cpp
erfc.cpp
erf.cpp erf.cpp
erfc.cpp
errorCodeToName.cpp errorCodeToName.cpp
evalMLMethod.cpp evalMLMethod.cpp
exp.cpp
exp10.cpp exp10.cpp
exp2.cpp exp2.cpp
exp.cpp extract.cpp
extractAllGroupsHorizontal.cpp extractAllGroupsHorizontal.cpp
extractAllGroupsVertical.cpp extractAllGroupsVertical.cpp
extract.cpp
extractGroups.cpp extractGroups.cpp
extractTimeZoneFromFunctionArguments.cpp extractTimeZoneFromFunctionArguments.cpp
filesystem.cpp filesystem.cpp
@ -176,47 +239,13 @@ SRCS(
fromUnixTimestamp64Micro.cpp fromUnixTimestamp64Micro.cpp
fromUnixTimestamp64Milli.cpp fromUnixTimestamp64Milli.cpp
fromUnixTimestamp64Nano.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 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 gcd.cpp
generateUUIDv4.cpp generateUUIDv4.cpp
GeoHash.cpp geoToH3.cpp
geohashDecode.cpp geohashDecode.cpp
geohashEncode.cpp geohashEncode.cpp
geohashesInBox.cpp geohashesInBox.cpp
geoToH3.cpp
getMacro.cpp getMacro.cpp
getScalar.cpp getScalar.cpp
getSetting.cpp getSetting.cpp
@ -233,20 +262,19 @@ SRCS(
h3HexAreaM2.cpp h3HexAreaM2.cpp
h3IndexesAreNeighbors.cpp h3IndexesAreNeighbors.cpp
h3IsValid.cpp h3IsValid.cpp
h3kRing.cpp
h3ToChildren.cpp h3ToChildren.cpp
h3ToParent.cpp h3ToParent.cpp
h3ToString.cpp h3ToString.cpp
h3kRing.cpp
hasColumnInTable.cpp hasColumnInTable.cpp
hasThreadFuzzer.cpp hasThreadFuzzer.cpp
hasTokenCaseInsensitive.cpp
hasToken.cpp hasToken.cpp
hasTokenCaseInsensitive.cpp
hostName.cpp hostName.cpp
identity.cpp identity.cpp
if.cpp if.cpp
ifNotFinite.cpp ifNotFinite.cpp
ifNull.cpp ifNull.cpp
IFunction.cpp
ignore.cpp ignore.cpp
ilike.cpp ilike.cpp
in.cpp in.cpp
@ -272,9 +300,9 @@ SRCS(
lessOrEquals.cpp lessOrEquals.cpp
lgamma.cpp lgamma.cpp
like.cpp like.cpp
log.cpp
log10.cpp log10.cpp
log2.cpp log2.cpp
log.cpp
logTrace.cpp logTrace.cpp
lowCardinalityIndices.cpp lowCardinalityIndices.cpp
lowCardinalityKeys.cpp lowCardinalityKeys.cpp
@ -292,56 +320,56 @@ SRCS(
multiMatchAllIndices.cpp multiMatchAllIndices.cpp
multiMatchAny.cpp multiMatchAny.cpp
multiMatchAnyIndex.cpp multiMatchAnyIndex.cpp
multiply.cpp multiSearchAllPositions.cpp
multiSearchAllPositionsCaseInsensitive.cpp multiSearchAllPositionsCaseInsensitive.cpp
multiSearchAllPositionsCaseInsensitiveUTF8.cpp multiSearchAllPositionsCaseInsensitiveUTF8.cpp
multiSearchAllPositions.cpp
multiSearchAllPositionsUTF8.cpp multiSearchAllPositionsUTF8.cpp
multiSearchAny.cpp
multiSearchAnyCaseInsensitive.cpp multiSearchAnyCaseInsensitive.cpp
multiSearchAnyCaseInsensitiveUTF8.cpp multiSearchAnyCaseInsensitiveUTF8.cpp
multiSearchAny.cpp
multiSearchAnyUTF8.cpp multiSearchAnyUTF8.cpp
multiSearchFirstIndex.cpp
multiSearchFirstIndexCaseInsensitive.cpp multiSearchFirstIndexCaseInsensitive.cpp
multiSearchFirstIndexCaseInsensitiveUTF8.cpp multiSearchFirstIndexCaseInsensitiveUTF8.cpp
multiSearchFirstIndex.cpp
multiSearchFirstIndexUTF8.cpp multiSearchFirstIndexUTF8.cpp
multiSearchFirstPosition.cpp
multiSearchFirstPositionCaseInsensitive.cpp multiSearchFirstPositionCaseInsensitive.cpp
multiSearchFirstPositionCaseInsensitiveUTF8.cpp multiSearchFirstPositionCaseInsensitiveUTF8.cpp
multiSearchFirstPosition.cpp
multiSearchFirstPositionUTF8.cpp multiSearchFirstPositionUTF8.cpp
multiply.cpp
negate.cpp negate.cpp
neighbor.cpp neighbor.cpp
normalizedQueryHash.cpp
normalizeQuery.cpp normalizeQuery.cpp
normalizedQueryHash.cpp
notEmpty.cpp notEmpty.cpp
notEquals.cpp notEquals.cpp
notILike.cpp notILike.cpp
notLike.cpp notLike.cpp
now64.cpp
now.cpp now.cpp
now64.cpp
nullIf.cpp nullIf.cpp
pi.cpp pi.cpp
plus.cpp plus.cpp
pointInEllipses.cpp pointInEllipses.cpp
pointInPolygon.cpp pointInPolygon.cpp
position.cpp
positionCaseInsensitive.cpp positionCaseInsensitive.cpp
positionCaseInsensitiveUTF8.cpp positionCaseInsensitiveUTF8.cpp
position.cpp
positionUTF8.cpp positionUTF8.cpp
pow.cpp pow.cpp
rand.cpp
rand64.cpp rand64.cpp
randConstant.cpp randConstant.cpp
rand.cpp
randomFixedString.cpp randomFixedString.cpp
randomPrintableASCII.cpp randomPrintableASCII.cpp
randomString.cpp randomString.cpp
randomStringUTF8.cpp randomStringUTF8.cpp
regexpQuoteMeta.cpp regexpQuoteMeta.cpp
registerFunctions.cpp
registerFunctionsArithmetic.cpp registerFunctionsArithmetic.cpp
registerFunctionsComparison.cpp registerFunctionsComparison.cpp
registerFunctionsConditional.cpp registerFunctionsConditional.cpp
registerFunctionsConsistentHashing.cpp registerFunctionsConsistentHashing.cpp
registerFunctions.cpp
registerFunctionsDateTime.cpp registerFunctionsDateTime.cpp
registerFunctionsFormatting.cpp registerFunctionsFormatting.cpp
registerFunctionsGeo.cpp registerFunctionsGeo.cpp
@ -395,7 +423,6 @@ SRCS(
subtractYears.cpp subtractYears.cpp
tan.cpp tan.cpp
tanh.cpp tanh.cpp
TargetSpecific.cpp
tgamma.cpp tgamma.cpp
throwIf.cpp throwIf.cpp
tid.cpp tid.cpp
@ -404,7 +431,6 @@ SRCS(
timezone.cpp timezone.cpp
toColumnTypeName.cpp toColumnTypeName.cpp
toCustomWeek.cpp toCustomWeek.cpp
today.cpp
toDayOfMonth.cpp toDayOfMonth.cpp
toDayOfWeek.cpp toDayOfWeek.cpp
toDayOfYear.cpp toDayOfYear.cpp
@ -431,8 +457,8 @@ SRCS(
toStartOfFifteenMinutes.cpp toStartOfFifteenMinutes.cpp
toStartOfFiveMinute.cpp toStartOfFiveMinute.cpp
toStartOfHour.cpp toStartOfHour.cpp
toStartOfInterval.cpp
toStartOfISOYear.cpp toStartOfISOYear.cpp
toStartOfInterval.cpp
toStartOfMinute.cpp toStartOfMinute.cpp
toStartOfMonth.cpp toStartOfMonth.cpp
toStartOfQuarter.cpp toStartOfQuarter.cpp
@ -446,10 +472,11 @@ SRCS(
toUnixTimestamp64Milli.cpp toUnixTimestamp64Milli.cpp
toUnixTimestamp64Nano.cpp toUnixTimestamp64Nano.cpp
toValidUTF8.cpp toValidUTF8.cpp
toYear.cpp
toYYYYMM.cpp toYYYYMM.cpp
toYYYYMMDD.cpp toYYYYMMDD.cpp
toYYYYMMDDhhmmss.cpp toYYYYMMDDhhmmss.cpp
toYear.cpp
today.cpp
transform.cpp transform.cpp
trap.cpp trap.cpp
trim.cpp trim.cpp
@ -459,33 +486,6 @@ SRCS(
upper.cpp upper.cpp
upperUTF8.cpp upperUTF8.cpp
uptime.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 version.cpp
visibleWidth.cpp visibleWidth.cpp
visitParamExtractBool.cpp visitParamExtractBool.cpp

View File

@ -10,45 +10,40 @@ PEERDIR(
SRCS( SRCS(
AIOContextPool.cpp
AIO.cpp AIO.cpp
AIOContextPool.cpp
BrotliReadBuffer.cpp BrotliReadBuffer.cpp
BrotliWriteBuffer.cpp BrotliWriteBuffer.cpp
CascadeWriteBuffer.cpp CascadeWriteBuffer.cpp
CompressionMethod.cpp CompressionMethod.cpp
copyData.cpp
createReadBufferFromFileBase.cpp
createWriteBufferFromFileBase.cpp
DoubleConverter.cpp DoubleConverter.cpp
HTTPCommon.cpp
HashingWriteBuffer.cpp HashingWriteBuffer.cpp
HexWriteBuffer.cpp HexWriteBuffer.cpp
HTTPCommon.cpp
LimitReadBuffer.cpp LimitReadBuffer.cpp
MemoryReadWriteBuffer.cpp
MMapReadBufferFromFile.cpp MMapReadBufferFromFile.cpp
MMapReadBufferFromFileDescriptor.cpp MMapReadBufferFromFileDescriptor.cpp
MemoryReadWriteBuffer.cpp
MySQLBinlogEventReadBuffer.cpp MySQLBinlogEventReadBuffer.cpp
MySQLPacketPayloadReadBuffer.cpp MySQLPacketPayloadReadBuffer.cpp
MySQLPacketPayloadWriteBuffer.cpp MySQLPacketPayloadWriteBuffer.cpp
NullWriteBuffer.cpp NullWriteBuffer.cpp
parseDateTimeBestEffort.cpp
PeekableReadBuffer.cpp PeekableReadBuffer.cpp
Progress.cpp Progress.cpp
ReadBufferAIO.cpp ReadBufferAIO.cpp
ReadBufferFromFileBase.cpp
ReadBufferFromFile.cpp ReadBufferFromFile.cpp
ReadBufferFromFileBase.cpp
ReadBufferFromFileDescriptor.cpp ReadBufferFromFileDescriptor.cpp
ReadBufferFromIStream.cpp ReadBufferFromIStream.cpp
ReadBufferFromMemory.cpp ReadBufferFromMemory.cpp
ReadBufferFromPocoSocket.cpp ReadBufferFromPocoSocket.cpp
readFloatText.cpp
ReadHelpers.cpp ReadHelpers.cpp
ReadWriteBufferFromHTTP.cpp ReadWriteBufferFromHTTP.cpp
SeekAvoidingReadBuffer.cpp SeekAvoidingReadBuffer.cpp
UseSSL.cpp UseSSL.cpp
WriteBufferAIO.cpp WriteBufferAIO.cpp
WriteBufferFromFileBase.cpp
WriteBufferFromFile.cpp WriteBufferFromFile.cpp
WriteBufferFromFileBase.cpp
WriteBufferFromFileDescriptor.cpp WriteBufferFromFileDescriptor.cpp
WriteBufferFromFileDescriptorDiscardOnFailure.cpp WriteBufferFromFileDescriptorDiscardOnFailure.cpp
WriteBufferFromHTTP.cpp WriteBufferFromHTTP.cpp
@ -60,6 +55,11 @@ SRCS(
WriteHelpers.cpp WriteHelpers.cpp
ZlibDeflatingWriteBuffer.cpp ZlibDeflatingWriteBuffer.cpp
ZlibInflatingReadBuffer.cpp ZlibInflatingReadBuffer.cpp
copyData.cpp
createReadBufferFromFileBase.cpp
createWriteBufferFromFileBase.cpp
parseDateTimeBestEffort.cpp
readFloatText.cpp
) )

View File

@ -18,8 +18,6 @@ NO_COMPILER_WARNINGS()
SRCS( SRCS(
ActionLocksManager.cpp ActionLocksManager.cpp
ActionsVisitor.cpp ActionsVisitor.cpp
addMissingDefaults.cpp
addTypeConversionToAST.cpp
AggregateDescription.cpp AggregateDescription.cpp
Aggregator.cpp Aggregator.cpp
ApplyWithAliasVisitor.cpp ApplyWithAliasVisitor.cpp
@ -30,26 +28,21 @@ SRCS(
AsynchronousMetricLog.cpp AsynchronousMetricLog.cpp
AsynchronousMetrics.cpp AsynchronousMetrics.cpp
BloomFilter.cpp BloomFilter.cpp
castColumn.cpp
CatBoostModel.cpp CatBoostModel.cpp
ClientInfo.cpp ClientInfo.cpp
Cluster.cpp Cluster.cpp
ClusterProxy/executeQuery.cpp
ClusterProxy/SelectStreamFactory.cpp ClusterProxy/SelectStreamFactory.cpp
ClusterProxy/executeQuery.cpp
CollectJoinOnKeysVisitor.cpp CollectJoinOnKeysVisitor.cpp
Context.cpp Context.cpp
convertFieldToType.cpp
CrashLog.cpp CrashLog.cpp
createBlockSelector.cpp
CrossToInnerJoinVisitor.cpp CrossToInnerJoinVisitor.cpp
DDLWorker.cpp
DNSCacheUpdater.cpp
DatabaseAndTableWithAlias.cpp DatabaseAndTableWithAlias.cpp
DatabaseCatalog.cpp DatabaseCatalog.cpp
DDLWorker.cpp
DictionaryReader.cpp DictionaryReader.cpp
DNSCacheUpdater.cpp
EmbeddedDictionaries.cpp EmbeddedDictionaries.cpp
evaluateConstantExpression.cpp
executeQuery.cpp
ExecuteScalarSubqueriesVisitor.cpp ExecuteScalarSubqueriesVisitor.cpp
ExpressionActions.cpp ExpressionActions.cpp
ExpressionAnalyzer.cpp ExpressionAnalyzer.cpp
@ -61,14 +54,10 @@ SRCS(
ExternalModelsLoader.cpp ExternalModelsLoader.cpp
ExtractExpressionInfoVisitor.cpp ExtractExpressionInfoVisitor.cpp
FillingRow.cpp FillingRow.cpp
getClusterName.cpp
getHeaderForProcessingStage.cpp
getTableExpressions.cpp
HashJoin.cpp HashJoin.cpp
IdentifierSemantic.cpp
IExternalLoadable.cpp IExternalLoadable.cpp
IdentifierSemantic.cpp
InJoinSubqueriesPreprocessor.cpp InJoinSubqueriesPreprocessor.cpp
inplaceBlockConversions.cpp
InternalTextLogsQueue.cpp InternalTextLogsQueue.cpp
InterpreterAlterQuery.cpp InterpreterAlterQuery.cpp
InterpreterCheckQuery.cpp InterpreterCheckQuery.cpp
@ -105,12 +94,9 @@ SRCS(
InterpreterSystemQuery.cpp InterpreterSystemQuery.cpp
InterpreterUseQuery.cpp InterpreterUseQuery.cpp
InterpreterWatchQuery.cpp InterpreterWatchQuery.cpp
interpretSubquery.cpp
join_common.cpp
JoinedTables.cpp
JoinSwitcher.cpp JoinSwitcher.cpp
JoinToSubqueryTransformVisitor.cpp JoinToSubqueryTransformVisitor.cpp
loadMetadata.cpp JoinedTables.cpp
LogicalExpressionsOptimizer.cpp LogicalExpressionsOptimizer.cpp
MarkTableIdentifiersVisitor.cpp MarkTableIdentifiersVisitor.cpp
MergeJoin.cpp MergeJoin.cpp
@ -140,7 +126,6 @@ SRCS(
RowRefs.cpp RowRefs.cpp
Set.cpp Set.cpp
SetVariants.cpp SetVariants.cpp
sortBlock.cpp
SortedBlocksWriter.cpp SortedBlocksWriter.cpp
StorageID.cpp StorageID.cpp
SubqueryForSet.cpp SubqueryForSet.cpp
@ -153,6 +138,21 @@ SRCS(
TranslateQualifiedNamesVisitor.cpp TranslateQualifiedNamesVisitor.cpp
TreeOptimizer.cpp TreeOptimizer.cpp
TreeRewriter.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
) )

View File

@ -19,8 +19,8 @@ SRCS(
ASTCreateRowPolicyQuery.cpp ASTCreateRowPolicyQuery.cpp
ASTCreateSettingsProfileQuery.cpp ASTCreateSettingsProfileQuery.cpp
ASTCreateUserQuery.cpp ASTCreateUserQuery.cpp
ASTDictionaryAttributeDeclaration.cpp
ASTDictionary.cpp ASTDictionary.cpp
ASTDictionaryAttributeDeclaration.cpp
ASTDropAccessEntityQuery.cpp ASTDropAccessEntityQuery.cpp
ASTDropQuery.cpp ASTDropQuery.cpp
ASTExpressionList.cpp ASTExpressionList.cpp
@ -56,21 +56,17 @@ SRCS(
ASTShowTablesQuery.cpp ASTShowTablesQuery.cpp
ASTSubquery.cpp ASTSubquery.cpp
ASTSystemQuery.cpp ASTSystemQuery.cpp
ASTTablesInSelectQuery.cpp
ASTTTLElement.cpp ASTTTLElement.cpp
ASTTablesInSelectQuery.cpp
ASTUserNameWithHost.cpp ASTUserNameWithHost.cpp
ASTWithAlias.cpp ASTWithAlias.cpp
ASTWithElement.cpp ASTWithElement.cpp
CommonParsers.cpp CommonParsers.cpp
ExpressionElementParsers.cpp ExpressionElementParsers.cpp
ExpressionListParsers.cpp ExpressionListParsers.cpp
formatAST.cpp
formatSettingName.cpp
IAST.cpp IAST.cpp
iostream_debug_helpers.cpp
IParserBase.cpp IParserBase.cpp
Lexer.cpp Lexer.cpp
makeASTForLogicalFunction.cpp
MySQL/ASTAlterCommand.cpp MySQL/ASTAlterCommand.cpp
MySQL/ASTAlterQuery.cpp MySQL/ASTAlterQuery.cpp
MySQL/ASTCreateDefines.cpp MySQL/ASTCreateDefines.cpp
@ -84,11 +80,6 @@ SRCS(
MySQL/ASTDeclareReference.cpp MySQL/ASTDeclareReference.cpp
MySQL/ASTDeclareSubPartition.cpp MySQL/ASTDeclareSubPartition.cpp
MySQL/ASTDeclareTableOptions.cpp MySQL/ASTDeclareTableOptions.cpp
obfuscateQueries.cpp
parseDatabaseAndTableName.cpp
parseIdentifierOrStringLiteral.cpp
parseIntervalKind.cpp
parseQuery.cpp
ParserAlterQuery.cpp ParserAlterQuery.cpp
ParserCase.cpp ParserCase.cpp
ParserCheckQuery.cpp ParserCheckQuery.cpp
@ -100,8 +91,8 @@ SRCS(
ParserCreateUserQuery.cpp ParserCreateUserQuery.cpp
ParserDataType.cpp ParserDataType.cpp
ParserDescribeTableQuery.cpp ParserDescribeTableQuery.cpp
ParserDictionaryAttributeDeclaration.cpp
ParserDictionary.cpp ParserDictionary.cpp
ParserDictionaryAttributeDeclaration.cpp
ParserDropAccessEntityQuery.cpp ParserDropAccessEntityQuery.cpp
ParserDropQuery.cpp ParserDropQuery.cpp
ParserExplainQuery.cpp ParserExplainQuery.cpp
@ -135,10 +126,19 @@ SRCS(
ParserUserNameWithHost.cpp ParserUserNameWithHost.cpp
ParserWatchQuery.cpp ParserWatchQuery.cpp
ParserWithElement.cpp ParserWithElement.cpp
parseUserName.cpp
queryToString.cpp
QueryWithOutputSettingsPushDownVisitor.cpp QueryWithOutputSettingsPushDownVisitor.cpp
TokenIterator.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
) )

View File

@ -19,11 +19,14 @@ SRCS(
Executors/PullingPipelineExecutor.cpp Executors/PullingPipelineExecutor.cpp
ForkProcessor.cpp ForkProcessor.cpp
Formats/IInputFormat.cpp Formats/IInputFormat.cpp
Formats/IOutputFormat.cpp
Formats/IRowInputFormat.cpp
Formats/IRowOutputFormat.cpp
Formats/Impl/BinaryRowInputFormat.cpp Formats/Impl/BinaryRowInputFormat.cpp
Formats/Impl/BinaryRowOutputFormat.cpp Formats/Impl/BinaryRowOutputFormat.cpp
Formats/Impl/ConstantExpressionTemplate.cpp
Formats/Impl/CSVRowInputFormat.cpp Formats/Impl/CSVRowInputFormat.cpp
Formats/Impl/CSVRowOutputFormat.cpp Formats/Impl/CSVRowOutputFormat.cpp
Formats/Impl/ConstantExpressionTemplate.cpp
Formats/Impl/JSONAsStringRowInputFormat.cpp Formats/Impl/JSONAsStringRowInputFormat.cpp
Formats/Impl/JSONCompactEachRowRowInputFormat.cpp Formats/Impl/JSONCompactEachRowRowInputFormat.cpp
Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp
@ -49,19 +52,16 @@ SRCS(
Formats/Impl/RawBLOBRowInputFormat.cpp Formats/Impl/RawBLOBRowInputFormat.cpp
Formats/Impl/RawBLOBRowOutputFormat.cpp Formats/Impl/RawBLOBRowOutputFormat.cpp
Formats/Impl/RegexpRowInputFormat.cpp Formats/Impl/RegexpRowInputFormat.cpp
Formats/Impl/TSKVRowInputFormat.cpp
Formats/Impl/TSKVRowOutputFormat.cpp
Formats/Impl/TabSeparatedRowInputFormat.cpp Formats/Impl/TabSeparatedRowInputFormat.cpp
Formats/Impl/TabSeparatedRowOutputFormat.cpp Formats/Impl/TabSeparatedRowOutputFormat.cpp
Formats/Impl/TemplateBlockOutputFormat.cpp Formats/Impl/TemplateBlockOutputFormat.cpp
Formats/Impl/TemplateRowInputFormat.cpp Formats/Impl/TemplateRowInputFormat.cpp
Formats/Impl/TSKVRowInputFormat.cpp
Formats/Impl/TSKVRowOutputFormat.cpp
Formats/Impl/ValuesBlockInputFormat.cpp Formats/Impl/ValuesBlockInputFormat.cpp
Formats/Impl/ValuesRowOutputFormat.cpp Formats/Impl/ValuesRowOutputFormat.cpp
Formats/Impl/VerticalRowOutputFormat.cpp Formats/Impl/VerticalRowOutputFormat.cpp
Formats/Impl/XMLRowOutputFormat.cpp Formats/Impl/XMLRowOutputFormat.cpp
Formats/IOutputFormat.cpp
Formats/IRowInputFormat.cpp
Formats/IRowOutputFormat.cpp
Formats/LazyOutputFormat.cpp Formats/LazyOutputFormat.cpp
Formats/OutputStreamToOutputFormat.cpp Formats/OutputStreamToOutputFormat.cpp
Formats/PullingOutputFormat.cpp Formats/PullingOutputFormat.cpp
@ -87,7 +87,6 @@ SRCS(
OffsetTransform.cpp OffsetTransform.cpp
Pipe.cpp Pipe.cpp
Port.cpp Port.cpp
printPipeline.cpp
QueryPipeline.cpp QueryPipeline.cpp
QueryPlan/AddingDelayedSourceStep.cpp QueryPlan/AddingDelayedSourceStep.cpp
QueryPlan/AggregatingStep.cpp QueryPlan/AggregatingStep.cpp
@ -151,6 +150,7 @@ SRCS(
Transforms/RollupTransform.cpp Transforms/RollupTransform.cpp
Transforms/SortingTransform.cpp Transforms/SortingTransform.cpp
Transforms/TotalsHavingTransform.cpp Transforms/TotalsHavingTransform.cpp
printPipeline.cpp
) )

View File

@ -15,10 +15,8 @@ SRCS(
ConstraintsDescription.cpp ConstraintsDescription.cpp
Distributed/DirectoryMonitor.cpp Distributed/DirectoryMonitor.cpp
Distributed/DistributedBlockOutputStream.cpp Distributed/DistributedBlockOutputStream.cpp
extractKeyExpressionList.cpp
getStructureOfRemoteTable.cpp
IndicesDescription.cpp
IStorage.cpp IStorage.cpp
IndicesDescription.cpp
JoinSettings.cpp JoinSettings.cpp
KeyDescription.cpp KeyDescription.cpp
LiveView/StorageLiveView.cpp LiveView/StorageLiveView.cpp
@ -27,19 +25,15 @@ SRCS(
MergeTree/AllMergeSelector.cpp MergeTree/AllMergeSelector.cpp
MergeTree/BackgroundProcessingPool.cpp MergeTree/BackgroundProcessingPool.cpp
MergeTree/BoolMask.cpp MergeTree/BoolMask.cpp
MergeTree/checkDataPart.cpp
MergeTree/DataPartsExchange.cpp MergeTree/DataPartsExchange.cpp
MergeTree/EphemeralLockInZooKeeper.cpp MergeTree/EphemeralLockInZooKeeper.cpp
MergeTree/IMergedBlockOutputStream.cpp
MergeTree/IMergeTreeDataPart.cpp MergeTree/IMergeTreeDataPart.cpp
MergeTree/IMergeTreeDataPartWriter.cpp MergeTree/IMergeTreeDataPartWriter.cpp
MergeTree/IMergeTreeReader.cpp MergeTree/IMergeTreeReader.cpp
MergeTree/IMergedBlockOutputStream.cpp
MergeTree/KeyCondition.cpp MergeTree/KeyCondition.cpp
MergeTree/LevelMergeSelector.cpp MergeTree/LevelMergeSelector.cpp
MergeTree/localBackup.cpp
MergeTree/MergeAlgorithm.cpp MergeTree/MergeAlgorithm.cpp
MergeTree/MergedBlockOutputStream.cpp
MergeTree/MergedColumnOnlyOutputStream.cpp
MergeTree/MergeList.cpp MergeTree/MergeList.cpp
MergeTree/MergeTreeBaseSelectProcessor.cpp MergeTree/MergeTreeBaseSelectProcessor.cpp
MergeTree/MergeTreeBlockOutputStream.cpp MergeTree/MergeTreeBlockOutputStream.cpp
@ -76,11 +70,11 @@ SRCS(
MergeTree/MergeTreePartition.cpp MergeTree/MergeTreePartition.cpp
MergeTree/MergeTreePartsMover.cpp MergeTree/MergeTreePartsMover.cpp
MergeTree/MergeTreeRangeReader.cpp MergeTree/MergeTreeRangeReader.cpp
MergeTree/MergeTreeReadPool.cpp
MergeTree/MergeTreeReaderCompact.cpp MergeTree/MergeTreeReaderCompact.cpp
MergeTree/MergeTreeReaderInMemory.cpp MergeTree/MergeTreeReaderInMemory.cpp
MergeTree/MergeTreeReaderStream.cpp MergeTree/MergeTreeReaderStream.cpp
MergeTree/MergeTreeReaderWide.cpp MergeTree/MergeTreeReaderWide.cpp
MergeTree/MergeTreeReadPool.cpp
MergeTree/MergeTreeReverseSelectProcessor.cpp MergeTree/MergeTreeReverseSelectProcessor.cpp
MergeTree/MergeTreeSelectProcessor.cpp MergeTree/MergeTreeSelectProcessor.cpp
MergeTree/MergeTreeSequentialSource.cpp MergeTree/MergeTreeSequentialSource.cpp
@ -89,7 +83,8 @@ SRCS(
MergeTree/MergeTreeWhereOptimizer.cpp MergeTree/MergeTreeWhereOptimizer.cpp
MergeTree/MergeTreeWriteAheadLog.cpp MergeTree/MergeTreeWriteAheadLog.cpp
MergeTree/MergeType.cpp MergeTree/MergeType.cpp
MergeTree/registerStorageMergeTree.cpp MergeTree/MergedBlockOutputStream.cpp
MergeTree/MergedColumnOnlyOutputStream.cpp
MergeTree/ReplicatedFetchList.cpp MergeTree/ReplicatedFetchList.cpp
MergeTree/ReplicatedMergeTreeAddress.cpp MergeTree/ReplicatedMergeTreeAddress.cpp
MergeTree/ReplicatedMergeTreeAltersSequence.cpp MergeTree/ReplicatedMergeTreeAltersSequence.cpp
@ -104,10 +99,12 @@ SRCS(
MergeTree/ReplicatedMergeTreeTableMetadata.cpp MergeTree/ReplicatedMergeTreeTableMetadata.cpp
MergeTree/SimpleMergeSelector.cpp MergeTree/SimpleMergeSelector.cpp
MergeTree/TTLMergeSelector.cpp MergeTree/TTLMergeSelector.cpp
MergeTree/checkDataPart.cpp
MergeTree/localBackup.cpp
MergeTree/registerStorageMergeTree.cpp
MutationCommands.cpp MutationCommands.cpp
PartitionCommands.cpp PartitionCommands.cpp
ReadInOrderOptimizer.cpp ReadInOrderOptimizer.cpp
registerStorages.cpp
SelectQueryDescription.cpp SelectQueryDescription.cpp
SetSettings.cpp SetSettings.cpp
StorageBuffer.cpp StorageBuffer.cpp
@ -121,8 +118,8 @@ SRCS(
StorageJoin.cpp StorageJoin.cpp
StorageLog.cpp StorageLog.cpp
StorageLogSettings.cpp StorageLogSettings.cpp
StorageMaterializedView.cpp
StorageMaterializeMySQL.cpp StorageMaterializeMySQL.cpp
StorageMaterializedView.cpp
StorageMemory.cpp StorageMemory.cpp
StorageMerge.cpp StorageMerge.cpp
StorageMergeTree.cpp StorageMergeTree.cpp
@ -137,7 +134,6 @@ SRCS(
StorageValues.cpp StorageValues.cpp
StorageView.cpp StorageView.cpp
StorageXDBC.cpp StorageXDBC.cpp
System/attachSystemTables.cpp
System/StorageSystemAggregateFunctionCombinators.cpp System/StorageSystemAggregateFunctionCombinators.cpp
System/StorageSystemAsynchronousMetrics.cpp System/StorageSystemAsynchronousMetrics.cpp
System/StorageSystemBuildOptions.cpp System/StorageSystemBuildOptions.cpp
@ -147,8 +143,8 @@ SRCS(
System/StorageSystemContributors.cpp System/StorageSystemContributors.cpp
System/StorageSystemContributors.generated.cpp System/StorageSystemContributors.generated.cpp
System/StorageSystemCurrentRoles.cpp System/StorageSystemCurrentRoles.cpp
System/StorageSystemDatabases.cpp
System/StorageSystemDataTypeFamilies.cpp System/StorageSystemDataTypeFamilies.cpp
System/StorageSystemDatabases.cpp
System/StorageSystemDetachedParts.cpp System/StorageSystemDetachedParts.cpp
System/StorageSystemDictionaries.cpp System/StorageSystemDictionaries.cpp
System/StorageSystemDisks.cpp System/StorageSystemDisks.cpp
@ -161,22 +157,22 @@ SRCS(
System/StorageSystemGrants.cpp System/StorageSystemGrants.cpp
System/StorageSystemGraphite.cpp System/StorageSystemGraphite.cpp
System/StorageSystemMacros.cpp System/StorageSystemMacros.cpp
System/StorageSystemMerges.cpp
System/StorageSystemMergeTreeSettings.cpp System/StorageSystemMergeTreeSettings.cpp
System/StorageSystemMerges.cpp
System/StorageSystemMetrics.cpp System/StorageSystemMetrics.cpp
System/StorageSystemModels.cpp System/StorageSystemModels.cpp
System/StorageSystemMutations.cpp System/StorageSystemMutations.cpp
System/StorageSystemNumbers.cpp System/StorageSystemNumbers.cpp
System/StorageSystemOne.cpp System/StorageSystemOne.cpp
System/StorageSystemParts.cpp
System/StorageSystemPartsBase.cpp System/StorageSystemPartsBase.cpp
System/StorageSystemPartsColumns.cpp System/StorageSystemPartsColumns.cpp
System/StorageSystemParts.cpp
System/StorageSystemPrivileges.cpp System/StorageSystemPrivileges.cpp
System/StorageSystemProcesses.cpp System/StorageSystemProcesses.cpp
System/StorageSystemQuotaLimits.cpp System/StorageSystemQuotaLimits.cpp
System/StorageSystemQuotaUsage.cpp
System/StorageSystemQuotas.cpp System/StorageSystemQuotas.cpp
System/StorageSystemQuotasUsage.cpp System/StorageSystemQuotasUsage.cpp
System/StorageSystemQuotaUsage.cpp
System/StorageSystemReplicas.cpp System/StorageSystemReplicas.cpp
System/StorageSystemReplicatedFetches.cpp System/StorageSystemReplicatedFetches.cpp
System/StorageSystemReplicationQueue.cpp System/StorageSystemReplicationQueue.cpp
@ -195,9 +191,13 @@ SRCS(
System/StorageSystemUsers.cpp System/StorageSystemUsers.cpp
System/StorageSystemZeros.cpp System/StorageSystemZeros.cpp
System/StorageSystemZooKeeper.cpp System/StorageSystemZooKeeper.cpp
transformQueryForExternalDatabase.cpp System/attachSystemTables.cpp
TTLDescription.cpp TTLDescription.cpp
VirtualColumnUtils.cpp VirtualColumnUtils.cpp
extractKeyExpressionList.cpp
getStructureOfRemoteTable.cpp
registerStorages.cpp
transformQueryForExternalDatabase.cpp
) )

View File

@ -10,8 +10,6 @@ SRCS(
ITableFunction.cpp ITableFunction.cpp
ITableFunctionFileLike.cpp ITableFunctionFileLike.cpp
ITableFunctionXDBC.cpp ITableFunctionXDBC.cpp
parseColumnsListForTableFunction.cpp
registerTableFunctions.cpp
TableFunctionFactory.cpp TableFunctionFactory.cpp
TableFunctionFile.cpp TableFunctionFile.cpp
TableFunctionGenerateRandom.cpp TableFunctionGenerateRandom.cpp
@ -25,6 +23,8 @@ SRCS(
TableFunctionValues.cpp TableFunctionValues.cpp
TableFunctionView.cpp TableFunctionView.cpp
TableFunctionZeros.cpp TableFunctionZeros.cpp
parseColumnsListForTableFunction.cpp
registerTableFunctions.cpp
) )

View File

@ -7,6 +7,9 @@
ROOT_PATH=$(git rev-parse --show-toplevel) ROOT_PATH=$(git rev-parse --show-toplevel)
EXCLUDE_DIRS='build/|integration/|widechar_width/|glibc-compatibility/|memcpy/|consistent-hashing' 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 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/}" 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/}") (cd $(dirname "${path}") && perl -pne 's/<\?(.+?)\?>/`$1`/e' < "${path}" >> "${path/.in/}")