ClickHouse/src/Interpreters
2022-10-31 10:50:33 +01:00
..
Access Better 2022-09-21 10:16:49 +00:00
Cache Merge pull request #42418 from KinderRiven/max_cache_download_limit 2022-10-21 19:36:08 +02:00
ClusterProxy Merge remote-tracking branch 'upstream/master' into build/shorten-64-to-32 2022-10-22 16:49:08 +02:00
examples Fix -Wshorten-64-to-32 in examples 2022-10-21 13:25:43 +02:00
fuzzers Prefix overridden add_executable() command with "clickhouse_" 2022-07-11 19:36:18 +02:00
JIT Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
MySQL Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
tests Delete garbage 2022-09-26 10:24:39 +00:00
ActionLocksManager.cpp Remove specialization global lock/unlock from ActionLocksManager (#39215) 2022-07-21 01:29:35 +02:00
ActionLocksManager.h Remove specialization global lock/unlock from ActionLocksManager (#39215) 2022-07-21 01:29:35 +02:00
ActionsDAG.cpp Update ActionsDAG.cpp 2022-08-19 11:34:15 +03:00
ActionsDAG.h Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
ActionsVisitor.cpp Merge pull request #42263 from vitlibar/refactor-udf 2022-10-15 12:33:10 +02:00
ActionsVisitor.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
AddDefaultDatabaseVisitor.h
AddIndexConstraintsOptimizer.cpp
AddIndexConstraintsOptimizer.h
addMissingDefaults.cpp ActionsDAG rename index to outputs 2022-08-08 18:01:32 +02:00
addMissingDefaults.h Add check for columns sizes match 2021-04-23 19:09:09 +00:00
addTypeConversionToAST.cpp
addTypeConversionToAST.h
AggregateDescription.cpp Move updateInputStream to ITransformingStep (#37393) 2022-06-27 13:16:52 +02:00
AggregateDescription.h Move updateInputStream to ITransformingStep (#37393) 2022-06-27 13:16:52 +02:00
AggregateFunctionOfGroupByKeysVisitor.h
AggregationCommon.h
AggregationUtils.cpp Fix memory leaks and segfaults in combinators 2022-09-14 18:01:49 +00:00
AggregationUtils.h fix style 2022-08-16 18:56:22 +02:00
Aggregator.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
Aggregator.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
Aliases.h
applyTableOverride.cpp
applyTableOverride.h
ApplyWithAliasVisitor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
ApplyWithAliasVisitor.h
ApplyWithGlobalVisitor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
ApplyWithGlobalVisitor.h
ApplyWithSubqueryVisitor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
ApplyWithSubqueryVisitor.h Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
ArithmeticOperationsInAgrFuncOptimize.cpp
ArithmeticOperationsInAgrFuncOptimize.h
ArrayJoinAction.cpp
ArrayJoinAction.h
ArrayJoinedColumnsVisitor.h
AsynchronousInsertLog.cpp slightly better 2022-10-04 14:19:05 +00:00
AsynchronousInsertLog.h slightly better 2022-10-04 14:19:05 +00:00
AsynchronousInsertQueue.cpp Merge branch 'master' into async-inserts-log 2022-10-06 01:59:27 +02:00
AsynchronousInsertQueue.h Merge branch 'master' into async-inserts-log 2022-10-06 01:59:27 +02:00
AsynchronousMetricLog.cpp
AsynchronousMetricLog.h Remove useless codec from system.asynchronous_metric_log 2022-06-25 07:16:25 +02:00
AsynchronousMetrics.cpp Relax "too many parts" thresholds 2022-10-08 00:24:51 +02:00
AsynchronousMetrics.h work on remarks on the review 2022-08-30 20:18:35 +02:00
BloomFilter.cpp
BloomFilter.h
BloomFilterHash.h
CancellationCode.h
castColumn.cpp Only fix LowCardinality for now 2022-10-22 15:47:13 +08:00
castColumn.h Only fix LowCardinality for now 2022-10-22 15:47:13 +08:00
ClientInfo.cpp Generate config_version.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
ClientInfo.h pass session certificate for showCertificate() 2022-09-18 07:11:52 +00:00
Cluster.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
Cluster.h update tcp protocol, add quota_key 2022-08-03 15:44:08 -04:00
ClusterDiscovery.cpp More robust ClusterDiscovery::updateCluster 2022-08-17 14:46:06 +00:00
ClusterDiscovery.h Add observer mode to (zoo)keeper cluster discovery feature 2022-08-12 13:26:12 +00:00
CMakeLists.txt
CollectJoinOnKeysVisitor.cpp Join enums refactoring 2022-07-29 18:35:05 +02:00
CollectJoinOnKeysVisitor.h Join enums refactoring 2022-07-29 18:35:05 +02:00
ColumnAliasesVisitor.cpp
ColumnAliasesVisitor.h
ComparisonGraph.cpp abort instead of __builtin_unreachable in debug builds 2022-10-07 21:49:08 +02:00
ComparisonGraph.h
ConcurrentHashJoin.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
ConcurrentHashJoin.h upd ConcurrentHashJoin 2022-07-12 20:22:35 +02:00
Context_fwd.h
Context.cpp Merge branch 'master' into fix-42575 2022-10-25 15:31:32 +02:00
Context.h Fix trash 2022-10-17 04:21:08 +02:00
convertFieldToType.cpp Merge pull request #42469 from amosbird/issue_42456 2022-10-28 16:18:00 +02:00
convertFieldToType.h
ConvertFunctionOrLikeVisitor.cpp
ConvertFunctionOrLikeVisitor.h
ConvertStringsToEnumVisitor.cpp
ConvertStringsToEnumVisitor.h
CrashLog.cpp Generate config_version.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
CrashLog.h
createBlockSelector.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
createBlockSelector.h
CrossToInnerJoinVisitor.cpp Fix exponential query rewrite in case of lots of cross joins with where 2022-09-12 15:05:34 +00:00
CrossToInnerJoinVisitor.h
DatabaseAndTableWithAlias.cpp
DatabaseAndTableWithAlias.h
DatabaseCatalog.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
DatabaseCatalog.h fix 2022-10-07 19:52:34 +02:00
DDLTask.cpp Fix style 2022-09-23 11:48:50 +08:00
DDLTask.h Update name/comments 2022-09-23 11:36:06 +08:00
DDLWorker.cpp Improve the time to recover keeper connections (#42541) 2022-10-25 13:26:29 +02:00
DDLWorker.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
DirectJoin.cpp Added JOIN support for different algorithm 2022-10-24 10:22:21 +02:00
DirectJoin.h Added JOIN support for different algorithm 2022-10-24 10:22:21 +02:00
DNSCacheUpdater.cpp
DNSCacheUpdater.h DNS cache: Add option to drop elements after several consecutive failures 2022-04-05 13:00:27 +02:00
DuplicateOrderByVisitor.cpp
DuplicateOrderByVisitor.h Fix bad optimization of ORDER BY in subquery if it contains WITH FILL 2021-09-12 01:24:20 +03:00
EmbeddedDictionaries.cpp Don't use std::unique_lock unless we have to 2022-06-28 19:19:06 +00:00
EmbeddedDictionaries.h
evaluateConstantExpression.cpp Continue: ContextPtr -> const ContextPtr & in parameters 2022-07-06 13:13:19 +00:00
evaluateConstantExpression.h Continue: ContextPtr -> const ContextPtr & in parameters 2022-07-06 13:13:19 +00:00
executeDDLQueryOnCluster.cpp Merge branch 'master' into on_cluster_dll 2022-09-22 09:58:10 +08:00
executeDDLQueryOnCluster.h ignore cluster if equals to db name 2022-07-06 19:54:05 +02:00
executeQuery.cpp Move prepareQueryForLogging() to a separate header. 2022-10-31 10:50:33 +01:00
executeQuery.h
ExecuteScalarSubqueriesVisitor.cpp Fix some tests. 2022-05-27 20:47:35 +00:00
ExecuteScalarSubqueriesVisitor.h
ExpressionActions.cpp Added support for JOIN, ARRAY JOIN 2022-10-24 10:22:19 +02:00
ExpressionActions.h Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
ExpressionActionsSettings.cpp
ExpressionActionsSettings.h
ExpressionAnalyzer.cpp Merge pull request #39354 from ClickHouse/window-order-by 2022-09-19 09:22:37 +03:00
ExpressionAnalyzer.h Simplify the code and check what will happen 2022-08-15 06:56:29 +02:00
ExpressionJIT.cpp Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
ExternalDictionariesLoader.cpp Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
ExternalDictionariesLoader.h
ExternalLoader.cpp Fix incorrect trace log line on dict reload 2022-10-24 11:58:37 +02:00
ExternalLoader.h
ExternalLoaderDatabaseConfigRepository.h
ExternalLoaderDictionaryStorageConfigRepository.cpp
ExternalLoaderDictionaryStorageConfigRepository.h
ExternalLoaderTempConfigRepository.cpp
ExternalLoaderTempConfigRepository.h
ExternalLoaderXMLConfigRepository.cpp
ExternalLoaderXMLConfigRepository.h
ExtractExpressionInfoVisitor.cpp
ExtractExpressionInfoVisitor.h
FilesystemCacheLog.cpp abort instead of __builtin_unreachable in debug builds 2022-10-07 21:49:08 +02:00
FilesystemCacheLog.h Fix 2022-08-29 17:50:27 +02:00
FillingRow.cpp do not fill 'to' boundary 2022-06-14 22:26:50 -04:00
FillingRow.h
FullSortingMergeJoin.h Cleanup logic around join_algorithm setting 2022-07-21 14:53:39 +00:00
FunctionMaskingArgumentCheckVisitor.h fixed 02303_query_kind test; added logging in 02352_grouby_shadows_arg test 2022-08-02 10:50:27 +00:00
FunctionNameNormalizer.cpp Function name normalization fix functions header 2022-10-04 17:29:33 +02:00
FunctionNameNormalizer.h Add comments to FunctionNameNormalizer. 2022-09-19 22:07:04 +08:00
GatherFunctionQuantileVisitor.cpp Normalize everything else 2022-08-01 21:04:11 +08:00
GatherFunctionQuantileVisitor.h Normalize everything else 2022-08-01 21:04:11 +08:00
GetAggregatesVisitor.cpp Allow to use higher-order functions in window expressions 2022-07-11 23:47:46 +00:00
GetAggregatesVisitor.h Small refactoring 2022-06-16 15:41:04 +00:00
getClusterName.cpp Better exception messages on wrong table engines/functions argument types 2022-06-23 20:04:06 +00:00
getClusterName.h
getColumnFromBlock.cpp minor fixes 2022-03-14 17:29:18 +00:00
getColumnFromBlock.h
getHeaderForProcessingStage.cpp Fixed tests 2022-10-24 10:22:20 +02:00
getHeaderForProcessingStage.h Fix refcnt for unused MergeTree parts in SELECT queries 2022-06-08 07:04:53 +03:00
getTableExpressions.cpp
getTableExpressions.h
getTableOverride.cpp
getTableOverride.h
GlobalSubqueriesVisitor.h Merge branch 'master' into refactor-prepared-sets 2022-08-04 13:27:38 +02:00
GroupByFunctionKeysVisitor.h
GroupingSetsRewriterVisitor.cpp Rewrite queries GROUPING SETS (foo, bar) to GROUP BY foo, bar 2022-05-27 17:44:51 +03:00
GroupingSetsRewriterVisitor.h Rewrite queries GROUPING SETS (foo, bar) to GROUP BY foo, bar 2022-05-27 17:44:51 +03:00
HashJoin.cpp Fix assert cast in join on falsy condition 2022-10-17 16:12:00 +00:00
HashJoin.h abort instead of __builtin_unreachable in debug builds 2022-10-07 21:49:08 +02:00
IdentifierSemantic.cpp Fix exponential query rewrite in case of lots of cross joins with where 2022-09-12 15:05:34 +00:00
IdentifierSemantic.h Fix exponential query rewrite in case of lots of cross joins with where 2022-09-12 15:05:34 +00:00
IExternalLoadable.cpp
IExternalLoadable.h
IExternalLoaderConfigRepository.h
IInterpreter.cpp
IInterpreter.h
IInterpreterUnionOrSelectQuery.cpp ActionsDAG rename index to outputs 2022-08-08 18:01:32 +02:00
IInterpreterUnionOrSelectQuery.h Revert "Query plan optimization setting: read in window order" 2022-09-09 22:15:38 +02:00
IJoin.h Minor updates for full soring merge join 2022-07-06 14:28:05 +00:00
IKeyValueEntity.h better code for join with dict 2022-08-10 14:20:29 +00:00
InDepthNodeVisitor.h Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
InJoinSubqueriesPreprocessor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
InJoinSubqueriesPreprocessor.h
inplaceBlockConversions.cpp try to fix filling of missed Nested columns with multiple levels 2022-09-08 00:20:11 +00:00
inplaceBlockConversions.h try to fix filling of missed Nested columns with multiple levels 2022-09-06 13:56:32 +00:00
InternalTextLogsQueue.cpp Text log source regexp 2022-07-13 17:52:14 +08:00
InternalTextLogsQueue.h Text log source regexp 2022-07-13 17:52:14 +08:00
InterpreterAlterQuery.cpp make tryEnqueueReplicatedDDL virtual 2022-09-16 16:25:32 +02:00
InterpreterAlterQuery.h
InterpreterBackupQuery.cpp Rename column "uuid" -> "id" in system.backups and allow user to set it in a query. 2022-07-27 09:04:10 +02:00
InterpreterBackupQuery.h
InterpreterCheckQuery.cpp
InterpreterCheckQuery.h
InterpreterCreateFunctionQuery.cpp Split UserDefinedSQLObjectsLoader to interface and implementation. 2022-10-13 10:32:32 +02:00
InterpreterCreateFunctionQuery.h Split UserDefinedSQLObjectsLoader to interface and implementation. 2022-10-13 10:32:32 +02:00
InterpreterCreateIndexQuery.cpp make tryEnqueueReplicatedDDL virtual 2022-09-16 16:25:32 +02:00
InterpreterCreateIndexQuery.h Support sql standard drop index in seprate parser files 2022-06-29 11:08:05 +08:00
InterpreterCreateQuery.cpp Make as_table_function a child of ASTCreateQuery (to help writing visitors). 2022-10-31 10:50:33 +01:00
InterpreterCreateQuery.h fix race between DROP and short form of ATTACH 2022-09-14 18:03:36 +02:00
InterpreterDeleteQuery.cpp make tryEnqueueReplicatedDDL virtual 2022-09-16 16:25:32 +02:00
InterpreterDeleteQuery.h Support delete from ... where syntax on mergetree tables 2022-07-15 12:32:41 +08:00
InterpreterDescribeCacheQuery.cpp Rename 2022-09-19 14:02:51 +02:00
InterpreterDescribeCacheQuery.h Add describe cache command 2022-06-21 16:07:39 +02:00
InterpreterDescribeQuery.cpp Analyzer change setting into allow_experimental_analyzer 2022-10-25 12:35:25 +02:00
InterpreterDescribeQuery.h
InterpreterDropFunctionQuery.cpp Split UserDefinedSQLObjectsLoader to interface and implementation. 2022-10-13 10:32:32 +02:00
InterpreterDropFunctionQuery.h
InterpreterDropIndexQuery.cpp make tryEnqueueReplicatedDDL virtual 2022-09-16 16:25:32 +02:00
InterpreterDropIndexQuery.h Support sql standard drop index in seprate parser files 2022-06-29 11:08:05 +08:00
InterpreterDropQuery.cpp Fix truncate table does not hold lock correctly 2022-10-27 08:56:18 +00:00
InterpreterDropQuery.h deprecate Ordinary database 2022-06-23 10:20:14 +02:00
InterpreterExistsQuery.cpp
InterpreterExistsQuery.h
InterpreterExplainQuery.cpp Analyzer change setting into allow_experimental_analyzer 2022-10-25 12:35:25 +02:00
InterpreterExplainQuery.h
InterpreterExternalDDLQuery.cpp Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
InterpreterExternalDDLQuery.h
InterpreterFactory.cpp Analyzer change setting into allow_experimental_analyzer 2022-10-25 12:35:25 +02:00
InterpreterFactory.h
InterpreterInsertQuery.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
InterpreterInsertQuery.h Fix a destruction order for views ThreadStatus 2022-09-21 18:37:40 +00:00
InterpreterKillQueryQuery.cpp Remove some methods 2022-09-10 05:04:40 +02:00
InterpreterKillQueryQuery.h
InterpreterOptimizeQuery.cpp fix 2022-10-02 00:44:46 +02:00
InterpreterOptimizeQuery.h
InterpreterRenameQuery.cpp make tryEnqueueReplicatedDDL virtual 2022-09-16 16:25:32 +02:00
InterpreterRenameQuery.h Check grants for databases in case of renaming databases (#40906) 2022-09-05 12:38:44 +02:00
InterpreterSelectIntersectExceptQuery.cpp implement intersect + except distinct 2022-08-30 18:09:01 +08:00
InterpreterSelectIntersectExceptQuery.h Cleanup 2022-06-02 10:34:40 +00:00
InterpreterSelectQuery.cpp Merge pull request #42580 from hanfei1991/fei/limit_max_rows 2022-10-26 14:09:59 +02:00
InterpreterSelectQuery.h Merge remote-tracking branch 'origin/master' into skipping_sorting_step 2022-08-13 21:46:34 +00:00
InterpreterSelectQueryAnalyzer.cpp Fixed tests 2022-10-24 10:22:37 +02:00
InterpreterSelectQueryAnalyzer.h Fixed tests 2022-10-24 10:22:37 +02:00
InterpreterSelectWithUnionQuery.cpp implement intersect + except distinct 2022-08-30 18:09:01 +08:00
InterpreterSelectWithUnionQuery.h Simple cleanup: interpreters and parsers 2022-07-05 22:13:39 +00:00
InterpreterSetQuery.cpp move default settings to different part of ast 2022-10-11 18:25:28 +00:00
InterpreterSetQuery.h
InterpreterShowCreateQuery.cpp
InterpreterShowCreateQuery.h
InterpreterShowProcesslistQuery.cpp
InterpreterShowProcesslistQuery.h
InterpreterShowTablesQuery.cpp Rename 2022-09-19 14:02:51 +02:00
InterpreterShowTablesQuery.h
InterpreterSystemQuery.cpp Merge pull request #42263 from vitlibar/refactor-udf 2022-10-15 12:33:10 +02:00
InterpreterSystemQuery.h stop background ops before converting db engine 2022-09-09 18:27:19 +02:00
InterpreterTransactionControlQuery.cpp abort instead of __builtin_unreachable in debug builds 2022-10-07 21:49:08 +02:00
InterpreterTransactionControlQuery.h Add implicit_transaction setting 2022-06-23 15:23:37 +02:00
InterpreterUseQuery.cpp Move access-rights' source files needed for parser to a separate target. 2021-11-01 19:13:49 +03:00
InterpreterUseQuery.h
InterpreterWatchQuery.cpp Refactor a little bit more. 2022-05-31 14:43:38 +00:00
InterpreterWatchQuery.h
interpretSubquery.cpp
interpretSubquery.h
InterserverCredentials.cpp
InterserverCredentials.h
InterserverIOHandler.h
ITokenExtractor.cpp More conversions 2022-07-31 22:06:02 +00:00
ITokenExtractor.h
joinDispatch.h Join enums refactoring 2022-07-29 18:35:05 +02:00
JoinedTables.cpp better code for join with dict 2022-08-10 14:20:29 +00:00
JoinedTables.h
JoinSwitcher.cpp Rename join_common -> JoinUtils 2022-08-10 14:20:28 +00:00
JoinSwitcher.h
JoinToSubqueryTransformVisitor.cpp Merge branch 'master' into tsan_clang_15 2022-08-02 13:00:55 +03:00
JoinToSubqueryTransformVisitor.h Add setting multiple_joins_try_to_keep_original_names 2022-06-16 15:50:03 +00:00
JoinUtils.cpp Rename join_common -> JoinUtils 2022-08-10 14:20:28 +00:00
JoinUtils.h Rename join_common -> JoinUtils 2022-08-10 14:20:28 +00:00
Lemmatizers.cpp Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
Lemmatizers.h Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
loadMetadata.cpp Fix amusing error in conversion from Ordinary to Atomic 2022-09-21 07:10:33 +02:00
loadMetadata.h add flag that enables automatic canversion from Ordinary to Atomic 2022-08-05 21:41:25 +02:00
LogicalExpressionsOptimizer.cpp Activate clang-tidy warning "readability-container-contains" 2022-04-18 23:53:11 +02:00
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp
MarkTableIdentifiersVisitor.h
maskSensitiveInfoInQueryForLogging.cpp Wipe passwords from backup logs too. 2022-10-31 10:50:33 +01:00
maskSensitiveInfoInQueryForLogging.h Wipe passwords from backup logs too. 2022-10-31 10:50:33 +01:00
MergeJoin.cpp Followup for TemporaryDataOnDisk 2022-10-12 15:25:23 +02:00
MergeJoin.h fix bugs in MergeJoin when 'not_processed' is not null 2022-08-18 18:09:47 +08:00
MergeTreeTransaction.cpp block memory exceptions in TransactionLog 2022-07-18 17:40:09 +02:00
MergeTreeTransaction.h disable transactions with Ordinary database 2022-07-15 15:36:01 +02:00
MergeTreeTransactionHolder.cpp
MergeTreeTransactionHolder.h
MetricLog.cpp add system table asynchronous_inserts_log 2022-10-03 21:35:55 +00:00
MetricLog.h
misc.h
MonotonicityCheckVisitor.h Add comment. 2022-09-28 11:30:09 +00:00
MutationsInterpreter.cpp optimize compact part mutation 2022-09-09 10:22:35 +08:00
MutationsInterpreter.h Add support for update 2022-08-31 14:33:53 +00:00
NormalizeSelectWithUnionQueryVisitor.cpp Fix normalization of UNION inside DESCRIBE query 2022-10-24 10:22:37 +02:00
NormalizeSelectWithUnionQueryVisitor.h implement intersect + except distinct 2022-08-30 18:09:01 +08:00
NullableUtils.cpp
NullableUtils.h
OpenTelemetrySpanLog.cpp Fix code 2022-07-07 17:44:19 +08:00
OpenTelemetrySpanLog.h Remove using namespace from header 2022-08-25 20:20:13 +08:00
OptimizeIfChains.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
OptimizeIfChains.h replace multiIf to if in case of one condition 2022-05-31 14:45:12 +00:00
OptimizeIfWithConstantConditionVisitor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
OptimizeIfWithConstantConditionVisitor.h
OptimizeShardingKeyRewriteInVisitor.cpp
OptimizeShardingKeyRewriteInVisitor.h
parseColumnsListForTableFunction.cpp Remove unnended field 2022-08-16 09:51:52 +00:00
parseColumnsListForTableFunction.h Allow to specify structure hints in schema inference 2022-08-16 09:46:57 +00:00
PartLog.cpp better semantic of constsness of DataPartStorage 2022-10-23 15:24:20 +00:00
PartLog.h Add merge_algorithm to system.part_log 2022-07-13 17:16:25 +03:00
PredicateExpressionsOptimizer.cpp Fix exponential query rewrite in case of lots of cross joins with where 2022-09-12 15:05:34 +00:00
PredicateExpressionsOptimizer.h
PredicateRewriteVisitor.cpp Merge branch 'master' into another_fix_for_an_ast_optimization 2022-09-21 19:05:08 +03:00
PredicateRewriteVisitor.h
PreparedSets.cpp upd PreparedSets: rename/change signature of methods, add comments 2022-07-27 11:22:16 +00:00
PreparedSets.h Fixed tests 2022-10-24 10:22:20 +02:00
processColumnTransformers.cpp
processColumnTransformers.h OPTIMIZE DEDUPLICATE BY columns 2020-12-07 09:44:07 +03:00
ProcessList.cpp Merge remote-tracking branch 'upstream/master' into build/shorten-64-to-32 2022-10-22 16:49:08 +02:00
ProcessList.h Add more trash. 2022-10-21 22:19:06 +00:00
ProcessorsProfileLog.cpp processor profile 2022-08-11 21:03:34 +08:00
ProcessorsProfileLog.h processor profile 2022-08-11 21:03:34 +08:00
ProfileEventsExt.cpp fix build with clang-15 2022-08-01 18:00:54 +02:00
ProfileEventsExt.h
QueryAliasesVisitor.cpp
QueryAliasesVisitor.h
QueryLog.cpp
QueryLog.h
QueryNormalizer.cpp
QueryNormalizer.h
QueryParameterVisitor.cpp Fix clang-tidy 2022-09-11 20:43:36 +02:00
QueryParameterVisitor.h
QueryPriorities.h
QueryThreadLog.cpp
QueryThreadLog.h
QueryViewsLog.cpp Fix query_views_log with Window views 2022-09-09 13:46:53 +02:00
QueryViewsLog.h Fix a destruction order for views ThreadStatus 2022-09-21 18:37:40 +00:00
RedundantFunctionsInOrderByVisitor.h
RemoveInjectiveFunctionsVisitor.cpp
RemoveInjectiveFunctionsVisitor.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 2022-07-30 18:42:22 +03:00
replaceForPositionalArguments.h Fix 2022-07-30 18:42:22 +03:00
ReplaceQueryParameterVisitor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
ReplaceQueryParameterVisitor.h
RequiredSourceColumnsData.cpp
RequiredSourceColumnsData.h Fixing a test with indexHint 2022-07-28 12:24:16 +00:00
RequiredSourceColumnsVisitor.cpp Fix unused columns introduced by with stmt 2022-08-24 00:40:01 +08:00
RequiredSourceColumnsVisitor.h Fix lambdas with multiple_joins_rewriter v2 (#11587) 2020-06-16 19:32:32 +03:00
RewriteAnyFunctionVisitor.cpp Small refactoring 2022-06-16 15:41:04 +00:00
RewriteAnyFunctionVisitor.h
RewriteCountDistinctVisitor.cpp implement intersect + except distinct 2022-08-30 18:09:01 +08:00
RewriteCountDistinctVisitor.h
RewriteCountVariantsVisitor.cpp Add more checkStackSize calls 2022-10-01 17:48:56 +02:00
RewriteCountVariantsVisitor.h
RewriteFunctionToSubcolumnVisitor.cpp Remove some methods 2022-09-10 05:04:40 +02:00
RewriteFunctionToSubcolumnVisitor.h
RewriteOrderByVisitor.cpp Fix: rewrite only outer braces 2022-07-06 10:23:05 +00:00
RewriteOrderByVisitor.hpp Fix: clear children in order by element during rewriting 2022-07-05 22:48:48 +00:00
RewriteSumIfFunctionVisitor.cpp
RewriteSumIfFunctionVisitor.h
RowRefs.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
RowRefs.h Review fixes 2022-10-21 22:40:13 +02:00
SelectIntersectExceptQueryVisitor.cpp implement intersect + except distinct 2022-08-30 18:09:01 +08:00
SelectIntersectExceptQueryVisitor.h implement intersect + except distinct 2022-08-30 18:09:01 +08:00
SelectQueryOptions.h Revert "Fix converting types for UNION queries (may produce LOGICAL_ERROR)" 2022-06-28 22:50:01 +03:00
Session.cpp pass session certificate for showCertificate() 2022-09-18 07:11:52 +00:00
Session.h pass session certificate for showCertificate() 2022-09-18 07:11:52 +00:00
SessionLog.cpp add system table asynchronous_inserts_log 2022-10-03 21:35:55 +00:00
SessionLog.h
Set.cpp Fix create set with wrong header when data type is lowcardinality 2022-10-22 16:17:05 +00:00
Set.h Add Creating/FilterBySetsOnTheFlyStep for full sorting join 2022-08-29 09:46:57 +00:00
SetVariants.cpp abort instead of __builtin_unreachable in debug builds 2022-10-07 21:49:08 +02:00
SetVariants.h
sortBlock.cpp
sortBlock.h
SortedBlocksWriter.cpp Followup for TemporaryDataOnDisk 2022-10-12 15:25:23 +02:00
SortedBlocksWriter.h Upd TemporaryFileOnDisk 2022-08-24 16:15:54 +00:00
SquashingTransform.cpp
SquashingTransform.h
StorageID.cpp
StorageID.h code optimization, add test 2022-09-09 23:27:42 +08:00
SubstituteColumnOptimizer.cpp
SubstituteColumnOptimizer.h
SynonymsExtensions.cpp Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
SynonymsExtensions.h Consolidate config_core.h into config.h 2022-09-28 13:31:57 +00:00
SystemLog.cpp add system table asynchronous_inserts_log 2022-10-03 21:35:55 +00:00
SystemLog.h add system table asynchronous_inserts_log 2022-10-03 21:35:55 +00:00
TableJoin.cpp Fixed tests 2022-10-24 10:22:20 +02:00
TableJoin.h Added JOIN support for different algorithm 2022-10-24 10:22:21 +02:00
TableOverrideUtils.cpp
TableOverrideUtils.h
TablesStatus.cpp Revert "Fix errors of CheckTriviallyCopyableMove type" 2022-06-07 13:53:10 +02:00
TablesStatus.h
TemporaryDataOnDisk.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
TemporaryDataOnDisk.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
TextLog.cpp
TextLog.h
threadPoolCallbackRunner.cpp Get rid of static threadpools 2022-09-07 17:48:11 +02:00
threadPoolCallbackRunner.h Get rid of static threadpools 2022-09-07 17:48:11 +02:00
ThreadStatusExt.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
TraceCollector.cpp
TraceCollector.h
TraceLog.cpp
TraceLog.h
TransactionLog.cpp Define methods for multi read requests 2022-09-29 09:19:47 +00:00
TransactionLog.h Define methods for multi read requests 2022-09-29 09:19:47 +00:00
TransactionsInfoLog.cpp First try at reducing the use of StringRef 2022-07-17 17:26:02 +00:00
TransactionsInfoLog.h
TransactionVersionMetadata.cpp fix race on queue processing 2022-06-15 16:21:26 +02:00
TransactionVersionMetadata.h
TranslateQualifiedNamesVisitor.cpp Support countState(*) 2022-10-01 14:59:26 +08:00
TranslateQualifiedNamesVisitor.h Pass const std::string_view & by value, not by reference 2022-07-14 16:11:57 +00:00
TreeCNFConverter.cpp fix some typos and clang-tidy warnings 2022-09-05 09:50:24 +08:00
TreeCNFConverter.h fix some typos and clang-tidy warnings 2022-09-05 09:50:24 +08:00
TreeOptimizer.cpp Split UserDefinedSQLObjectsLoader to interface and implementation. 2022-10-13 10:32:32 +02:00
TreeOptimizer.h
TreeRewriter.cpp Added support for JOIN, ARRAY JOIN 2022-10-24 10:22:19 +02:00
TreeRewriter.h fix some typos and clang-tidy warnings 2022-09-05 09:50:24 +08:00
WhereConstraintsOptimizer.cpp fix some typos and clang-tidy warnings 2022-09-05 09:50:24 +08:00
WhereConstraintsOptimizer.h
WindowDescription.cpp Added WINDOW functions support 2022-10-24 10:22:20 +02:00
WindowDescription.h Added WINDOW functions support 2022-10-24 10:22:20 +02:00
ZooKeeperLog.cpp Fix zookeeper_log 2022-09-27 12:36:59 +00:00
ZooKeeperLog.h Add duration_ms into system.zookeeper_log 2022-07-28 22:34:51 +03:00