..
Access
Better
2022-09-21 10:16:49 +00:00
Cache
Merge pull request #41733 from kssenii/cache-logging-level-reduce
2022-09-24 17:20:46 +02:00
ClusterProxy
when using clang12 compile, the unused filed shard_count will cause compile error. So delete it.
2022-06-16 10:43:31 +08:00
examples
Fix 8/9 of trash
2022-09-19 08:53:20 +02:00
fuzzers
Prefix overridden add_executable() command with "clickhouse_"
2022-07-11 19:36:18 +02:00
JIT
Temporary disable complation of compileAddIntoAggregateStatesFunctions
2022-09-10 21:38:35 +02:00
MySQL
tests
Merge pull request #41042 from kssenii/refactor-cache-for-async-download
2022-09-13 12:26:35 +02: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
Add comments to FunctionNameNormalizer.
2022-09-19 22:07:04 +08:00
ActionsVisitor.cpp
40907 Parameterized views as table functions
2022-09-26 15:22:17 +02:00
ActionsVisitor.h
Refactor PreparedSets/SubqueryForSet
2022-07-26 18:39:02 +00:00
AddDefaultDatabaseVisitor.h
AddIndexConstraintsOptimizer.cpp
AddIndexConstraintsOptimizer.h
addMissingDefaults.cpp
ActionsDAG rename index to outputs
2022-08-08 18:01:32 +02:00
addMissingDefaults.h
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
Merge pull request #41186 from ClickHouse/fix-three-fourth-of-trash
2022-09-22 07:28:26 +03:00
Aggregator.h
Prefetching in aggregation ( #39304 )
2022-09-21 18:59:07 +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
AsynchronousInsertQueue.cpp
fix writing of empty columns of type Object
2022-09-15 03:38:22 +00:00
AsynchronousInsertQueue.h
Terminate AsynchronousInsertQueue w/o waiting for timeout
2022-09-12 16:11:54 +02:00
AsynchronousMetricLog.cpp
AsynchronousMetricLog.h
Remove useless codec from system.asynchronous_metric_log
2022-06-25 07:16:25 +02:00
AsynchronousMetrics.cpp
Purge jemalloc arenas in case of high memory usage. ( #40277 )
2022-09-20 23:56:10 +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
castColumn.h
ClientInfo.cpp
ClientInfo.h
Remove using namespace from header
2022-08-25 20:20:13 +08:00
Cluster.cpp
update tcp protocol, add quota_key
2022-08-03 15:44:08 -04: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
ComparisonGraph.h
ConcurrentHashJoin.cpp
Merge branch 'master' into refactor-prepared-sets
2022-08-04 13:27:38 +02:00
ConcurrentHashJoin.h
upd ConcurrentHashJoin
2022-07-12 20:22:35 +02:00
Context_fwd.h
Remove old code
2021-07-06 05:31:09 +03:00
Context.cpp
40907 Parameterized views as table functions
2022-09-26 15:22:17 +02:00
Context.h
Fix 5/6 of trash
2022-09-19 08:50:53 +02:00
convertFieldToType.cpp
Code simplification
2022-09-18 08:58:32 +02:00
convertFieldToType.h
fix some logical errors
2020-06-24 23:51:17 +03:00
ConvertFunctionOrLikeVisitor.cpp
Fix new occurrences of new clang-tidy warnings
2022-05-16 11:31:36 +02:00
ConvertFunctionOrLikeVisitor.h
Fix new occurrences of new clang-tidy warnings
2022-05-16 11:31:36 +02:00
ConvertStringsToEnumVisitor.cpp
ConvertStringsToEnumVisitor.h
CrashLog.cpp
More consistent use of platform macros
2022-06-10 10:22:31 +02:00
CrashLog.h
createBlockSelector.cpp
Optimize most important parts with NEON SIMD
2022-06-15 13:19:29 +00: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
Fix stack overflow on recursive Buffer tables and system.tables
2022-08-25 21:26:32 +02:00
DatabaseCatalog.h
remove unused dirs from store on all disks
2022-08-03 19:49:16 +02:00
DDLTask.cpp
fix "incorrect replica identifier"
2022-08-18 16:13:27 +02:00
DDLTask.h
fix logical error on connection loss
2022-08-03 14:13:01 +02:00
DDLWorker.cpp
Improve remove recursive
2022-09-01 12:16:13 +00:00
DDLWorker.h
fix issuse#41096
2022-09-14 09:15:40 +00:00
DirectJoin.cpp
better code for join with dict
2022-08-10 14:20:29 +00:00
DirectJoin.h
better code for join with dict
2022-08-10 14:20:29 +00:00
DNSCacheUpdater.cpp
DNSCacheUpdater.h
DuplicateOrderByVisitor.cpp
DuplicateOrderByVisitor.h
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
fix ON CLUSTER with Replicated database cluster
2022-09-15 21:15:57 +02:00
executeDDLQueryOnCluster.h
ignore cluster if equals to db name
2022-07-06 19:54:05 +02:00
executeQuery.cpp
Merge pull request #41186 from ClickHouse/fix-three-fourth-of-trash
2022-09-22 07:28:26 +03:00
executeQuery.h
ExecuteScalarSubqueriesVisitor.cpp
Fix some tests.
2022-05-27 20:47:35 +00:00
ExecuteScalarSubqueriesVisitor.h
ExpressionActions.cpp
Merge remote-tracking branch 'origin/master' into skipping_sorting_step
2022-08-11 12:35:55 +00:00
ExpressionActions.h
ExpressionStep: simple check if expression changes sorting order
2022-08-02 10:45:05 +00:00
ExpressionActionsSettings.cpp
ExpressionActionsSettings.h
ExpressionAnalyzer.cpp
40907 Parameterized views as table functions
2022-09-26 15:22:17 +02:00
ExpressionAnalyzer.h
Simplify the code and check what will happen
2022-08-15 06:56:29 +02:00
ExpressionJIT.cpp
Reduce some usage of StringRef
2022-08-21 18:10:32 +00:00
ExternalDictionariesLoader.cpp
ExternalDictionariesLoader.h
ExternalLoader.cpp
Remove dictionaries from prometheus metrics on DETACH/DROP
2022-08-06 12:58:07 +03:00
ExternalLoader.h
ExternalLoaderDatabaseConfigRepository.h
ExternalLoaderDictionaryStorageConfigRepository.cpp
ExternalLoaderDictionaryStorageConfigRepository.h
ExternalLoaderTempConfigRepository.cpp
ExternalLoaderTempConfigRepository.h
ExternalLoaderXMLConfigRepository.cpp
ExternalLoaderXMLConfigRepository.h
ExternalUserDefinedExecutableFunctionsLoader.cpp
Disable parameters for non direct executable user defined functions
2022-06-16 16:29:04 +02:00
ExternalUserDefinedExecutableFunctionsLoader.h
ExtractExpressionInfoVisitor.cpp
ExtractExpressionInfoVisitor.h
FilesystemCacheLog.cpp
Fix String in log entry
2022-09-12 18:53:54 +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
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
getColumnFromBlock.h
getHeaderForProcessingStage.cpp
Fix exponential query rewrite in case of lots of cross joins with where
2022-09-12 15:05:34 +00: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
Rename join_common -> JoinUtils
2022-08-10 14:20:28 +00:00
HashJoin.h
IKeyValueEntity is not inheritor of IStorage
2022-08-10 14:20:28 +00: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
Rework expressions with window functions
2022-06-16 13:29:56 +00:00
InJoinSubqueriesPreprocessor.cpp
Join enums refactoring
2022-07-29 18:35:05 +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
InterpreterCreateFunctionQuery.h
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
Merge pull request #41495 from canhld94/ch_fixedstring_len
2022-09-21 19:35:34 +02: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
fix filling of empty Nested + small refactoring
2022-06-17 01:10:52 +00:00
InterpreterDescribeQuery.h
InterpreterDropFunctionQuery.cpp
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
make tryEnqueueReplicatedDDL virtual
2022-09-16 16:25:32 +02:00
InterpreterDropQuery.h
deprecate Ordinary database
2022-06-23 10:20:14 +02:00
InterpreterExistsQuery.cpp
InterpreterExistsQuery.h
InterpreterExplainQuery.cpp
Revert "Query plan optimization setting: read in window order"
2022-09-09 22:15:38 +02:00
InterpreterExplainQuery.h
InterpreterExternalDDLQuery.cpp
InterpreterExternalDDLQuery.h
InterpreterFactory.cpp
Merge remote-tracking branch 'origin/master' into tracing_context_propagation
2022-08-02 10:02:09 +08:00
InterpreterFactory.h
InterpreterInsertQuery.cpp
implement intersect + except distinct
2022-08-30 18:09:01 +08:00
InterpreterInsertQuery.h
InterpreterKillQueryQuery.cpp
Remove some methods
2022-09-10 05:04:40 +02:00
InterpreterKillQueryQuery.h
InterpreterOptimizeQuery.cpp
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
40907 Parameterized views as table functions
2022-09-26 15:22:17 +02:00
InterpreterSelectQuery.h
Merge remote-tracking branch 'origin/master' into skipping_sorting_step
2022-08-13 21:46:34 +00: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
Extend protocol with query parameters ( #39906 )
2022-08-12 14:28:35 +02: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
Add SYSTEM RELOAD USERS command.
2022-09-18 12:44:00 +02:00
InterpreterSystemQuery.h
stop background ops before converting db engine
2022-09-09 18:27:19 +02:00
InterpreterTransactionControlQuery.cpp
fix race on queue processing
2022-06-15 16:21:26 +02:00
InterpreterTransactionControlQuery.h
Add implicit_transaction setting
2022-06-23 15:23:37 +02:00
InterpreterUseQuery.cpp
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
Lemmatizers.h
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
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp
MarkTableIdentifiersVisitor.h
MergeJoin.cpp
fix bugs in MergeJoin when 'not_processed' is not null
2022-08-18 18:09:47 +08: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
better waiting, add fault injection
2022-05-20 22:10:01 +02:00
MergeTreeTransactionHolder.h
MetricLog.cpp
MetricLog.h
misc.h
MonotonicityCheckVisitor.h
Small refactoring
2022-06-16 15:41:04 +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
implement intersect + except distinct
2022-08-30 18:09:01 +08: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
OptimizeIfChains.h
replace multiIf to if in case of one condition
2022-05-31 14:45:12 +00:00
OptimizeIfWithConstantConditionVisitor.cpp
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
First try at reducing the use of StringRef
2022-07-17 17:26:02 +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
upd PreparedSets: rename/change signature of methods, add comments
2022-07-27 11:22:16 +00:00
processColumnTransformers.cpp
processColumnTransformers.h
ProcessList.cpp
Merge pull request #41343 from azat/deadlock-fix
2022-09-20 16:59:31 +03:00
ProcessList.h
Fix possible hung/deadlock on query cancellation
2022-09-19 17:31:21 +02: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
40907 Parameterized views as table functions
2022-09-26 15:22:17 +02:00
QueryNormalizer.h
40907 Parameterized views as table functions
2022-09-26 15:22:17 +02:00
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
RedundantFunctionsInOrderByVisitor.h
RemoveInjectiveFunctionsVisitor.cpp
RemoveInjectiveFunctionsVisitor.h
RenameColumnVisitor.cpp
RenameColumnVisitor.h
replaceAliasColumnsInQuery.cpp
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
impl ( #40952 )
2022-09-04 16:26:31 +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
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
RewriteCountVariantsVisitor.h
Fix
2021-02-10 12:48:41 +08:00
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
Join enums refactoring
2022-07-29 18:35:05 +02:00
RowRefs.h
Join enums refactoring
2022-07-29 18:35:05 +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
better code
2022-06-01 16:49:26 +02:00
Session.h
Clean code
2022-08-24 15:59:44 +08:00
SessionLog.cpp
fix build with clang-15
2022-08-01 18:00:54 +02:00
SessionLog.h
review suggestions
2022-05-23 21:55:17 +02:00
Set.cpp
Merge pull request #40850 from canhld94/ch_canh_fix_set
2022-09-02 14:40:35 -04:00
Set.h
Add Creating/FilterBySetsOnTheFlyStep for full sorting join
2022-08-29 09:46:57 +00:00
SetVariants.cpp
SetVariants.h
sortBlock.cpp
sortBlock.h
SortedBlocksWriter.cpp
Merge pull request #41154 from azat/fix-sorted-block-writer
2022-09-13 19:14:45 +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
SynonymsExtensions.h
SystemLog.cpp
review suggestions
2022-05-23 21:55:17 +02:00
SystemLog.h
TableJoin.cpp
better code for join with dict
2022-08-10 14:20:29 +00:00
TableJoin.h
Create sets for joins: upd
2022-08-29 09:46:58 +00:00
TableOverrideUtils.cpp
TableOverrideUtils.h
TablesStatus.cpp
Revert "Fix errors of CheckTriviallyCopyableMove type"
2022-06-07 13:53:10 +02:00
TablesStatus.h
TextLog.cpp
TextLog.h
threadPoolCallbackRunner.cpp
threadPoolCallbackRunner.h
ThreadStatusExt.cpp
Optimize the lock contentions for ThreadGroupStatus::mutex
2022-09-22 16:23:16 +08:00
TraceCollector.cpp
TraceCollector.h
TraceLog.cpp
TraceLog.h
TransactionLog.cpp
Fix 5/6 of trash
2022-09-19 08:50:53 +02:00
TransactionLog.h
add some TSA aanotations
2022-06-27 22:48:27 +02: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
Pass const std::string_view & by value, not by reference
2022-07-14 16:11:57 +00: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
Tiny improvements along the code
2022-09-13 12:06:56 +00:00
TreeOptimizer.h
TreeRewriter.cpp
Merge pull request #41158 from den-crane/bug/trivial_count_optimization_with_array_join
2022-09-12 08:56:10 +03:00
TreeRewriter.h
fix some typos and clang-tidy warnings
2022-09-05 09:50:24 +08:00
UserDefinedExecutableFunction.cpp
Fixing some warnings
2022-05-16 20:59:27 +02:00
UserDefinedExecutableFunction.h
Executable user defined functions support parameters
2022-06-03 18:05:37 +02:00
UserDefinedExecutableFunctionFactory.cpp
Small style fixes
2022-09-15 13:05:18 +02:00
UserDefinedExecutableFunctionFactory.h
Executable user defined functions support parameters
2022-06-03 18:05:37 +02:00
UserDefinedSQLFunctionFactory.cpp
Style
2022-08-10 21:53:11 +02:00
UserDefinedSQLFunctionFactory.h
Don't visit the AST for UDFs if none are registered
2022-08-10 17:54:56 +02:00
UserDefinedSQLFunctionVisitor.cpp
UserDefinedSQLFunctionVisitor.h
UserDefinedSQLObjectsLoader.cpp
Pass const std::string_view & by value, not by reference
2022-07-14 16:11:57 +00:00
UserDefinedSQLObjectsLoader.h
Pass const std::string_view & by value, not by reference
2022-07-14 16:11:57 +00:00
WhereConstraintsOptimizer.cpp
fix some typos and clang-tidy warnings
2022-09-05 09:50:24 +08:00
WhereConstraintsOptimizer.h
Reduce dependencies on ASTSelectQuery.h
2021-11-26 18:35:24 +01:00
WindowDescription.cpp
Uppercase ROWS
, GROUPS
, RANGE
in queries with windows. ( #39410 )
2022-07-25 22:53:53 +02:00
WindowDescription.h
Uppercase ROWS
, GROUPS
, RANGE
in queries with windows. ( #39410 )
2022-07-25 22:53:53 +02:00
ZooKeeperLog.cpp
Add duration_ms into system.zookeeper_log
2022-07-28 22:34:51 +03:00
ZooKeeperLog.h
Add duration_ms into system.zookeeper_log
2022-07-28 22:34:51 +03:00