.. |
Access
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
ClusterProxy
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
examples
|
|
|
fuzzers
|
|
|
JIT
|
Add ability to pass range of rows to Aggregator
|
2022-04-29 06:57:55 +03:00 |
MySQL
|
Merge branch 'master' into mysqldump-format
|
2022-04-28 15:58:18 +02:00 |
tests
|
Remove the possibility of adding columns with table overrides
|
2021-12-22 08:20:14 +01:00 |
ActionLocksManager.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Merge remote-tracking branch 'origin/master' into grouping-sets-fix
|
2022-05-05 17:14:52 +00:00 |
ActionsDAG.h
|
Support distributed queries
|
2022-05-05 13:56:16 +00:00 |
ActionsVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ActionsVisitor.h
|
Remove Arcadia
|
2022-04-15 23:59:49 +02: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
|
|
|
AggregateDescription.cpp
|
|
|
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
|
|
Aggregator.cpp
|
Merge remote-tracking branch 'origin/master' into grouping-sets-fix
|
2022-05-05 17:14:52 +00:00 |
Aggregator.h
|
Cleanup code
|
2022-05-05 18:13:00 +00: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
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02: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
|
base should not depend on Common
|
2022-04-29 10:26:35 +08: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
|
|
|
AsynchronousMetrics.h
|
|
|
BloomFilter.cpp
|
|
|
BloomFilter.h
|
|
|
BloomFilterHash.h
|
|
|
CancellationCode.h
|
|
|
castColumn.cpp
|
|
|
castColumn.h
|
|
|
CatBoostModel.cpp
|
|
|
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
|
Make calculation of shard_num & replica_num not dependant on match of the cluster's definitions on nodes.
|
2022-05-03 11:01:44 +02:00 |
Cluster.h
|
Make calculation of shard_num & replica_num not dependant on match of the cluster's definitions on nodes.
|
2022-05-03 11:01:44 +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
|
|
|
Context_fwd.h
|
|
|
Context.cpp
|
Merge pull request #36864 from vitlibar/backup-improvements-4
|
2022-05-05 15:37:51 +02:00 |
Context.h
|
Improved using ThreadPool for making backup or restoring, changed columns in system.backups.
|
2022-05-03 11:03:13 +02:00 |
convertFieldToType.cpp
|
fix ConvertDecimalType unexpected behavior
|
2022-04-24 23:35:58 +08:00 |
convertFieldToType.h
|
|
|
ConvertStringsToEnumVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
CrashLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
createBlockSelector.cpp
|
|
|
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
|
|
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Fix build, pt. II
|
2022-05-04 10:15:25 +02:00 |
DatabaseCatalog.h
|
|
|
DDLTask.cpp
|
Make calculation of shard_num & replica_num not dependant on match of the cluster's definitions on nodes.
|
2022-05-03 11:01:44 +02:00 |
DDLTask.h
|
|
|
DDLWorker.cpp
|
Merge pull request #36715 from amosbird/refactorbase
|
2022-04-30 09:40:58 +03:00 |
DDLWorker.h
|
|
|
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
|
Fix build
|
2022-05-02 14:27:00 +02:00 |
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
Make calculation of shard_num & replica_num not dependant on match of the cluster's definitions on nodes.
|
2022-05-03 11:01:44 +02:00 |
executeDDLQueryOnCluster.h
|
Make calculation of shard_num & replica_num not dependant on match of the cluster's definitions on nodes.
|
2022-05-03 11:01:44 +02:00 |
executeQuery.cpp
|
Add Other Time Microseconds Profile Event
|
2022-05-02 17:13:57 +02:00 |
executeQuery.h
|
|
|
ExecuteScalarSubqueriesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ExecuteScalarSubqueriesVisitor.h
|
|
|
ExpressionActions.cpp
|
Support distributed queries
|
2022-05-05 13:56:16 +00:00 |
ExpressionActions.h
|
|
|
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Cleanup code
|
2022-05-05 18:13:00 +00:00 |
ExpressionAnalyzer.h
|
Cleanup code
|
2022-05-05 18:13:00 +00: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
|
|
|
ExternalUserDefinedExecutableFunctionsLoader.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
|
|
FilesystemCacheLog.cpp
|
Better
|
2022-05-03 15:55:36 +02:00 |
FilesystemCacheLog.h
|
Better
|
2022-05-03 15:55:36 +02:00 |
FillingRow.cpp
|
fixed Nullable, tests added
|
2022-04-08 10:52:10 -04:00 |
FillingRow.h
|
|
|
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
|
|
GatherFunctionQuantileVisitor.h
|
|
|
GetAggregatesVisitor.h
|
|
|
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
getColumnFromBlock.cpp
|
|
|
getColumnFromBlock.h
|
|
|
getHeaderForProcessingStage.cpp
|
|
|
getHeaderForProcessingStage.h
|
|
|
getTableExpressions.cpp
|
Containers iteration fix erase
|
2021-12-20 13:42:31 +03:00 |
getTableExpressions.h
|
|
|
getTableOverride.cpp
|
|
|
getTableOverride.h
|
Move to Interpreters
|
2021-12-17 22:19:10 +03:00 |
GlobalSubqueriesVisitor.h
|
Don't materialize external tables if it's explain statement
|
2022-04-08 09:00:55 +08:00 |
GroupByFunctionKeysVisitor.h
|
|
|
HashJoin.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +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
|
|
|
IInterpreterUnionOrSelectQuery.h
|
Fix performance regression of scalar query
|
2022-04-06 17:50:22 +08:00 |
IJoin.h
|
|
|
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
Apply suggestions from code review
|
2021-11-10 14:44:35 +03:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
inplaceBlockConversions.h
|
|
|
InternalTextLogsQueue.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InternalTextLogsQueue.h
|
|
|
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
|
Merge pull request #36803 from CurtizJ/fix-unflatten-nested
|
2022-05-02 13:58:16 +02:00 |
InterpreterCreateQuery.h
|
|
|
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
|
Merge branch 'master' into master2
|
2022-04-13 11:51:43 +00:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
|
|
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
|
|
InterpreterFactory.h
|
|
|
InterpreterInsertQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterInsertQuery.h
|
|
|
InterpreterKillQueryQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02: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
|
|
|
InterpreterSelectIntersectExceptQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
Remove whitespaces
|
2022-05-05 18:35:41 +00:00 |
InterpreterSelectQuery.h
|
Cleanup code
|
2022-05-05 18:13:00 +00:00 |
InterpreterSelectWithUnionQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterSelectWithUnionQuery.h
|
|
|
InterpreterSetQuery.cpp
|
|
|
InterpreterSetQuery.h
|
|
|
InterpreterShowCreateQuery.cpp
|
|
|
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowProcesslistQuery.cpp
|
|
|
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowTablesQuery.cpp
|
|
|
InterpreterShowTablesQuery.h
|
|
|
InterpreterSystemQuery.cpp
|
Merge pull request #36802 from KinderRiven/local_cache_trace
|
2022-05-02 00:16:04 +02:00 |
InterpreterSystemQuery.h
|
Added SYSTEM SYNC DATABASE query (#35944)
|
2022-05-01 15:40:18 +02:00 |
InterpreterTransactionControlQuery.cpp
|
|
|
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUseQuery.cpp
|
|
|
InterpreterUseQuery.h
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterpreterWatchQuery.cpp
|
|
|
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
|
|
|
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
join_common.cpp
|
Fix assertion in join
|
2022-04-29 09:15:00 +00:00 |
join_common.h
|
|
|
joinDispatch.h
|
|
|
JoinedTables.cpp
|
|
|
JoinedTables.h
|
|
|
JoinSwitcher.cpp
|
|
|
JoinSwitcher.h
|
|
|
JoinToSubqueryTransformVisitor.cpp
|
Merge branch 'master' into fixcolumnmatcher
|
2022-04-21 02:15:25 +03:00 |
JoinToSubqueryTransformVisitor.h
|
|
|
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
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
MergeJoin.h
|
|
|
MergeTreeTransaction.cpp
|
slightly beter fix
|
2022-04-11 16:25:59 +02:00 |
MergeTreeTransaction.h
|
fix a race condition
|
2022-04-07 18:17:43 +02:00 |
MergeTreeTransactionHolder.cpp
|
|
|
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
|
Refactor joinGet and implement multi-key lookup.
|
2020-07-28 22:38:52 +08:00 |
MonotonicityCheckVisitor.h
|
|
|
MutationsInterpreter.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
MutationsInterpreter.h
|
|
|
NormalizeSelectWithUnionQueryVisitor.cpp
|
|
|
NormalizeSelectWithUnionQueryVisitor.h
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
fix transform_null_in with sets of tuples
|
2020-11-05 21:07:44 +03:00 |
OpenTelemetrySpanLog.cpp
|
|
|
OpenTelemetrySpanLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:53:28 +02:00 |
OptimizeIfChains.cpp
|
|
|
OptimizeIfChains.h
|
|
|
OptimizeIfWithConstantConditionVisitor.cpp
|
Remove Arcadia
|
2022-04-16 00:20:47 +02:00 |
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
|
|
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
PartLog.cpp
|
Remove microseconds from system.asynchronous_metric_log
|
2022-04-17 22:01:58 +02:00 |
PartLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +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
|
Revert "Revert "Memory overcommit: continue query execution if memory is available""
|
2022-05-03 00:45:13 +02: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
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
QueryParameterVisitor.cpp
|
|
|
QueryParameterVisitor.h
|
|
|
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
|
|
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
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02: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
|
|
|
RowRefs.h
|
|
|
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
Don't materialize external tables if it's explain statement
|
2022-04-08 09:00:55 +08:00 |
Session.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
Session.h
|
|
|
SessionLog.cpp
|
Fixed missing enum values for ClientInfo::Interface
|
2022-04-21 12:16:12 +03:00 |
SessionLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +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
|
|
|
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
|
|
|
StorageID.h
|
|
|
SubqueryForSet.cpp
|
|
|
SubqueryForSet.h
|
|
|
SubstituteColumnOptimizer.cpp
|
|
|
SubstituteColumnOptimizer.h
|
|
|
SynonymsExtensions.cpp
|
|
|
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
fix
|
2022-05-01 19:45:16 +08:00 |
SystemLog.h
|
fix
|
2022-05-01 19:45:16 +08:00 |
TableJoin.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TableJoin.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TableOverrideUtils.cpp
|
|
|
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
|
|
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
|
Remove outdated comment from ThreadStatusExt
|
2022-04-29 17:04:56 +03: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
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TransactionLog.h
|
|
|
TransactionsInfoLog.cpp
|
|
|
TransactionsInfoLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
TransactionVersionMetadata.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TransactionVersionMetadata.h
|
|
|
TranslateQualifiedNamesVisitor.cpp
|
Update TranslateQualifiedNamesVisitor.cpp
|
2022-04-24 05:04:13 +03:00 |
TranslateQualifiedNamesVisitor.h
|
|
|
TreeCNFConverter.cpp
|
|
|
TreeCNFConverter.h
|
|
|
TreeOptimizer.cpp
|
Merge remote-tracking branch 'origin/master' into grouping-sets-fix
|
2022-05-05 17:14:52 +00:00 |
TreeOptimizer.h
|
|
|
TreeRewriter.cpp
|
Merge pull request #36444 from rschu1ze/clang-tidy-fixes
|
2022-04-21 16:11:27 +02:00 |
TreeRewriter.h
|
|
|
UserDefinedExecutableFunction.cpp
|
|
|
UserDefinedExecutableFunction.h
|
|
|
UserDefinedExecutableFunctionFactory.cpp
|
Throw exception when file cant be executed instead of displaying success
|
2022-04-12 17:52:44 +02:00 |
UserDefinedExecutableFunctionFactory.h
|
|
|
UserDefinedSQLFunctionFactory.cpp
|
Fix evaluateConstantExpression for subqueries
|
2022-04-28 22:09:29 +02:00 |
UserDefinedSQLFunctionFactory.h
|
|
|
UserDefinedSQLFunctionVisitor.cpp
|
|
|
UserDefinedSQLFunctionVisitor.h
|
|
|
UserDefinedSQLObjectsLoader.cpp
|
Merge pull request #36715 from amosbird/refactorbase
|
2022-04-30 09:40:58 +03:00 |
UserDefinedSQLObjectsLoader.h
|
|
|
WhereConstraintsOptimizer.cpp
|
|
|
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
|
|
WindowDescription.h
|
|
|
ZooKeeperLog.cpp
|
add thread_id and query_id to zookeeper_log
|
2022-04-08 17:10:08 +02:00 |
ZooKeeperLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |