ClickHouse/src/Interpreters
2024-03-13 19:22:16 +08:00
..
Access independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
Cache Merge branch 'master' into add-a-way-to-force-read-through-filesystem-cache-for-merges 2024-03-11 11:30:03 +01:00
ClusterProxy Treat 2+ in allow_experimental_parallel_reading_from_replicas as 2 2024-02-21 15:33:37 +01:00
examples Remove old code 2024-03-04 00:11:55 +01:00
fuzzers Fix something strange 2024-03-10 09:35:57 +01:00
JIT Revert "Merging #53757" 2024-01-05 13:46:18 +01:00
MySQL Maintain list of ASTRenameQuery children 2024-03-11 11:34:10 +00:00
tests Userspace page cache (#53770) 2024-02-29 12:28:32 +00:00
ActionLocksManager.cpp Overhaul RefreshTask 2023-12-28 17:56:04 +00:00
ActionLocksManager.h
ActionsDAG.cpp Merge pull request #60313 from ClickHouse/analyzer-refactor-constant-name 2024-03-08 12:08:05 +01:00
ActionsDAG.h Merge pull request #58554 from ClickHouse/try-to-always-push-down-prewhere-from-query-plan 2024-02-12 12:52:39 +01:00
ActionsVisitor.cpp Fixes and improvements for Variant type 2024-02-20 18:58:06 +00:00
ActionsVisitor.h
AddDefaultDatabaseVisitor.h Maintain list of ASTRenameQuery children 2024-03-11 11:34:10 +00:00
AddIndexConstraintsOptimizer.cpp Fix most tests 2024-02-26 02:31:58 +08:00
AddIndexConstraintsOptimizer.h
addMissingDefaults.cpp Remove dependencies 2023-11-11 06:59:20 +01:00
addMissingDefaults.h
addTypeConversionToAST.cpp
addTypeConversionToAST.h
AggregatedData.h too big translation unit in Aggregator 2024-03-12 16:17:33 +08:00
AggregatedDataVariants.cpp Merge remote-tracking branch 'origin/master' into split_aggregator 2024-03-13 16:56:42 +08:00
AggregatedDataVariants.h too big translation unit in Aggregator 2024-03-12 16:17:33 +08:00
AggregateDescription.cpp
AggregateDescription.h
AggregateFunctionOfGroupByKeysVisitor.h
AggregationCommon.h Improve the performance of serialized aggregation method when involving multiple [nullable] columns. 2024-02-29 21:48:15 +08:00
AggregationMethod.cpp too big translation unit in Aggregator 2024-03-12 16:17:33 +08:00
AggregationMethod.h too big translation unit in Aggregator 2024-03-12 16:17:33 +08:00
AggregationUtils.cpp
AggregationUtils.h
Aggregator.cpp fixed 2024-03-13 19:22:16 +08:00
Aggregator.h Merge remote-tracking branch 'origin/master' into split_aggregator 2024-03-13 16:56:42 +08: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 fix failed ut 2023-11-27 10:48:01 +08:00
ArrayJoinAction.h Respect max_block_size for array join to avoid possible OOM 2023-09-18 11:04:38 +08:00
ArrayJoinedColumnsVisitor.h Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
AsynchronousInsertLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
AsynchronousInsertLog.h Update to clang-19 2024-02-27 14:37:21 +01:00
AsynchronousInsertQueue.cpp set priority when scheduling task in thread pool 2024-03-05 19:45:25 +01:00
AsynchronousInsertQueue.h Update to clang-19 2024-02-27 14:37:21 +01:00
AsynchronousMetricLog.cpp Add comments to all columns of system tables (#58356) 2024-01-12 16:39:22 +01:00
AsynchronousMetricLog.h Remove unused method 2024-02-25 22:40:03 +01:00
BackupLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
BackupLog.h Fixing more headers 2024-02-29 15:40:30 +00:00
BlobStorageLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
BlobStorageLog.h Update to clang-19 2024-02-27 14:37:21 +01:00
BloomFilter.cpp Reuse granule during skip index reading 2023-10-18 14:40:34 +08:00
BloomFilter.h Reuse granule during skip index reading 2023-10-18 14:40:34 +08:00
BloomFilterHash.h Adding a unit test 2023-11-22 08:33:41 +01:00
CancellationCode.h
castColumn.cpp Remove C++ templates 2023-11-10 05:25:02 +01:00
castColumn.h Remove C++ templates 2023-11-10 05:25:02 +01:00
ClientInfo.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
ClientInfo.h Revert "add function getClientHTTPHeader" 2023-12-05 13:34:34 +03:00
Cluster.cpp Fix addShard() 2023-12-05 18:07:51 +00:00
Cluster.h Fix addShard() 2023-12-05 18:07:51 +00:00
ClusterDiscovery.cpp Cleanups 2024-02-14 00:21:13 +01:00
ClusterDiscovery.h Updated implementation 2024-01-25 14:31:49 +03:00
CMakeLists.txt
CollectJoinOnKeysVisitor.cpp Support 'is not distinct from' in join on section 2023-08-28 11:41:36 +00:00
CollectJoinOnKeysVisitor.h Support 'is not distinct from' in join on section 2023-08-28 11:41:36 +00:00
ColumnAliasesVisitor.cpp
ColumnAliasesVisitor.h Skip JOIN OR/USING sections in replaceAliasColumnsInQuery 2021-09-14 14:13:19 +03:00
ComparisonGraph.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
ComparisonGraph.h Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
ComparisonTupleEliminationVisitor.cpp
ComparisonTupleEliminationVisitor.h
ConcurrentHashJoin.cpp Disable max_joined_block_rows in ConcurrentHashJoin 2024-01-08 10:20:39 +00:00
ConcurrentHashJoin.h Remove redundant descriptionForPlan 2023-11-28 11:01:38 +00:00
Context_fwd.h
Context.cpp http connections pools 2024-03-10 10:00:18 +01:00
Context.h http connections pools 2024-03-10 10:00:18 +01:00
convertFieldToType.cpp Merge pull request #60004 from yariks5s/fix_datetime64_scale_conversion 2024-02-29 15:45:54 +01:00
convertFieldToType.h
ConvertFunctionOrLikeVisitor.cpp
ConvertFunctionOrLikeVisitor.h
ConvertStringsToEnumVisitor.cpp Fix some typos 2023-10-15 15:43:02 +02:00
ConvertStringsToEnumVisitor.h
CrashLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
CrashLog.h Add comments to all columns of system tables (#58356) 2024-01-12 16:39:22 +01:00
createBlockSelector.cpp
createBlockSelector.h
CrossToInnerJoinVisitor.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
CrossToInnerJoinVisitor.h
DatabaseAndTableWithAlias.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
DatabaseAndTableWithAlias.h
DatabaseCatalog.cpp skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
DatabaseCatalog.h Remove a bunch of transitive dependencies 2024-03-11 14:52:32 +01:00
DDLTask.cpp http connections pools 2024-03-10 10:00:18 +01:00
DDLTask.h Address comments 2024-02-16 19:30:16 +00:00
DDLWorker.cpp Updated implementation 2024-01-25 14:31:49 +03:00
DDLWorker.h Updated implementation 2024-01-25 14:31:49 +03:00
DirectJoin.cpp Updated implementation 2024-01-25 14:31:49 +03:00
DirectJoin.h Updated implementation 2024-01-25 14:31:49 +03:00
DNSCacheUpdater.cpp Updated implementation 2024-01-25 14:31:49 +03:00
DNSCacheUpdater.h DNS cache: Add option to drop elements after several consecutive failures 2022-04-05 13:00:27 +02:00
DuplicateOrderByVisitor.cpp Move handling of RESPECT NULLS outside of the parser 2023-11-27 11:00:27 +01:00
DuplicateOrderByVisitor.h
EmbeddedDictionaries.cpp Updated implementation 2024-01-25 14:31:49 +03:00
EmbeddedDictionaries.h Updated implementation 2024-01-25 14:31:49 +03:00
evaluateConstantExpression.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
evaluateConstantExpression.h Merge branch 'master' into planner-prepare-filters-for-analysis-2 2023-09-11 16:14:03 +02:00
executeDDLQueryOnCluster.cpp add none_only_active DDL output mode 2024-02-23 13:10:01 +01:00
executeDDLQueryOnCluster.h Move ZooKeeperRetries.h to Common 2024-01-30 19:02:17 +01:00
executeQuery.cpp Reject INSERT if async_insert=1 + deduplicate_blocks_in_dependent_materialized_views=1 (#60888) 2024-03-07 20:39:56 +01:00
executeQuery.h Review fix 2023-11-09 16:03:51 +01:00
ExecuteScalarSubqueriesVisitor.cpp Try to avoid calculation of scalar subqueries for CREATE TABLE. 2024-02-27 17:46:13 +00:00
ExecuteScalarSubqueriesVisitor.h
ExpressionActions.cpp Merge pull request #60196 from azat/preliminary-filters-fix 2024-02-29 10:17:05 -08:00
ExpressionActions.h Fix actions execution during preliminary filtering (PK, partition pruning) 2024-02-22 15:01:57 +01:00
ExpressionActionsSettings.cpp
ExpressionActionsSettings.h
ExpressionAnalyzer.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ExpressionAnalyzer.h
ExpressionJIT.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ExternalDictionariesLoader.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ExternalDictionariesLoader.h
ExternalLoader.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ExternalLoader.h Updated implementation 2024-01-25 14:31:49 +03:00
ExternalLoaderDictionaryStorageConfigRepository.cpp
ExternalLoaderDictionaryStorageConfigRepository.h
ExternalLoaderTempConfigRepository.cpp
ExternalLoaderTempConfigRepository.h
ExternalLoaderXMLConfigRepository.cpp
ExternalLoaderXMLConfigRepository.h
ExtractExpressionInfoVisitor.cpp
ExtractExpressionInfoVisitor.h
FilesystemCacheLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
FilesystemCacheLog.h Add comments to all columns of system tables (#58356) 2024-01-12 16:39:22 +01:00
FilesystemReadPrefetchesLog.cpp Add comments to all columns of system tables (#58356) 2024-01-12 16:39:22 +01:00
FilesystemReadPrefetchesLog.h Remove unused method 2024-02-25 22:40:03 +01:00
FillingRow.cpp
FillingRow.h
formatWithPossiblyHidingSecrets.h
FullSortingMergeJoin.h Updated implementation 2024-01-25 14:31:49 +03:00
FunctionMaskingArgumentCheckVisitor.h
FunctionNameNormalizer.cpp
FunctionNameNormalizer.h
GatherFunctionQuantileVisitor.cpp fix bug of quantileGK 2024-01-31 12:14:04 +08:00
GatherFunctionQuantileVisitor.h
GetAggregatesVisitor.cpp
GetAggregatesVisitor.h Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02:00
getClusterName.cpp
getClusterName.h
getColumnFromBlock.cpp
getColumnFromBlock.h
getCustomKeyFilterForParallelReplicas.cpp Revert "Revert flaky" 2024-01-19 13:51:30 +01:00
getCustomKeyFilterForParallelReplicas.h Revert "Revert flaky" 2024-01-19 13:51:30 +01:00
getHeaderForProcessingStage.cpp Merge branch 'master' into analyzer-refactor-constant-name 2024-03-06 17:55:52 +01:00
getHeaderForProcessingStage.h
getTableExpressions.cpp better interfaces for virtual columns 2024-03-01 22:29:56 +00:00
getTableExpressions.h
getTableOverride.cpp
getTableOverride.h
GinFilter.cpp Code refactoring according to code review 2023-10-16 17:52:39 -07:00
GinFilter.h Code refactoring according to code review 2023-10-16 17:52:39 -07:00
GlobalSubqueriesVisitor.h Rename the setting 2024-03-07 13:38:00 +00:00
GraceHashJoin.cpp Remove a bunch of transitive dependencies 2024-03-11 14:52:32 +01:00
GraceHashJoin.h Updated implementation 2024-01-25 14:31:49 +03:00
GroupByFunctionKeysVisitor.h
GroupingSetsRewriterVisitor.cpp
GroupingSetsRewriterVisitor.h
HashJoin.cpp Merge pull request #58278 from liuneng1994/optimize-all-join 2024-03-05 16:35:27 +01:00
HashJoin.h Updated implementation 2024-01-25 14:31:49 +03:00
IdentifierSemantic.cpp
IdentifierSemantic.h Fix 01890_materialized_distributed_join 2023-10-12 10:45:57 +00:00
IExternalLoadable.cpp
IExternalLoadable.h
IExternalLoaderConfigRepository.h
IInterpreter.cpp
IInterpreter.h More interesting settings for Stress Tests (#41534) 2023-02-21 15:36:23 +03:00
IInterpreterUnionOrSelectQuery.cpp Seperate max_execution_time and max_estimated_execution_time 2024-01-07 12:32:42 +08:00
IInterpreterUnionOrSelectQuery.h
IJoin.h Remove redundant descriptionForPlan 2023-11-28 11:01:38 +00:00
IKeyValueEntity.h
InDepthNodeVisitor.h
InJoinSubqueriesPreprocessor.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
InJoinSubqueriesPreprocessor.h
inplaceBlockConversions.cpp fix tests 2024-03-01 18:44:33 +00:00
inplaceBlockConversions.h refactoring of virtual columns 2024-02-21 00:57:35 +00:00
InternalTextLogsQueue.cpp Updated implementation 2024-01-25 14:31:49 +03:00
InternalTextLogsQueue.h Some fixups 2024-01-07 22:28:08 +00:00
InterpreterAlterNamedCollectionQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterAlterNamedCollectionQuery.h
InterpreterAlterQuery.cpp Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
InterpreterAlterQuery.h
InterpreterBackupQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterBackupQuery.h
InterpreterCheckQuery.cpp Updated implementation 2024-01-25 14:31:49 +03:00
InterpreterCheckQuery.h Updated implementation 2024-01-25 14:31:49 +03:00
InterpreterCreateFunctionQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterCreateFunctionQuery.h
InterpreterCreateIndexQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterCreateIndexQuery.h
InterpreterCreateNamedCollectionQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterCreateNamedCollectionQuery.h
InterpreterCreateQuery.cpp Maintain list of ASTRenameQuery children 2024-03-11 11:34:10 +00:00
InterpreterCreateQuery.h Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
InterpreterDeleteQuery.cpp refactoring of virtual columns 2024-02-21 00:57:35 +00:00
InterpreterDeleteQuery.h
InterpreterDescribeCacheQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterDescribeCacheQuery.h
InterpreterDescribeQuery.cpp better interfaces for virtual columns 2024-03-01 22:29:56 +00:00
InterpreterDescribeQuery.h fix test 2024-02-29 21:09:12 +00:00
InterpreterDropFunctionQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterDropFunctionQuery.h
InterpreterDropIndexQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterDropIndexQuery.h
InterpreterDropNamedCollectionQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterDropNamedCollectionQuery.h
InterpreterDropQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterDropQuery.h the worst fix for a deadlock ever 2023-08-17 00:42:51 +02:00
InterpreterExistsQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterExistsQuery.h Small refactoring. 2021-09-15 22:35:48 +03:00
InterpreterExplainQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterExplainQuery.h
InterpreterExternalDDLQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterExternalDDLQuery.h
InterpreterFactory.cpp Update to clang-19 2024-02-27 14:37:21 +01:00
InterpreterFactory.h Update to clang-19 2024-02-27 14:37:21 +01:00
InterpreterInsertQuery.cpp Merge pull request #60205 from CurtizJ/refactor-virtual-columns 2024-03-07 13:38:35 +01:00
InterpreterInsertQuery.h Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
InterpreterKillQueryQuery.cpp Disambiguate alter commands list (#59532) 2024-02-22 19:17:15 +01:00
InterpreterKillQueryQuery.h
InterpreterOptimizeQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterOptimizeQuery.h
InterpreterRenameQuery.cpp Maintain list of ASTRenameQuery children 2024-03-11 11:34:10 +00:00
InterpreterRenameQuery.h
InterpreterSelectIntersectExceptQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterSelectIntersectExceptQuery.h
InterpreterSelectQuery.cpp Revert "Don't allow to set max_parallel_replicas to 0 as it doesn't make sense" 2024-03-11 21:05:44 +01:00
InterpreterSelectQuery.h Fix 2024-02-26 02:31:57 +08:00
InterpreterSelectQueryAnalyzer.cpp Fixing analyzer. 2024-03-07 15:42:45 +00:00
InterpreterSelectQueryAnalyzer.h Analyzer log used row policies 2023-11-09 19:43:31 +03:00
InterpreterSelectWithUnionQuery.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
InterpreterSelectWithUnionQuery.h
InterpreterSetQuery.cpp Fix inconsistent formatting of SET param_... 2024-02-26 02:11:51 +01:00
InterpreterSetQuery.h
InterpreterShowColumnsQuery.cpp better interfaces for virtual columns 2024-03-01 22:29:56 +00:00
InterpreterShowColumnsQuery.h
InterpreterShowCreateQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterShowCreateQuery.h
InterpreterShowEngineQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterShowEngineQuery.h
InterpreterShowFunctionsQuery.cpp Style check for abbreviations 2024-02-17 02:14:15 +01:00
InterpreterShowFunctionsQuery.h Add SHOW FUNCTIONS support to client 2023-09-07 14:08:50 -07:00
InterpreterShowIndexesQuery.cpp Revert "Fix wacky primary key sorting in SHOW INDEX" 2024-03-06 08:57:20 +01:00
InterpreterShowIndexesQuery.h
InterpreterShowProcesslistQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterShowProcesslistQuery.h
InterpreterShowSettingQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterShowSettingQuery.h Add SHOW SETTING query 2023-10-25 18:49:00 +03:00
InterpreterShowTablesQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterShowTablesQuery.h Implement SHOW COLUMNS 2023-03-28 18:04:22 +00:00
InterpreterSystemQuery.cpp http connections pools 2024-03-10 10:00:18 +01:00
InterpreterSystemQuery.h Updated implementation 2024-01-25 14:31:49 +03:00
InterpreterTransactionControlQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterTransactionControlQuery.h
InterpreterUndropQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterUndropQuery.h
InterpreterUseQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterUseQuery.h
InterpreterWatchQuery.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
InterpreterWatchQuery.h
interpretSubquery.cpp
interpretSubquery.h Replace all Context references with std::weak_ptr (#22297) 2021-04-11 02:33:54 +03:00
InterserverCredentials.cpp Updated implementation 2024-01-25 14:31:49 +03:00
InterserverCredentials.h
InterserverIOHandler.h
ITokenExtractor.cpp
ITokenExtractor.h
joinDispatch.h
JoinedTables.cpp better interfaces for virtual columns 2024-03-01 22:29:56 +00:00
JoinedTables.h
JoinSwitcher.cpp
JoinSwitcher.h EXPLAIN actions for JOIN step 2023-08-03 18:55:15 +03:00
JoinToSubqueryTransformVisitor.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
JoinToSubqueryTransformVisitor.h Add setting multiple_joins_try_to_keep_original_names 2022-06-16 15:50:03 +00:00
JoinUtils.cpp Another fix join using nullable in old analyzer 2024-01-09 11:58:50 +00:00
JoinUtils.h Fix MergeJoin lowcard keys support 2023-12-13 17:43:15 +00:00
Lemmatizers.cpp
Lemmatizers.h
loadMetadata.cpp skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
loadMetadata.h
LogicalExpressionsOptimizer.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp
MarkTableIdentifiersVisitor.h
MergeJoin.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
MergeJoin.h Updated implementation 2024-01-25 14:31:49 +03:00
MergeTreeTransaction.cpp
MergeTreeTransaction.h
MergeTreeTransactionHolder.cpp
MergeTreeTransactionHolder.h
MetricLog.cpp Add comments to all columns of system tables (#58356) 2024-01-12 16:39:22 +01:00
MetricLog.h Remove unused method 2024-02-25 22:40:03 +01:00
misc.h
MonotonicityCheckVisitor.h Revert "Merge pull request #59122 from arthurpassos/bring_back_attach_partition_pr" 2024-02-07 02:52:43 +01:00
MutationsInterpreter.cpp address review comments 2024-03-05 16:03:02 +00:00
MutationsInterpreter.h Revert "Merge pull request #56864 from ClickHouse/broken-projections-better-handling" 2024-02-27 00:13:28 +01:00
MutationsNonDeterministicHelpers.cpp Support query parameters in ALTER TABLE ... PART 2024-01-15 14:16:54 +03:00
MutationsNonDeterministicHelpers.h
NormalizeSelectWithUnionQueryVisitor.cpp Fix incomplete query result for UNION in view() function. 2023-11-02 18:33:57 +00:00
NormalizeSelectWithUnionQueryVisitor.h
NullableUtils.cpp
NullableUtils.h
OpenTelemetrySpanLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
OpenTelemetrySpanLog.h Fixing more headers 2024-02-29 15:40:30 +00:00
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h
OptimizeIfChains.cpp
OptimizeIfChains.h
OptimizeIfWithConstantConditionVisitor.cpp Fixing tests. 2024-02-27 19:42:49 +00:00
OptimizeIfWithConstantConditionVisitor.h
OptimizeShardingKeyRewriteInVisitor.cpp Fix some skip_unused_shards tests. 2023-08-24 11:07:17 +00:00
OptimizeShardingKeyRewriteInVisitor.h Refactor code around optimize_skip_unused_shards_rewrite_in a little 2021-07-07 00:17:39 +03:00
parseColumnsListForTableFunction.cpp Merge branch 'master' into variant-improvements 2024-02-28 17:38:54 +01:00
parseColumnsListForTableFunction.h Merge branch 'master' into variant-improvements 2024-02-28 17:38:54 +01:00
PartLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
PartLog.h Remove unused method 2024-02-25 22:40:03 +01:00
PasteJoin.h Updated implementation 2024-01-25 14:31:49 +03:00
PredicateExpressionsOptimizer.cpp Fixing tests. 2023-11-14 12:51:25 +00:00
PredicateExpressionsOptimizer.h
PredicateRewriteVisitor.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
PredicateRewriteVisitor.h Reduce dependencies on ASTSelectQuery.h 2021-11-26 18:35:24 +01:00
PreparedSets.cpp Fix PreparedSets 2024-02-07 12:43:26 +00:00
PreparedSets.h Fix PreparedSets 2024-02-07 12:43:26 +00:00
processColumnTransformers.cpp better interfaces for virtual columns 2024-03-01 22:29:56 +00:00
processColumnTransformers.h
ProcessList.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
ProcessList.h Fixing more headers 2024-02-29 15:40:30 +00:00
ProcessorsProfileLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
ProcessorsProfileLog.h Remove unused method 2024-02-25 22:40:03 +01:00
ProfileEventsExt.cpp Use FQDN as host name by default for TCP 2024-01-30 20:27:30 +00:00
ProfileEventsExt.h Use FQDN as host name by default for TCP 2024-01-30 20:27:30 +00:00
QueryAliasesVisitor.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
QueryAliasesVisitor.h
QueryLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
QueryLog.h Remove unused method 2024-02-25 22:40:03 +01:00
QueryNormalizer.cpp QueryNormalizer only checks stack size 2023-10-16 10:33:04 +00:00
QueryNormalizer.h
QueryPriorities.h
QueryThreadLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
QueryThreadLog.h Remove unused method 2024-02-25 22:40:03 +01:00
QueryViewsLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
QueryViewsLog.h Remove unused method 2024-02-25 22:40:03 +01:00
RedundantFunctionsInOrderByVisitor.h
registerInterpreters.cpp independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
registerInterpreters.h independent registration of interpreters (#58443) 2024-01-08 22:33:48 -08:00
RemoveInjectiveFunctionsVisitor.cpp
RemoveInjectiveFunctionsVisitor.h
removeOnClusterClauseIfNeeded.cpp Updated implementation 2024-01-25 14:31:49 +03:00
removeOnClusterClauseIfNeeded.h
RenameColumnVisitor.cpp
RenameColumnVisitor.h
replaceAliasColumnsInQuery.cpp Skip JOIN OR/USING sections in replaceAliasColumnsInQuery 2021-09-14 14:13:19 +03:00
replaceAliasColumnsInQuery.h
replaceForPositionalArguments.cpp Fix typo 2024-01-30 07:01:07 +00:00
replaceForPositionalArguments.h
replaceMissedSubcolumnsInQuery.cpp Replace missed Object(Nullable(json)) subcolumns 2023-09-19 09:55:45 +08:00
replaceMissedSubcolumnsInQuery.h Replace missed Object(Nullable(json)) subcolumns 2023-09-19 09:55:45 +08:00
ReplaceQueryParameterVisitor.cpp fix 2023-08-16 22:35:45 +02:00
ReplaceQueryParameterVisitor.h fix 2023-08-16 22:35:45 +02:00
RequiredSourceColumnsData.cpp
RequiredSourceColumnsData.h Check if I can remove KeyCondition analysis on AST. 2024-01-03 17:50:46 +00:00
RequiredSourceColumnsVisitor.cpp Check if I can remove KeyCondition analysis on AST. 2024-01-03 17:50:46 +00:00
RequiredSourceColumnsVisitor.h
RewriteArrayExistsFunctionVisitor.cpp Fix build 2023-09-08 05:22:21 +02:00
RewriteArrayExistsFunctionVisitor.h Better 2023-09-07 02:35:21 +00:00
RewriteCountDistinctVisitor.cpp
RewriteCountDistinctVisitor.h
RewriteCountVariantsVisitor.cpp
RewriteCountVariantsVisitor.h
RewriteFunctionToSubcolumnVisitor.cpp Support function to subcolumns optimization for Variant, better text priority for reading Bool 2023-12-27 20:04:14 +00:00
RewriteFunctionToSubcolumnVisitor.h
RewriteOrderByVisitor.cpp
RewriteOrderByVisitor.hpp
RewriteSumFunctionWithSumAndCountVisitor.cpp Maintain function alias in RewriteSumFunctionWithSumAndCountVisitor 2024-02-06 19:09:28 +01:00
RewriteSumFunctionWithSumAndCountVisitor.h Rewrite the AST of sum(column + literal) function 2023-12-15 01:28:47 +08:00
RewriteSumIfFunctionVisitor.cpp
RewriteSumIfFunctionVisitor.h
RewriteUniqToCountVisitor.cpp Fix optimize_uniq_to_count removing the column alias 2024-02-15 14:10:55 +01:00
RewriteUniqToCountVisitor.h Add optimization uniq to count 2023-09-13 16:16:11 +08:00
RowRefs.cpp Fixed code review issues 2024-02-13 15:41:17 +03:00
RowRefs.h
S3QueueLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
S3QueueLog.h Remove unused method 2024-02-25 22:40:03 +01:00
SelectIntersectExceptQueryVisitor.cpp
SelectIntersectExceptQueryVisitor.h
SelectQueryOptions.h Fixing more headers 2024-02-29 15:40:30 +00:00
ServerAsynchronousMetrics.cpp Userspace page cache (#53770) 2024-02-29 12:28:32 +00:00
ServerAsynchronousMetrics.h Add statement 'SYSTEM RELOAD ASYNCHRONOUS METRICS' 2024-01-22 17:14:58 +00:00
Session.cpp Style check for abbreviations 2024-02-17 02:14:15 +01:00
Session.h Style check for abbreviations 2024-02-17 02:14:15 +01:00
SessionLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
SessionLog.h Remove unused method 2024-02-25 22:40:03 +01:00
SessionTracker.cpp
SessionTracker.h
Set.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
Set.h Merge branch 'master' into non-ready-set-ttl 2024-02-07 11:29:04 +00:00
SetKeys.h
SetVariants.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
SetVariants.h
sortBlock.cpp More iota 2023-12-29 17:20:18 +01:00
sortBlock.h
SortedBlocksWriter.cpp
SortedBlocksWriter.h
SquashingTransform.cpp
SquashingTransform.h
StorageID.cpp
StorageID.h
SubstituteColumnOptimizer.cpp
SubstituteColumnOptimizer.h Fix 2024-02-26 02:31:57 +08:00
SynonymsExtensions.cpp
SynonymsExtensions.h
SystemLog.cpp Maintain list of ASTRenameQuery children 2024-03-11 11:34:10 +00:00
SystemLog.h Updated implementation 2024-01-25 14:31:49 +03:00
TableJoin.cpp Updated implementation 2024-01-25 14:31:49 +03:00
TableJoin.h Fix join using nullable in old analyzer 2024-01-09 11:45:34 +00:00
TableOverrideUtils.cpp
TableOverrideUtils.h
TablesStatus.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
TablesStatus.h
TemporaryDataOnDisk.cpp Updated implementation 2024-01-25 14:31:49 +03:00
TemporaryDataOnDisk.h Remove a bunch of transitive dependencies 2024-03-11 14:52:32 +01:00
TextLog.cpp Add comments to all columns of system tables (#58356) 2024-01-12 16:39:22 +01:00
TextLog.h Remove unused method 2024-02-25 22:40:03 +01:00
ThreadStatusExt.cpp fix data race in SensitiveDataMasker 2024-01-17 08:10:50 +02:00
TraceCollector.cpp Fix real time query profiler on AArch64 2024-03-04 18:13:49 +01:00
TraceCollector.h
TraceLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
TraceLog.h Remove unused method 2024-02-25 22:40:03 +01:00
TransactionLog.cpp ability to detect undead ZooKeeper sessions 2024-02-15 22:17:31 +01:00
TransactionLog.h Updated implementation 2024-01-25 14:31:49 +03:00
TransactionsInfoLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
TransactionsInfoLog.h Remove unused method 2024-02-25 22:40:03 +01:00
TransactionVersionMetadata.cpp Updated implementation 2024-01-25 14:31:49 +03:00
TransactionVersionMetadata.h Updated implementation 2024-01-25 14:31:49 +03:00
TranslateQualifiedNamesVisitor.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
TranslateQualifiedNamesVisitor.h
TreeCNFConverter.cpp Fix most tests 2024-02-26 02:31:58 +08:00
TreeCNFConverter.h Fix most tests 2024-02-26 02:31:58 +08:00
TreeOptimizer.cpp Fix 2024-02-27 16:17:48 +01:00
TreeOptimizer.h
TreeRewriter.cpp fix tests 2024-03-01 18:44:33 +00:00
TreeRewriter.h Check if I can remove KeyCondition analysis on AST. 2024-01-03 17:50:46 +00:00
WhereConstraintsOptimizer.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
WhereConstraintsOptimizer.h
WindowDescription.cpp
WindowDescription.h
ZooKeeperLog.cpp More comments for column for system tables (#59016) 2024-03-08 18:05:56 +01:00
ZooKeeperLog.h Remove unused method 2024-02-25 22:40:03 +01:00