ClickHouse/src/Interpreters
2023-08-04 17:02:39 +02:00
..
Access Implemented max sessions for user 2023-07-30 22:09:03 +00:00
Cache Fix 2023-08-04 17:02:39 +02:00
ClusterProxy Change signature of the updateSettingsForCluster() to avoid cluster requirement 2023-07-24 05:50:44 +02:00
examples
fuzzers
JIT Fixed tests 2023-06-20 11:42:22 +03:00
MySQL
tests Update gtest_lru_file_cache.cpp 2023-07-22 12:03:20 +02:00
ActionLocksManager.cpp Add system stop pulling replication log (#52881) 2023-08-03 13:34:43 +03:00
ActionLocksManager.h
ActionsDAG.cpp Merge remote-tracking branch 'origin/master' into fix_remove_redundant_distinct_with_view 2023-07-22 18:10:24 +00:00
ActionsDAG.h
ActionsVisitor.cpp Merge pull request #51961 from nickitat/exec_udf_allow_parameters 2023-07-28 11:52:17 +02:00
ActionsVisitor.h
AddDefaultDatabaseVisitor.h
AddIndexConstraintsOptimizer.cpp
AddIndexConstraintsOptimizer.h
addMissingDefaults.cpp
addMissingDefaults.h
addTypeConversionToAST.cpp
addTypeConversionToAST.h
AggregateDescription.cpp
AggregateDescription.h
AggregateFunctionOfGroupByKeysVisitor.h
AggregationCommon.h
AggregationUtils.cpp
AggregationUtils.h
Aggregator.cpp Fix memory consumption when max_block_size is huge in Aggregator + more memory checks (#51566) 2023-08-02 15:11:52 +02:00
Aggregator.h Fix memory consumption when max_block_size is huge in Aggregator + more memory checks (#51566) 2023-08-02 15:11:52 +02:00
Aliases.h
applyTableOverride.cpp
applyTableOverride.h
ApplyWithAliasVisitor.cpp
ApplyWithAliasVisitor.h
ApplyWithGlobalVisitor.cpp
ApplyWithGlobalVisitor.h
ApplyWithSubqueryVisitor.cpp
ApplyWithSubqueryVisitor.h
ArithmeticOperationsInAgrFuncOptimize.cpp
ArithmeticOperationsInAgrFuncOptimize.h
ArrayJoinAction.cpp
ArrayJoinAction.h
ArrayJoinedColumnsVisitor.h
AsynchronousInsertLog.cpp Log async query flushes to query_log 2023-06-20 11:38:19 +02:00
AsynchronousInsertLog.h Log async query flushes to query_log 2023-06-20 11:38:19 +02:00
AsynchronousInsertQueue.cpp System logs improvements 2023-07-28 07:23:34 +00:00
AsynchronousInsertQueue.h Merge remote-tracking branch 'upstream/master' into HEAD 2023-07-24 10:55:31 +00:00
AsynchronousMetricLog.cpp Merge branch 'master' into keeper-prometheus 2022-11-15 12:00:02 +00:00
AsynchronousMetricLog.h
BloomFilter.cpp
BloomFilter.h
BloomFilterHash.h
CancellationCode.h
castColumn.cpp
castColumn.h
ClientInfo.cpp
ClientInfo.h
Cluster.cpp Initialize weight/slot_to_shards for cluster not from xml correcty 2023-06-28 19:07:14 +02:00
Cluster.h Remove non existing ctor of Cluster::Address 2023-07-24 05:50:44 +02:00
ClusterDiscovery.cpp
ClusterDiscovery.h
CMakeLists.txt
CollectJoinOnKeysVisitor.cpp
CollectJoinOnKeysVisitor.h
ColumnAliasesVisitor.cpp
ColumnAliasesVisitor.h
ComparisonGraph.cpp
ComparisonGraph.h
ComparisonTupleEliminationVisitor.cpp
ComparisonTupleEliminationVisitor.h
ConcurrentHashJoin.cpp addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
ConcurrentHashJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
Context_fwd.h
Context.cpp Merge pull request #51724 from arenadata/ADQM-939 2023-07-31 15:38:58 +03:00
Context.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
convertFieldToType.cpp
convertFieldToType.h
ConvertFunctionOrLikeVisitor.cpp
ConvertFunctionOrLikeVisitor.h
ConvertStringsToEnumVisitor.cpp
ConvertStringsToEnumVisitor.h
CrashLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
CrashLog.h System logs improvements 2023-07-28 07:23:34 +00:00
createBlockSelector.cpp Convert assert to LOGICAL_ERROR in createBlockSelector() for zero weight 2023-06-28 19:06:31 +02:00
createBlockSelector.h
CrossToInnerJoinVisitor.cpp
CrossToInnerJoinVisitor.h
DatabaseAndTableWithAlias.cpp
DatabaseAndTableWithAlias.h
DatabaseCatalog.cpp Merge branch 'master' into fix_insert_into_buffer_table 2023-07-25 16:06:42 +02:00
DatabaseCatalog.h more fair queue for drop table sync (#52276) 2023-07-20 14:51:01 +03:00
DDLTask.cpp Remove non-const function Context::getClientInfo(). 2023-07-17 15:02:07 +02:00
DDLTask.h
DDLWorker.cpp Check for punctuation 2023-07-25 06:10:04 +02:00
DDLWorker.h
DirectJoin.cpp addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
DirectJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
DNSCacheUpdater.cpp
DNSCacheUpdater.h
DuplicateOrderByVisitor.cpp
DuplicateOrderByVisitor.h
EmbeddedDictionaries.cpp
EmbeddedDictionaries.h
evaluateConstantExpression.cpp Better version 2023-07-17 04:49:04 +02:00
evaluateConstantExpression.h
executeDDLQueryOnCluster.cpp Do not replicate ALTER TABLE t FREEZE on Replicated engine (#52064) 2023-08-02 14:39:54 +03:00
executeDDLQueryOnCluster.h Do not replicate ALTER TABLE t FREEZE on Replicated engine (#52064) 2023-08-02 14:39:54 +03:00
executeQuery.cpp Include query cache usage in SYSTEM.QUERY_LOG 2023-07-24 16:24:36 +00:00
executeQuery.h Include query cache usage in SYSTEM.QUERY_LOG 2023-07-24 16:24:36 +00:00
ExecuteScalarSubqueriesVisitor.cpp
ExecuteScalarSubqueriesVisitor.h
ExpressionActions.cpp Remove isReady from FutureSet iface. 2023-06-19 12:56:24 +00:00
ExpressionActions.h
ExpressionActionsSettings.cpp
ExpressionActionsSettings.h
ExpressionAnalyzer.cpp Slightly more changes 2023-07-16 03:14:44 +02:00
ExpressionAnalyzer.h Slightly more changes 2023-07-16 03:14:44 +02:00
ExpressionJIT.cpp JIT infrastructure refactoring 2023-06-20 11:42:22 +03:00
ExternalDictionariesLoader.cpp
ExternalDictionariesLoader.h
ExternalLoader.cpp
ExternalLoader.h
ExternalLoaderDatabaseConfigRepository.h
ExternalLoaderDictionaryStorageConfigRepository.cpp
ExternalLoaderDictionaryStorageConfigRepository.h
ExternalLoaderTempConfigRepository.cpp
ExternalLoaderTempConfigRepository.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
ExternalLoaderXMLConfigRepository.cpp
ExternalLoaderXMLConfigRepository.h
ExtractExpressionInfoVisitor.cpp
ExtractExpressionInfoVisitor.h
FilesystemCacheLog.cpp Revert "Merge pull request #51917 from ClickHouse/revert-system-drop-filesystem-cache-by-key" 2023-07-30 13:39:54 +02:00
FilesystemCacheLog.h Revert "Merge pull request #51917 from ClickHouse/revert-system-drop-filesystem-cache-by-key" 2023-07-30 13:39:54 +02:00
FilesystemReadPrefetchesLog.cpp
FilesystemReadPrefetchesLog.h
FillingRow.cpp
FillingRow.h
formatWithPossiblyHidingSecrets.h
FullSortingMergeJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
FunctionMaskingArgumentCheckVisitor.h
FunctionNameNormalizer.cpp
FunctionNameNormalizer.h
GatherFunctionQuantileVisitor.cpp
GatherFunctionQuantileVisitor.h
GetAggregatesVisitor.cpp Fix ORDER BY tuple of WINDOW functions 2023-07-16 02:52:06 +02:00
GetAggregatesVisitor.h Slightly more changes 2023-07-16 03:14:44 +02:00
getClusterName.cpp
getClusterName.h Implement referential dependencies for table engine "Distributed" 2022-12-13 11:09:42 +01:00
getColumnFromBlock.cpp
getColumnFromBlock.h
getCustomKeyFilterForParallelReplicas.cpp
getCustomKeyFilterForParallelReplicas.h
getHeaderForProcessingStage.cpp
getHeaderForProcessingStage.h
getTableExpressions.cpp
getTableExpressions.h
getTableOverride.cpp
getTableOverride.h Move to Interpreters 2021-12-17 22:19:10 +03:00
GinFilter.cpp
GinFilter.h
GlobalSubqueriesVisitor.h Cleanup. 2023-06-22 14:23:04 +00:00
GraceHashJoin.cpp update 2023-07-20 18:22:01 +08:00
GraceHashJoin.h wip: grace hash join support full & right join 2023-07-20 18:22:01 +08:00
GroupByFunctionKeysVisitor.h
GroupingSetsRewriterVisitor.cpp
GroupingSetsRewriterVisitor.h
HashJoin.cpp wip: reserve hash table size (#50875) 2023-07-10 10:44:01 +02:00
HashJoin.h wip: reserve hash table size (#50875) 2023-07-10 10:44:01 +02:00
IdentifierSemantic.cpp
IdentifierSemantic.h
IExternalLoadable.cpp
IExternalLoadable.h
IExternalLoaderConfigRepository.h
IInterpreter.cpp
IInterpreter.h
IInterpreterUnionOrSelectQuery.cpp
IInterpreterUnionOrSelectQuery.h
IJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
IKeyValueEntity.h
InDepthNodeVisitor.h
InJoinSubqueriesPreprocessor.cpp
InJoinSubqueriesPreprocessor.h
inplaceBlockConversions.cpp
inplaceBlockConversions.h
InternalTextLogsQueue.cpp
InternalTextLogsQueue.h
InterpreterAlterNamedCollectionQuery.cpp
InterpreterAlterNamedCollectionQuery.h
InterpreterAlterQuery.cpp Remove ALTER of LIVE VIEW 2023-06-22 20:32:29 +02:00
InterpreterAlterQuery.h
InterpreterBackupQuery.cpp
InterpreterBackupQuery.h
InterpreterCheckQuery.cpp
InterpreterCheckQuery.h
InterpreterCreateFunctionQuery.cpp
InterpreterCreateFunctionQuery.h
InterpreterCreateIndexQuery.cpp no style 2023-07-12 11:14:49 +00:00
InterpreterCreateIndexQuery.h
InterpreterCreateNamedCollectionQuery.cpp
InterpreterCreateNamedCollectionQuery.h
InterpreterCreateQuery.cpp Merge branch 'master' into azure_blob_storage_sas_token 2023-07-17 17:23:29 +02:00
InterpreterCreateQuery.h bugfix 2023-07-03 19:10:39 +03:00
InterpreterDeleteQuery.cpp
InterpreterDeleteQuery.h
InterpreterDescribeCacheQuery.cpp Merge remote-tracking branch 'upstream/master' into min-file-segment-size 2023-06-29 19:36:13 +02:00
InterpreterDescribeCacheQuery.h
InterpreterDescribeQuery.cpp Added option to check if container exists before attempting to read/create it, added this flag for all table functions, only used in azureBlobStorage 2023-07-06 10:56:07 +02:00
InterpreterDescribeQuery.h
InterpreterDropFunctionQuery.cpp
InterpreterDropFunctionQuery.h
InterpreterDropIndexQuery.cpp make tryEnqueueReplicatedDDL virtual 2022-09-16 16:25:32 +02:00
InterpreterDropIndexQuery.h
InterpreterDropNamedCollectionQuery.cpp
InterpreterDropNamedCollectionQuery.h
InterpreterDropQuery.cpp Merge branch 'master' into add_delay_for_replicated 2023-07-22 12:11:39 +02:00
InterpreterDropQuery.h
InterpreterExistsQuery.cpp
InterpreterExistsQuery.h
InterpreterExplainQuery.cpp
InterpreterExplainQuery.h
InterpreterExternalDDLQuery.cpp
InterpreterExternalDDLQuery.h
InterpreterFactory.cpp
InterpreterFactory.h
InterpreterInsertQuery.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
InterpreterInsertQuery.h
InterpreterKillQueryQuery.cpp
InterpreterKillQueryQuery.h
InterpreterOptimizeQuery.cpp
InterpreterOptimizeQuery.h
InterpreterRenameQuery.cpp Check for punctuation 2023-07-25 06:10:04 +02:00
InterpreterRenameQuery.h
InterpreterSelectIntersectExceptQuery.cpp
InterpreterSelectIntersectExceptQuery.h
InterpreterSelectQuery.cpp Merge pull request #52569 from ClickHouse/Realize_parameterized_view_as_new_storage_view 2023-07-30 05:46:51 +03:00
InterpreterSelectQuery.h
InterpreterSelectQueryAnalyzer.cpp
InterpreterSelectQueryAnalyzer.h Trying to fix a test. 2023-06-14 18:10:30 +00:00
InterpreterSelectWithUnionQuery.cpp
InterpreterSelectWithUnionQuery.h
InterpreterSetQuery.cpp Implemented max sessions for user 2023-07-30 22:09:03 +00:00
InterpreterSetQuery.h Ignore setting constraints for projection ASTs 2023-07-12 10:34:36 +08:00
InterpreterShowColumnsQuery.cpp
InterpreterShowColumnsQuery.h
InterpreterShowCreateQuery.cpp
InterpreterShowCreateQuery.h
InterpreterShowEngineQuery.cpp
InterpreterShowEngineQuery.h
InterpreterShowIndexesQuery.cpp Incorporate review feedback 2023-07-06 15:03:15 +00:00
InterpreterShowIndexesQuery.h
InterpreterShowProcesslistQuery.cpp
InterpreterShowProcesslistQuery.h
InterpreterShowTablesQuery.cpp
InterpreterShowTablesQuery.h Implement SHOW COLUMNS 2023-03-28 18:04:22 +00:00
InterpreterSystemQuery.cpp Add system stop pulling replication log (#52881) 2023-08-03 13:34:43 +03:00
InterpreterSystemQuery.h
InterpreterTransactionControlQuery.cpp
InterpreterTransactionControlQuery.h
InterpreterUndropQuery.cpp
InterpreterUndropQuery.h
InterpreterUseQuery.cpp
InterpreterUseQuery.h
InterpreterWatchQuery.cpp
InterpreterWatchQuery.h
interpretSubquery.cpp Revert "Trying to fix a test." 2023-06-15 16:42:38 +00:00
interpretSubquery.h Revert "Trying to fix a test." 2023-06-15 16:42:38 +00:00
InterserverCredentials.cpp
InterserverCredentials.h
InterserverIOHandler.h
ITokenExtractor.cpp
ITokenExtractor.h
joinDispatch.h
JoinedTables.cpp disable direct join for range dictionary 2023-07-17 08:16:58 +00:00
JoinedTables.h
JoinSwitcher.cpp addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
JoinSwitcher.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
JoinToSubqueryTransformVisitor.cpp
JoinToSubqueryTransformVisitor.h
JoinUtils.cpp
JoinUtils.h
Lemmatizers.cpp
Lemmatizers.h
loadMetadata.cpp Add system stop pulling replication log (#52881) 2023-08-03 13:34:43 +03:00
loadMetadata.h
LogicalExpressionsOptimizer.cpp
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp
MarkTableIdentifiersVisitor.h
MergeJoin.cpp Fix usage of temporary directories during RESTORE 2023-07-27 19:24:54 +02:00
MergeJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
MergeTreeTransaction.cpp Update MergeTreeTransaction.cpp 2023-06-26 13:44:09 +03:00
MergeTreeTransaction.h
MergeTreeTransactionHolder.cpp
MergeTreeTransactionHolder.h
MetricLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
MetricLog.h
misc.h
MonotonicityCheckVisitor.h
MutationsInterpreter.cpp
MutationsInterpreter.h
MutationsNonDeterministicHelpers.cpp
MutationsNonDeterministicHelpers.h
NormalizeSelectWithUnionQueryVisitor.cpp
NormalizeSelectWithUnionQueryVisitor.h
NullableUtils.cpp fix transform_null_in with sets of tuples 2020-11-05 21:07:44 +03:00
NullableUtils.h
OpenTelemetrySpanLog.cpp
OpenTelemetrySpanLog.h
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp use UTC LUT 2023-07-05 11:57:18 +02:00
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h Revert "Revert "Merge pull request #50951 from ZhiguoZh/20230607-toyear-fix"" 2023-07-04 17:38:53 +02:00
OptimizeIfChains.cpp
OptimizeIfChains.h
OptimizeIfWithConstantConditionVisitor.cpp
OptimizeIfWithConstantConditionVisitor.h
OptimizeShardingKeyRewriteInVisitor.cpp
OptimizeShardingKeyRewriteInVisitor.h
parseColumnsListForTableFunction.cpp
parseColumnsListForTableFunction.h
PartLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
PartLog.h
PredicateExpressionsOptimizer.cpp Do not apply PredicateExpressionsOptimizer for ASOF/ANTI join 2023-06-29 17:12:55 +00:00
PredicateExpressionsOptimizer.h
PredicateRewriteVisitor.cpp
PredicateRewriteVisitor.h
PreparedSets.cpp Fix stupid bug. 2023-06-22 18:15:16 +00:00
PreparedSets.h Cleanup. 2023-06-22 14:23:04 +00:00
processColumnTransformers.cpp
processColumnTransformers.h
ProcessList.cpp Revert "Revert "Add an ability to specify allocations size for sampling memory profiler"" 2023-07-30 14:01:34 +02:00
ProcessList.h Merge branch 'master' into async_to_query_log 2023-06-27 13:12:13 +02:00
ProcessorsProfileLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
ProcessorsProfileLog.h System logs improvements 2023-07-28 07:23:34 +00:00
ProfileEventsExt.cpp Add peak memory usage (prototype) 2023-06-28 09:31:44 +00:00
ProfileEventsExt.h Add peak memory usage (prototype) 2023-06-28 09:31:44 +00:00
QueryAliasesVisitor.cpp
QueryAliasesVisitor.h
QueryLog.cpp Incorporate review feedback 2023-07-27 08:55:19 +00:00
QueryLog.h Include query cache usage in SYSTEM.QUERY_LOG 2023-07-24 16:24:36 +00:00
QueryNormalizer.cpp
QueryNormalizer.h
QueryPriorities.h
QueryThreadLog.cpp
QueryThreadLog.h
QueryViewsLog.cpp
QueryViewsLog.h
RedundantFunctionsInOrderByVisitor.h
RemoveInjectiveFunctionsVisitor.cpp
RemoveInjectiveFunctionsVisitor.h
RenameColumnVisitor.cpp
RenameColumnVisitor.h
replaceAliasColumnsInQuery.cpp
replaceAliasColumnsInQuery.h
replaceForPositionalArguments.cpp
replaceForPositionalArguments.h
ReplaceQueryParameterVisitor.cpp
ReplaceQueryParameterVisitor.h
RequiredSourceColumnsData.cpp
RequiredSourceColumnsData.h
RequiredSourceColumnsVisitor.cpp
RequiredSourceColumnsVisitor.h
RewriteAnyFunctionVisitor.cpp
RewriteAnyFunctionVisitor.h
RewriteArrayExistsFunctionVisitor.cpp
RewriteArrayExistsFunctionVisitor.h
RewriteCountDistinctVisitor.cpp
RewriteCountDistinctVisitor.h
RewriteCountVariantsVisitor.cpp
RewriteCountVariantsVisitor.h
RewriteFunctionToSubcolumnVisitor.cpp
RewriteFunctionToSubcolumnVisitor.h
RewriteOrderByVisitor.cpp
RewriteOrderByVisitor.hpp
RewriteSumIfFunctionVisitor.cpp
RewriteSumIfFunctionVisitor.h
RowRefs.cpp
RowRefs.h
SelectIntersectExceptQueryVisitor.cpp
SelectIntersectExceptQueryVisitor.h
SelectQueryOptions.h Ignore setting constraints for projection ASTs 2023-07-12 10:34:36 +08:00
ServerAsynchronousMetrics.cpp Add query cache metrics to system.asynchronous_metrics 2023-07-27 15:19:01 +00:00
ServerAsynchronousMetrics.h
Session.cpp Implemented max sessions for user 2023-07-30 22:09:03 +00:00
Session.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
SessionLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
SessionLog.h
SessionTracker.cpp Implemented max sessions for user 2023-07-30 22:09:03 +00:00
SessionTracker.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
Set.cpp Fix check. 2023-06-22 19:21:08 +00:00
Set.h Cleanup. 2023-06-22 14:23:04 +00:00
SetKeys.h Cleanup. 2023-06-22 14:23:04 +00:00
SetVariants.cpp
SetVariants.h
sortBlock.cpp Fixed build 2023-06-19 13:02:35 +03:00
sortBlock.h Sort block improvements 2023-06-18 12:52:08 +03:00
SortedBlocksWriter.cpp Fix usage of temporary directories during RESTORE 2023-07-27 19:24:54 +02:00
SortedBlocksWriter.h
SquashingTransform.cpp
SquashingTransform.h
StorageID.cpp
StorageID.h
SubstituteColumnOptimizer.cpp
SubstituteColumnOptimizer.h
SynonymsExtensions.cpp
SynonymsExtensions.h
SystemLog.cpp Update SystemLog.cpp (#52858) 2023-08-02 15:18:57 +03:00
SystemLog.h System logs improvements 2023-07-28 07:23:34 +00:00
TableJoin.cpp
TableJoin.h fix for analyzer 2023-07-18 05:51:55 +00:00
TableOverrideUtils.cpp
TableOverrideUtils.h
TablesStatus.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
TablesStatus.h
TemporaryDataOnDisk.cpp Fix usage of temporary directories during RESTORE 2023-07-27 19:24:54 +02:00
TemporaryDataOnDisk.h
TextLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TextLog.h System logs improvements 2023-07-28 07:23:34 +00:00
threadPoolCallbackRunner.h
ThreadStatusExt.cpp Revert "Revert "Add an ability to specify allocations size for sampling memory profiler"" 2023-07-30 14:01:34 +02:00
TraceCollector.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TraceCollector.h
TraceLog.cpp
TraceLog.h
TransactionLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TransactionLog.h
TransactionsInfoLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TransactionsInfoLog.h
TransactionVersionMetadata.cpp
TransactionVersionMetadata.h
TranslateQualifiedNamesVisitor.cpp Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02:00
TranslateQualifiedNamesVisitor.h Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02:00
TreeCNFConverter.cpp
TreeCNFConverter.h
TreeOptimizer.cpp Merge remote-tracking branch 'origin/master' into remove-perf-test-duplicate-order-by-and-distinct 2023-07-18 14:26:22 +00:00
TreeOptimizer.h
TreeRewriter.cpp Merge pull request #52569 from ClickHouse/Realize_parameterized_view_as_new_storage_view 2023-07-30 05:46:51 +03:00
TreeRewriter.h Merge pull request #52569 from ClickHouse/Realize_parameterized_view_as_new_storage_view 2023-07-30 05:46:51 +03:00
WhereConstraintsOptimizer.cpp
WhereConstraintsOptimizer.h
WindowDescription.cpp Allow Floats as boundaries for RANGE is nonsense 2023-07-30 23:19:54 +00:00
WindowDescription.h
ZooKeeperLog.cpp "reconfig" support for CH Keeper 2023-07-07 00:20:54 +03:00
ZooKeeperLog.h