.. |
Access
|
fix style check
|
2022-06-02 15:27:32 +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
|
|
|
fuzzers
|
|
|
JIT
|
Fixed tests
|
2022-05-11 21:59:51 +02:00 |
MySQL
|
Merge branch 'master' into mysqldump-format
|
2022-04-28 15:58:18 +02:00 |
tests
|
|
|
ActionLocksManager.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Fix a typo
|
2022-05-27 15:52:04 +08:00 |
ActionsDAG.h
|
Simplify code a little bit.
|
2022-05-10 16:00:00 +00:00 |
ActionsVisitor.cpp
|
Cleanup ActionsVisitor
|
2022-06-16 15:11:16 +00:00 |
ActionsVisitor.h
|
Remove redundant code
|
2022-06-16 15:49:49 +00:00 |
AddDefaultDatabaseVisitor.h
|
|
|
AddIndexConstraintsOptimizer.cpp
|
|
|
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
addMissingDefaults.h
|
|
|
addTypeConversionToAST.cpp
|
|
|
addTypeConversionToAST.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
AggregateDescription.cpp
|
|
|
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
|
|
Aggregator.cpp
|
Interpreters/Aggregator: cleaner interface for block release during merge
|
2022-06-16 09:58:36 +03:00 |
Aggregator.h
|
Interpreters/Aggregator: cleaner interface for block release during merge
|
2022-06-16 09:58:36 +03:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
|
|
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
Add comment for visiting children of select in ApplyWithGlobalVisitor
|
2022-05-13 10:53:26 +00:00 |
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
Merge pull request #36444 from rschu1ze/clang-tidy-fixes
|
2022-04-21 16:11:27 +02:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
ArrayJoinAction.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ArrayJoinAction.h
|
|
|
ArrayJoinedColumnsVisitor.h
|
|
|
asof.h
|
|
|
AsynchronousInsertQueue.cpp
|
Fixing style.
|
2022-05-26 11:09:36 +00:00 |
AsynchronousInsertQueue.h
|
|
|
AsynchronousMetricLog.cpp
|
Round values for the log
|
2022-04-17 22:07:50 +02:00 |
AsynchronousMetricLog.h
|
Avoid recreation of system.asynchronous_metric_log (due to difference in codec)
|
2022-04-30 12:19:29 +03:00 |
AsynchronousMetrics.cpp
|
Extract diff from PR 36171
|
2022-06-15 16:40:18 +02:00 |
AsynchronousMetrics.h
|
|
|
BloomFilter.cpp
|
|
|
BloomFilter.h
|
|
|
BloomFilterHash.h
|
|
|
CancellationCode.h
|
|
|
castColumn.cpp
|
|
|
castColumn.h
|
|
|
CatBoostModel.cpp
|
Use compile-time check for Exception messages, fix wrong messages
|
2022-03-29 13:16:11 +00:00 |
CatBoostModel.h
|
|
|
ClientInfo.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
ClientInfo.h
|
Slightly better mysql handler
|
2022-04-27 18:28:09 +08:00 |
Cluster.cpp
|
More accurate access checking for RESTORE.
|
2022-06-19 11:26:41 +02:00 |
Cluster.h
|
More accurate access checking for RESTORE.
|
2022-06-19 11:26:41 +02:00 |
ClusterDiscovery.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ClusterDiscovery.h
|
|
|
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
|
|
CollectJoinOnKeysVisitor.h
|
|
|
ColumnAliasesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ColumnAliasesVisitor.h
|
|
|
ComparisonGraph.cpp
|
|
|
ComparisonGraph.h
|
|
|
ConcurrentHashJoin.cpp
|
Update ConcurrentHashJoin.cpp
|
2022-05-10 14:14:58 +02:00 |
ConcurrentHashJoin.h
|
Minor style changes for ConcurrentHashJoin
|
2022-05-06 15:17:46 +00:00 |
Context_fwd.h
|
|
|
Context.cpp
|
Merge pull request #37859 from KinderRiven/support_max_request_cache_size
|
2022-06-10 16:17:18 +02:00 |
Context.h
|
Merge pull request #36060 from Varinara/master
|
2022-06-07 11:22:23 +02:00 |
convertFieldToType.cpp
|
fix ConvertDecimalType unexpected behavior
|
2022-04-24 23:35:58 +08:00 |
convertFieldToType.h
|
|
|
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
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
More consistent use of platform macros
|
2022-06-10 10:22:31 +02:00 |
CrashLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
createBlockSelector.cpp
|
Optimize most important parts with NEON SIMD
|
2022-06-15 13:19:29 +00:00 |
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Upd cross_to_inner_join_rewrite setting, add test
|
2022-05-11 10:56:43 +00:00 |
CrossToInnerJoinVisitor.h
|
Upd cross_to_inner_join_rewrite setting, add test
|
2022-05-11 10:56:43 +00:00 |
DatabaseAndTableWithAlias.cpp
|
Merge branch 'master' into ast-table-identifier-2
|
2021-04-09 17:56:15 +03:00 |
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Disable the 'BACKUP ALL' command (it's not quite clear what to do with predefined databases).
|
2022-06-15 20:32:35 +02:00 |
DatabaseCatalog.h
|
Disable the 'BACKUP ALL' command (it's not quite clear what to do with predefined databases).
|
2022-06-15 20:32:35 +02:00 |
DDLTask.cpp
|
better code
|
2022-06-01 16:49:26 +02:00 |
DDLTask.h
|
fix sync database replica
|
2022-05-06 18:37:20 +02:00 |
DDLWorker.cpp
|
Merge branch 'master' into remove-useless-code-2
|
2022-06-03 13:58:45 +00:00 |
DDLWorker.h
|
remove last mentions of data streams
|
2022-05-09 19:15:24 +00:00 |
DictionaryReader.cpp
|
|
|
DictionaryReader.h
|
|
|
DNSCacheUpdater.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
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
|
|
|
EmbeddedDictionaries.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
EmbeddedDictionaries.h
|
|
|
evaluateConstantExpression.cpp
|
Merge pull request #36937 from bigo-sg/fix_settings
|
2022-06-02 17:45:17 +03:00 |
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
Fix build.
|
2022-06-20 03:44:59 +02:00 |
executeDDLQueryOnCluster.h
|
Merge branch 'master' into refactor-read-metrics-and-callbacks
|
2022-05-25 16:27:40 +02:00 |
executeQuery.cpp
|
Print query in one line on fatal errors
|
2022-06-03 18:55:53 +03:00 |
executeQuery.h
|
|
|
ExecuteScalarSubqueriesVisitor.cpp
|
Fix some tests.
|
2022-05-27 20:47:35 +00:00 |
ExecuteScalarSubqueriesVisitor.h
|
|
|
ExpressionActions.cpp
|
Merge pull request #37336 from vdimir/fix_clash_const_aggegate_join
|
2022-05-23 17:09:30 +02:00 |
ExpressionActions.h
|
Perserve constness in ExpressionActionsChain::JoinStep
|
2022-05-20 11:31:58 +00:00 |
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Merge pull request #34632 from excitoon-favorites/optimizedprocessing
|
2022-06-20 20:03:26 +02:00 |
ExpressionAnalyzer.h
|
Merge pull request #34632 from excitoon-favorites/optimizedprocessing
|
2022-06-20 20:03:26 +02:00 |
ExpressionJIT.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ExternalDictionariesLoader.cpp
|
More logs on unsuccessful part removal
|
2022-04-04 13:17:33 +02:00 |
ExternalDictionariesLoader.h
|
|
|
ExternalLoader.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ExternalLoader.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ExternalLoaderDatabaseConfigRepository.h
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
|
|
ExternalLoaderXMLConfigRepository.h
|
|
|
ExternalModelsLoader.cpp
|
|
|
ExternalModelsLoader.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
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
|
Fixing some warnings
|
2022-05-16 20:59:27 +02:00 |
FilesystemCacheLog.h
|
Fixing some warnings
|
2022-05-16 20:59:27 +02:00 |
FillingRow.cpp
|
do not fill 'to' boundary
|
2022-06-14 22:26:50 -04:00 |
FillingRow.h
|
remove last mentions of data streams
|
2022-05-09 19:15:24 +00:00 |
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
|
|
GatherFunctionQuantileVisitor.h
|
|
|
GetAggregatesVisitor.cpp
|
Small refactoring
|
2022-06-18 01:40:30 +00:00 |
GetAggregatesVisitor.h
|
Small refactoring
|
2022-06-16 15:41:04 +00:00 |
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
getColumnFromBlock.cpp
|
|
|
getColumnFromBlock.h
|
|
|
getHeaderForProcessingStage.cpp
|
|
|
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
|
Fix
|
2021-12-21 01:19:51 +03:00 |
getTableOverride.h
|
|
|
GlobalSubqueriesVisitor.h
|
Don't materialize external tables if it's explain statement
|
2022-04-08 09:00:55 +08: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 significant join performance regression
|
2022-06-14 21:14:18 +08:00 |
HashJoin.h
|
|
|
IdentifierSemantic.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
IdentifierSemantic.h
|
|
|
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
|
|
IExternalLoaderConfigRepository.h
|
|
|
IInterpreter.cpp
|
|
|
IInterpreter.h
|
|
|
IInterpreterUnionOrSelectQuery.cpp
|
Cleanup
|
2022-06-02 10:34:40 +00:00 |
IInterpreterUnionOrSelectQuery.h
|
Minor cleanup
|
2022-06-05 14:31:07 +00:00 |
IJoin.h
|
Improve join
|
2022-04-19 16:07:30 +08:00 |
InDepthNodeVisitor.h
|
Rework expressions with window functions
|
2022-06-16 13:29:56 +00:00 |
InJoinSubqueriesPreprocessor.cpp
|
|
|
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
inplaceBlockConversions.h
|
|
|
InternalTextLogsQueue.cpp
|
Remove include
|
2022-05-18 01:44:51 +00:00 |
InternalTextLogsQueue.h
|
Fix possible deadlock in OvercommitTracker during logging
|
2022-05-17 18:07:52 +00:00 |
InterpreterAlterQuery.cpp
|
Fixed clang-tidy check "bugprone-branch-clone"
|
2022-04-30 19:40:28 +02:00 |
InterpreterAlterQuery.h
|
|
|
InterpreterBackupQuery.cpp
|
Improved using ThreadPool for making backup or restoring, changed columns in system.backups.
|
2022-05-03 11:03:13 +02:00 |
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterCheckQuery.h
|
|
|
InterpreterCreateFunctionQuery.cpp
|
Validate that function had been passed in CREATE FUNCTION
|
2022-05-01 19:01:03 +03:00 |
InterpreterCreateFunctionQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
support CREATE EMPTY AS SELECT
|
2022-06-21 15:03:58 +02:00 |
InterpreterCreateQuery.h
|
Extract schema only once on table creation and add it to metadata (#34684)
|
2022-03-04 21:23:19 +03:00 |
InterpreterDescribeQuery.cpp
|
|
|
InterpreterDescribeQuery.h
|
|
|
InterpreterDropFunctionQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterDropQuery.h
|
|
|
InterpreterExistsQuery.cpp
|
|
|
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
Move some resources
|
2022-05-23 13:46:57 +00:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
|
|
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
|
|
InterpreterFactory.h
|
|
|
InterpreterInsertQuery.cpp
|
Small refactoring
|
2022-06-16 15:41:04 +00:00 |
InterpreterInsertQuery.h
|
|
|
InterpreterKillQueryQuery.cpp
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterRenameQuery.h
|
|
|
InterpreterSelectIntersectExceptQuery.cpp
|
Cleanup
|
2022-06-02 10:34:40 +00:00 |
InterpreterSelectIntersectExceptQuery.h
|
Cleanup
|
2022-06-02 10:34:40 +00:00 |
InterpreterSelectQuery.cpp
|
Merge pull request #37469 from azat/projections-optimize_aggregation_in_order
|
2022-06-21 12:17:35 +02:00 |
InterpreterSelectQuery.h
|
Draft.
|
2022-06-20 05:15:07 +03:00 |
InterpreterSelectWithUnionQuery.cpp
|
Cleanup
|
2022-06-02 10:34:40 +00:00 |
InterpreterSelectWithUnionQuery.h
|
Cleanup
|
2022-06-02 10:34:40 +00:00 |
InterpreterSetQuery.cpp
|
|
|
InterpreterSetQuery.h
|
|
|
InterpreterShowCreateQuery.cpp
|
|
|
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowProcesslistQuery.cpp
|
|
|
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowTablesQuery.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowTablesQuery.h
|
|
|
InterpreterSystemQuery.cpp
|
Merge pull request #38088 from kssenii/diff-with-cache
|
2022-06-17 12:07:31 +02:00 |
InterpreterSystemQuery.h
|
fix flaky tests
|
2022-05-26 14:17:05 +02:00 |
InterpreterTransactionControlQuery.cpp
|
fix race on queue processing
|
2022-06-15 16:21:26 +02:00 |
InterpreterTransactionControlQuery.h
|
better waiting, add fault injection
|
2022-05-20 22:10:01 +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
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InterserverCredentials.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InterserverIOHandler.h
|
Mark Context::getInterserverIOHandler() as const
|
2022-05-12 16:54:01 +03:00 |
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
join_common.cpp
|
Handle non unique column names in NotJoinedBlocks
|
2022-05-10 14:30:33 +00:00 |
join_common.h
|
|
|
joinDispatch.h
|
|
|
JoinedTables.cpp
|
|
|
JoinedTables.h
|
|
|
JoinSwitcher.cpp
|
Fix cast lowcard of nullable in JoinSwitcher
|
2022-05-23 13:05:59 +00:00 |
JoinSwitcher.h
|
|
|
JoinToSubqueryTransformVisitor.cpp
|
Add setting multiple_joins_try_to_keep_original_names
|
2022-06-16 15:50:03 +00:00 |
JoinToSubqueryTransformVisitor.h
|
Add setting multiple_joins_try_to_keep_original_names
|
2022-06-16 15:50:03 +00:00 |
Lemmatizers.cpp
|
|
|
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
loadMetadata.h
|
|
|
LogicalExpressionsOptimizer.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
LogicalExpressionsOptimizer.h
|
|
|
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
|
|
MergeJoin.cpp
|
Try to fix temporary name clash in partial merge join
|
2022-06-16 12:47:55 +00:00 |
MergeJoin.h
|
|
|
MergeTreeTransaction.cpp
|
fixes
|
2022-06-16 19:41:32 +02:00 |
MergeTreeTransaction.h
|
Fix typos and buge
|
2022-06-03 14:35:15 +02:00 |
MergeTreeTransactionHolder.cpp
|
better waiting, add fault injection
|
2022-05-20 22:10:01 +02:00 |
MergeTreeTransactionHolder.h
|
|
|
MetricLog.cpp
|
Remove microseconds from system.asynchronous_metric_log
|
2022-04-17 22:01:58 +02:00 |
MetricLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
misc.h
|
|
|
MonotonicityCheckVisitor.h
|
Small refactoring
|
2022-06-16 15:41:04 +00:00 |
MutationsInterpreter.cpp
|
Merge branch 'master' into fix-mutations-again
|
2022-06-03 14:17:05 +02:00 |
MutationsInterpreter.h
|
Better.
|
2022-05-24 20:06:08 +00:00 |
NormalizeSelectWithUnionQueryVisitor.cpp
|
|
|
NormalizeSelectWithUnionQueryVisitor.h
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Opentracing minimal changes for processors (#37837)
|
2022-06-09 14:43:50 +02:00 |
OpenTelemetrySpanLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:53:28 +02:00 |
OptimizeIfChains.cpp
|
|
|
OptimizeIfChains.h
|
replace multiIf to if in case of one condition
|
2022-05-31 14:45:12 +00:00 |
OptimizeIfWithConstantConditionVisitor.cpp
|
Remove Arcadia
|
2022-04-16 00:20:47 +02:00 |
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
Fix implicit cast for optimize_skip_unused_shards_rewrite_in
|
2022-05-12 16:17:30 +03:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
PartLog.cpp
|
Cleanup.
|
2022-06-20 18:18:17 +00:00 |
PartLog.h
|
FR: Expose what triggered the merge in system.part_log #26255
|
2022-06-01 16:58:06 +02:00 |
PredicateExpressionsOptimizer.cpp
|
|
|
PredicateExpressionsOptimizer.h
|
|
|
PredicateRewriteVisitor.cpp
|
Fix column matcher and column transformer
|
2022-04-20 01:22:04 +08:00 |
PredicateRewriteVisitor.h
|
|
|
PreparedSets.h
|
|
|
processColumnTransformers.cpp
|
|
|
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Print query in one line on fatal errors
|
2022-06-03 18:55:53 +03:00 |
ProcessList.h
|
Set is_all_data_sent on exceptions too
|
2022-04-30 13:00:44 +03:00 |
ProcessorsProfileLog.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ProcessorsProfileLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
ProfileEventsExt.cpp
|
Fix build
|
2022-04-20 13:34:17 +02:00 |
ProfileEventsExt.h
|
|
|
QueryAliasesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
QueryAliasesVisitor.h
|
|
|
QueryLog.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
QueryLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
QueryNormalizer.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
QueryNormalizer.h
|
|
|
QueryParameterVisitor.cpp
|
|
|
QueryParameterVisitor.h
|
Even more
|
2020-09-19 18:02:11 +03:00 |
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
Fix writting is_secure
|
2022-03-30 06:39:40 +00:00 |
QueryThreadLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
QueryViewsLog.cpp
|
|
|
QueryViewsLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
RedundantFunctionsInOrderByVisitor.h
|
|
|
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
|
|
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
ReplaceQueryParameterVisitor.cpp
|
|
|
ReplaceQueryParameterVisitor.h
|
|
|
RequiredSourceColumnsData.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
RequiredSourceColumnsData.h
|
|
|
RequiredSourceColumnsVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
RequiredSourceColumnsVisitor.h
|
|
|
RewriteAnyFunctionVisitor.cpp
|
Small refactoring
|
2022-06-16 15:41:04 +00:00 |
RewriteAnyFunctionVisitor.h
|
|
|
RewriteCountDistinctVisitor.cpp
|
Activated a bunch of LLVM 12/13/14 clang-tidy warnings
|
2022-05-03 09:22:11 +02:00 |
RewriteCountDistinctVisitor.h
|
Count distinct optimization by using subquery of group by (#35993)
|
2022-04-28 14:55:37 +02:00 |
RewriteCountVariantsVisitor.cpp
|
|
|
RewriteCountVariantsVisitor.h
|
|
|
RewriteFunctionToSubcolumnVisitor.cpp
|
|
|
RewriteFunctionToSubcolumnVisitor.h
|
|
|
RewriteSumIfFunctionVisitor.cpp
|
|
|
RewriteSumIfFunctionVisitor.h
|
|
|
RowRefs.cpp
|
Use proper type for RadixSortTraits in RowRefs.cpp
|
2022-03-27 11:32:51 +03:00 |
RowRefs.h
|
|
|
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
fix optimize_monotonous_functions_in_order_by in distributed queries
|
2022-06-01 00:50:28 +00:00 |
Session.cpp
|
better code
|
2022-06-01 16:49:26 +02:00 |
Session.h
|
review suggestions
|
2022-05-23 21:55:17 +02:00 |
SessionLog.cpp
|
review suggestions
|
2022-05-23 21:55:17 +02:00 |
SessionLog.h
|
review suggestions
|
2022-05-23 21:55:17 +02:00 |
Set.cpp
|
Make SortDescription::column_name always non-empty (#35805)
|
2022-04-04 14:17:15 +02:00 |
Set.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
SetVariants.cpp
|
|
|
SetVariants.h
|
|
|
sortBlock.cpp
|
Make SortDescription::column_name always non-empty (#35805)
|
2022-04-04 14:17:15 +02:00 |
sortBlock.h
|
|
|
SortedBlocksWriter.cpp
|
Better.
|
2022-05-24 20:06:08 +00:00 |
SortedBlocksWriter.h
|
|
|
SquashingTransform.cpp
|
Remove memory reservation for SquashingTransform
|
2022-04-29 17:04:56 +03:00 |
SquashingTransform.h
|
Remove memory reservation for SquashingTransform
|
2022-04-29 17:04:56 +03:00 |
StorageID.cpp
|
Merge branch 'master' into query_parameters
|
2021-10-18 17:34:20 +03:00 |
StorageID.h
|
|
|
SubqueryForSet.cpp
|
|
|
SubqueryForSet.h
|
|
|
SubstituteColumnOptimizer.cpp
|
|
|
SubstituteColumnOptimizer.h
|
|
|
SynonymsExtensions.cpp
|
|
|
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
review suggestions
|
2022-05-23 21:55:17 +02:00 |
SystemLog.h
|
fix
|
2022-05-01 19:45:16 +08:00 |
TableJoin.cpp
|
Fix error on joining with dictionary on some conditions
|
2022-05-31 16:02:57 +00:00 |
TableJoin.h
|
Perserve constness in ExpressionActionsChain::JoinStep
|
2022-05-20 11:31: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
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TextLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
threadPoolCallbackRunner.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
threadPoolCallbackRunner.h
|
Better
|
2022-04-07 18:48:35 +02:00 |
ThreadStatusExt.cpp
|
fixes
|
2022-06-16 19:41:32 +02:00 |
TraceCollector.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TraceCollector.h
|
|
|
TraceLog.cpp
|
|
|
TraceLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
TransactionLog.cpp
|
fix style check, add comments
|
2022-06-17 13:47:14 +02:00 |
TransactionLog.h
|
fix flaky tests
|
2022-05-26 14:17:05 +02:00 |
TransactionsInfoLog.cpp
|
|
|
TransactionsInfoLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
TransactionVersionMetadata.cpp
|
fix race on queue processing
|
2022-06-15 16:21:26 +02:00 |
TransactionVersionMetadata.h
|
|
|
TranslateQualifiedNamesVisitor.cpp
|
Fix clang-tidy-14, part 1
|
2022-05-27 22:52:14 +02:00 |
TranslateQualifiedNamesVisitor.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
TreeCNFConverter.cpp
|
|
|
TreeCNFConverter.h
|
|
|
TreeOptimizer.cpp
|
replace multiIf to if in case of one condition
|
2022-05-31 14:45:12 +00:00 |
TreeOptimizer.h
|
Apply optimizeCountConstantAndSumOne before JOINs
|
2022-05-10 14:30:33 +00:00 |
TreeRewriter.cpp
|
Merge branch 'master' into window-function-expression
|
2022-06-19 22:14:54 +00:00 |
TreeRewriter.h
|
Merge pull request #37913 from azat/parts-refcnt
|
2022-06-21 22:56:26 +02: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
|
Executable user defined functions extract parameters name and type from command value
|
2022-06-03 18:06:59 +02:00 |
UserDefinedExecutableFunctionFactory.h
|
Executable user defined functions support parameters
|
2022-06-03 18:05:37 +02:00 |
UserDefinedSQLFunctionFactory.cpp
|
Fix evaluateConstantExpression for subqueries
|
2022-04-28 22:09:29 +02:00 |
UserDefinedSQLFunctionFactory.h
|
|
|
UserDefinedSQLFunctionVisitor.cpp
|
|
|
UserDefinedSQLFunctionVisitor.h
|
|
|
UserDefinedSQLObjectsLoader.cpp
|
SQLUserDefinedFunctionsLoader allow symlinks in user_defined directory
|
2022-06-17 17:43:42 +02:00 |
UserDefinedSQLObjectsLoader.h
|
|
|
WhereConstraintsOptimizer.cpp
|
|
|
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
|
|
WindowDescription.h
|
Added optimize_read_in_window_order setting.
|
2022-06-20 05:15:07 +03:00 |
ZooKeeperLog.cpp
|
Fixing some warnings
|
2022-05-16 20:59:27 +02:00 |
ZooKeeperLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |