.. |
Access
|
|
|
Cache
|
Update LRUFileCachePriority.cpp
|
2023-03-09 19:55:58 +01:00 |
ClusterProxy
|
Merge branch 'master' into custom-key-parallel-replicas
|
2023-03-02 14:28:42 +00:00 |
examples
|
|
|
fuzzers
|
|
|
JIT
|
Optimize one nullable key aggregate performance (#45772)
|
2023-03-02 21:01:52 +01:00 |
MySQL
|
Small improvements
|
2023-02-16 10:51:13 +00:00 |
tests
|
remove counters for threads, fix negative counters
|
2023-03-15 22:22:22 +01:00 |
ActionLocksManager.cpp
|
|
|
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Analyzer added PREWHERE support
|
2023-03-15 15:21:49 +01:00 |
ActionsDAG.h
|
Analyzer added PREWHERE support
|
2023-03-15 15:21:49 +01:00 |
ActionsVisitor.cpp
|
Merge pull request #46583 from ClickHouse/Support_parameterized_view_with_in_clause
|
2023-02-20 18:26:31 +01:00 |
ActionsVisitor.h
|
|
|
AddDefaultDatabaseVisitor.h
|
Add parameterized RENAME queries
|
2023-02-14 13:01:06 +00:00 |
AddIndexConstraintsOptimizer.cpp
|
|
|
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
|
|
addMissingDefaults.h
|
|
|
addTypeConversionToAST.cpp
|
|
|
addTypeConversionToAST.h
|
|
|
AggregateDescription.cpp
|
|
|
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
|
|
AggregationUtils.cpp
|
|
|
AggregationUtils.h
|
|
|
Aggregator.cpp
|
work with comments on PR
|
2023-03-16 19:55:58 +01:00 |
Aggregator.h
|
Optimize one nullable key aggregate performance (#45772)
|
2023-03-02 21:01:52 +01:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
|
|
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
|
|
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
|
|
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
fix logic + better test
|
2023-02-22 13:30:57 +08:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
ArrayJoinAction.cpp
|
SIZES_OF_ARRAYS_DOESN_MATCH --> SIZES_OF_ARRAYS_DONT_MATCH
|
2023-02-27 08:31:40 +00:00 |
ArrayJoinAction.h
|
|
|
ArrayJoinedColumnsVisitor.h
|
|
|
AsynchronousInsertLog.cpp
|
|
|
AsynchronousInsertLog.h
|
|
|
AsynchronousInsertQueue.cpp
|
Revert "Merge pull request #46622 from ClickHouse/async-insert-memory-fix"
|
2023-03-11 17:01:10 +01:00 |
AsynchronousInsertQueue.h
|
Revert "Merge pull request #46622 from ClickHouse/async-insert-memory-fix"
|
2023-03-11 17:01:10 +01:00 |
AsynchronousMetricLog.cpp
|
|
|
AsynchronousMetricLog.h
|
|
|
BloomFilter.cpp
|
|
|
BloomFilter.h
|
|
|
BloomFilterHash.h
|
|
|
CancellationCode.h
|
|
|
castColumn.cpp
|
|
|
castColumn.h
|
|
|
ClientInfo.cpp
|
|
|
ClientInfo.h
|
|
|
Cluster.cpp
|
Address PR comments
|
2023-03-07 10:56:11 +00:00 |
Cluster.h
|
|
|
ClusterDiscovery.cpp
|
|
|
ClusterDiscovery.h
|
|
|
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
|
|
CollectJoinOnKeysVisitor.h
|
|
|
ColumnAliasesVisitor.cpp
|
|
|
ColumnAliasesVisitor.h
|
|
|
ComparisonGraph.cpp
|
|
|
ComparisonGraph.h
|
|
|
ConcurrentHashJoin.cpp
|
|
|
ConcurrentHashJoin.h
|
BackgroundSchedulePool should not have any query context
|
2023-02-22 10:50:51 +01:00 |
Context_fwd.h
|
|
|
Context.cpp
|
add pool size metrics
|
2023-03-16 17:31:41 +00:00 |
Context.h
|
Better
|
2023-03-03 15:14:49 +00:00 |
convertFieldToType.cpp
|
|
|
convertFieldToType.h
|
|
|
ConvertFunctionOrLikeVisitor.cpp
|
Move likePatternToRegexp from Functions/ to Common/
|
2023-02-27 16:41:15 +00:00 |
ConvertFunctionOrLikeVisitor.h
|
|
|
ConvertStringsToEnumVisitor.cpp
|
|
|
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
initial solution
|
2023-03-06 19:35:00 +03:00 |
CrashLog.h
|
|
|
createBlockSelector.cpp
|
|
|
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Fix typo
|
2023-03-14 12:48:00 +01:00 |
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
|
|
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Add system.marked_dropped_tables (#47364)
|
2023-03-17 13:48:26 +03:00 |
DatabaseCatalog.h
|
Add system.marked_dropped_tables (#47364)
|
2023-03-17 13:48:26 +03:00 |
DDLTask.cpp
|
|
|
DDLTask.h
|
|
|
DDLWorker.cpp
|
Merge pull request #47499 from FrankChen021/span_kind
|
2023-03-13 11:35:03 +01:00 |
DDLWorker.h
|
|
|
DirectJoin.cpp
|
|
|
DirectJoin.h
|
|
|
DNSCacheUpdater.cpp
|
|
|
DNSCacheUpdater.h
|
|
|
DuplicateOrderByVisitor.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
DuplicateOrderByVisitor.h
|
|
|
EmbeddedDictionaries.cpp
|
|
|
EmbeddedDictionaries.h
|
|
|
evaluateConstantExpression.cpp
|
|
|
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
Set SpanKind for DDL
|
2023-03-12 21:31:24 +08:00 |
executeDDLQueryOnCluster.h
|
|
|
executeQuery.cpp
|
Merge branch 'master' into apply-settings-for-explain-earlier
|
2023-03-10 21:19:07 +01:00 |
executeQuery.h
|
add query_id header in all queries
|
2023-02-13 16:44:54 +00:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
|
|
ExecuteScalarSubqueriesVisitor.h
|
|
|
ExpressionActions.cpp
|
Add a style check for unsafe code
|
2023-03-18 03:29:14 +01:00 |
ExpressionActions.h
|
ReadFromMergeTree explain prewhere and row policy actions
|
2023-03-14 18:02:56 +01:00 |
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Fix NOT_IMPLEMENTED error with CROSS JOIN and algorithm = auto
|
2023-03-01 13:08:24 +00:00 |
ExpressionAnalyzer.h
|
|
|
ExpressionJIT.cpp
|
|
|
ExternalDictionariesLoader.cpp
|
Fixed tests
|
2023-03-01 18:05:07 +01:00 |
ExternalDictionariesLoader.h
|
Fixed tests
|
2023-03-01 18:05:07 +01:00 |
ExternalLoader.cpp
|
work with comments on PR
|
2023-03-16 19:55:58 +01:00 |
ExternalLoader.h
|
|
|
ExternalLoaderDatabaseConfigRepository.h
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
Apply some CTAD
|
2023-03-02 13:36:47 +00:00 |
ExternalLoaderXMLConfigRepository.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
|
|
FilesystemCacheLog.cpp
|
|
|
FilesystemCacheLog.h
|
|
|
FilesystemReadPrefetchesLog.cpp
|
|
|
FilesystemReadPrefetchesLog.h
|
|
|
FillingRow.cpp
|
Create result columns as MutableColumns at the begining
|
2023-03-16 17:44:29 +00:00 |
FillingRow.h
|
Create result columns as MutableColumns at the begining
|
2023-03-16 17:44:29 +00:00 |
FullSortingMergeJoin.h
|
Fixed tests
|
2023-03-11 11:51:54 +01:00 |
FunctionMaskingArgumentCheckVisitor.h
|
|
|
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
|
|
GatherFunctionQuantileVisitor.h
|
|
|
GetAggregatesVisitor.cpp
|
|
|
GetAggregatesVisitor.h
|
|
|
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
getColumnFromBlock.cpp
|
|
|
getColumnFromBlock.h
|
|
|
getCustomKeyFilterForParallelReplicas.cpp
|
Better
|
2023-03-03 15:14:49 +00:00 |
getCustomKeyFilterForParallelReplicas.h
|
Better
|
2023-03-03 15:14:49 +00:00 |
getHeaderForProcessingStage.cpp
|
Fixed tests
|
2023-03-01 18:05:07 +01:00 |
getHeaderForProcessingStage.h
|
Analyzer support storage Merge
|
2023-02-16 12:17:03 +01:00 |
getTableExpressions.cpp
|
|
|
getTableExpressions.h
|
|
|
getTableOverride.cpp
|
|
|
getTableOverride.h
|
|
|
GinFilter.cpp
|
|
|
GinFilter.h
|
|
|
GlobalSubqueriesVisitor.h
|
|
|
GraceHashJoin.cpp
|
Fix DelayedJoinedBlocksWorkerTransform for grace hash join
|
2023-03-03 16:30:01 +00:00 |
GraceHashJoin.h
|
Apply suggestions from code review
|
2023-03-06 16:56:02 +01:00 |
GroupByFunctionKeysVisitor.h
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
GroupingSetsRewriterVisitor.cpp
|
|
|
GroupingSetsRewriterVisitor.h
|
|
|
HashJoin.cpp
|
fix hashjoin debug code condition
|
2023-03-16 14:06:37 +01:00 |
HashJoin.h
|
|
|
IdentifierSemantic.cpp
|
|
|
IdentifierSemantic.h
|
|
|
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
|
|
IExternalLoaderConfigRepository.h
|
|
|
IInterpreter.cpp
|
More interesting settings for Stress Tests (#41534)
|
2023-02-21 15:36:23 +03:00 |
IInterpreter.h
|
More interesting settings for Stress Tests (#41534)
|
2023-02-21 15:36:23 +03:00 |
IInterpreterUnionOrSelectQuery.cpp
|
|
|
IInterpreterUnionOrSelectQuery.h
|
|
|
IJoin.h
|
|
|
IKeyValueEntity.h
|
|
|
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
Fix block structure mismatch for nullable LowCardinality column with default expression.
|
2023-03-13 17:57:07 +00:00 |
inplaceBlockConversions.h
|
|
|
InternalTextLogsQueue.cpp
|
|
|
InternalTextLogsQueue.h
|
|
|
InterpreterAlterNamedCollectionQuery.cpp
|
|
|
InterpreterAlterNamedCollectionQuery.h
|
|
|
InterpreterAlterQuery.cpp
|
|
|
InterpreterAlterQuery.h
|
|
|
InterpreterBackupQuery.cpp
|
|
|
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
|
|
InterpreterCheckQuery.h
|
|
|
InterpreterCreateFunctionQuery.cpp
|
|
|
InterpreterCreateFunctionQuery.h
|
|
|
InterpreterCreateIndexQuery.cpp
|
|
|
InterpreterCreateIndexQuery.h
|
|
|
InterpreterCreateNamedCollectionQuery.cpp
|
|
|
InterpreterCreateNamedCollectionQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
Fix grants hierarchy for temporary tables and comment about default engine
|
2023-03-13 16:39:15 +00:00 |
InterpreterCreateQuery.h
|
|
|
InterpreterDeleteQuery.cpp
|
Enable lightweight delete support by default
|
2023-03-01 19:35:55 +01:00 |
InterpreterDeleteQuery.h
|
|
|
InterpreterDescribeCacheQuery.cpp
|
|
|
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
|
|
InterpreterDescribeQuery.h
|
|
|
InterpreterDropFunctionQuery.cpp
|
|
|
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
|
|
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
|
|
InterpreterDropNamedCollectionQuery.h
|
|
|
InterpreterDropQuery.cpp
|
Merge branch 'master' into ADQM-639
|
2023-02-22 09:25:17 +03:00 |
InterpreterDropQuery.h
|
|
|
InterpreterExistsQuery.cpp
|
|
|
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
revert
|
2023-03-11 15:43:19 +00:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
|
|
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
|
|
InterpreterFactory.h
|
|
|
InterpreterInsertQuery.cpp
|
allow to fallback from async insert in case of large amount of data
|
2023-02-22 21:59:24 +00:00 |
InterpreterInsertQuery.h
|
allow to fallback from async insert in case of large amount of data
|
2023-02-22 21:59:24 +00:00 |
InterpreterKillQueryQuery.cpp
|
fix tests
|
2023-03-07 14:25:28 +01:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
[RFC] Replacing merge tree new engine (#41005)
|
2023-02-16 16:03:16 +03:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
Add parameterized RENAME queries
|
2023-02-14 13:01:06 +00:00 |
InterpreterRenameQuery.h
|
Add parameterized RENAME queries
|
2023-02-14 13:01:06 +00:00 |
InterpreterSelectIntersectExceptQuery.cpp
|
|
|
InterpreterSelectIntersectExceptQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
Analyzer added PREWHERE support
|
2023-03-15 15:21:49 +01:00 |
InterpreterSelectQuery.h
|
Merge branch 'master' into custom-key-parallel-replicas
|
2023-03-02 14:28:42 +00:00 |
InterpreterSelectQueryAnalyzer.cpp
|
Fixed tests
|
2023-03-11 11:51:54 +01:00 |
InterpreterSelectQueryAnalyzer.h
|
Fixed tests
|
2023-03-11 11:51:54 +01:00 |
InterpreterSelectWithUnionQuery.cpp
|
|
|
InterpreterSelectWithUnionQuery.h
|
|
|
InterpreterSetQuery.cpp
|
Fix test.
|
2023-03-12 11:13:44 +00:00 |
InterpreterSetQuery.h
|
Apply settings for EXPLAIN earlier (in the same way we do for SELECT).
|
2023-03-10 15:24:47 +00:00 |
InterpreterShowCreateQuery.cpp
|
|
|
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowEngineQuery.cpp
|
|
|
InterpreterShowEngineQuery.h
|
|
|
InterpreterShowProcesslistQuery.cpp
|
|
|
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowTablesQuery.cpp
|
|
|
InterpreterShowTablesQuery.h
|
|
|
InterpreterSystemQuery.cpp
|
add 'strict' mode for sync replica, fix 00993
|
2023-03-16 16:04:42 +01:00 |
InterpreterSystemQuery.h
|
add 'strict' mode for sync replica, fix 00993
|
2023-03-16 16:04:42 +01:00 |
InterpreterTransactionControlQuery.cpp
|
|
|
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUseQuery.cpp
|
|
|
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
InterpreterWatchQuery.h
|
|
|
interpretSubquery.cpp
|
|
|
interpretSubquery.h
|
|
|
InterserverCredentials.cpp
|
|
|
InterserverCredentials.h
|
|
|
InterserverIOHandler.h
|
|
|
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
joinDispatch.h
|
|
|
JoinedTables.cpp
|
|
|
JoinedTables.h
|
|
|
JoinSwitcher.cpp
|
|
|
JoinSwitcher.h
|
|
|
JoinToSubqueryTransformVisitor.cpp
|
|
|
JoinToSubqueryTransformVisitor.h
|
|
|
JoinUtils.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
JoinUtils.h
|
|
|
Lemmatizers.cpp
|
|
|
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
Better error after failed Ordinary-to-Atomic conversion (#47487)
|
2023-03-13 19:13:49 +03:00 |
loadMetadata.h
|
|
|
LogicalExpressionsOptimizer.cpp
|
Add a comment.
|
2023-03-12 11:06:29 +00:00 |
LogicalExpressionsOptimizer.h
|
|
|
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
|
|
MergeJoin.cpp
|
|
|
MergeJoin.h
|
|
|
MergeTreeTransaction.cpp
|
Fix MergeTreeTransaction::isReadOnly
|
2023-03-07 16:16:51 +00:00 |
MergeTreeTransaction.h
|
Fix MergeTreeTransaction::isReadOnly
|
2023-03-07 16:16:51 +00:00 |
MergeTreeTransactionHolder.cpp
|
|
|
MergeTreeTransactionHolder.h
|
|
|
MetricLog.cpp
|
|
|
MetricLog.h
|
|
|
misc.h
|
|
|
MonotonicityCheckVisitor.h
|
|
|
MutationsInterpreter.cpp
|
Analyzer MutationsInterpreter fix
|
2023-03-01 18:03:41 +01:00 |
MutationsInterpreter.h
|
|
|
NormalizeSelectWithUnionQueryVisitor.cpp
|
|
|
NormalizeSelectWithUnionQueryVisitor.h
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Merge pull request #47499 from FrankChen021/span_kind
|
2023-03-13 11:35:03 +01:00 |
OpenTelemetrySpanLog.h
|
|
|
OptimizeIfChains.cpp
|
add checks
|
2023-03-09 12:37:57 +01:00 |
OptimizeIfChains.h
|
|
|
OptimizeIfWithConstantConditionVisitor.cpp
|
|
|
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
|
|
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
parseColumnsListForTableFunction.cpp
|
Better exception messages when schema_inference_hints is ill-formatted
|
2023-02-27 15:20:56 +00:00 |
parseColumnsListForTableFunction.h
|
Better exception messages when schema_inference_hints is ill-formatted
|
2023-02-27 15:20:56 +00:00 |
PartLog.cpp
|
Merge pull request #38614 from bharatnc/ncb/profile-events-partlog
|
2023-02-21 11:06:44 +01:00 |
PartLog.h
|
Use overload of PartLog::addNewPart with profile_events
|
2023-02-14 14:11:12 +00:00 |
PredicateExpressionsOptimizer.cpp
|
Fix incorrect predicate push down with grouping sets (#46151)
|
2023-02-22 11:54:19 +01:00 |
PredicateExpressionsOptimizer.h
|
|
|
PredicateRewriteVisitor.cpp
|
|
|
PredicateRewriteVisitor.h
|
|
|
PreparedSets.cpp
|
|
|
PreparedSets.h
|
|
|
processColumnTransformers.cpp
|
|
|
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
work with comments on PR
|
2023-03-16 19:55:58 +01:00 |
ProcessList.h
|
Fix possible deadlock in QueryStatus
|
2023-03-02 17:20:29 +00:00 |
ProcessorsProfileLog.cpp
|
|
|
ProcessorsProfileLog.h
|
|
|
ProfileEventsExt.cpp
|
remove counters for threads, fix negative counters
|
2023-03-15 22:22:22 +01:00 |
ProfileEventsExt.h
|
Remove unused ProfileEventsExt::dumpToString
|
2023-02-14 14:11:11 +00:00 |
QueryAliasesVisitor.cpp
|
|
|
QueryAliasesVisitor.h
|
|
|
QueryLog.cpp
|
|
|
QueryLog.h
|
|
|
QueryNormalizer.cpp
|
Update aliases when clone happens
|
2023-02-20 19:08:54 +01:00 |
QueryNormalizer.h
|
|
|
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
|
|
QueryThreadLog.h
|
|
|
QueryViewsLog.cpp
|
|
|
QueryViewsLog.h
|
|
|
RedundantFunctionsInOrderByVisitor.h
|
|
|
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
|
|
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
replaceForPositionalArguments.cpp
|
|
|
replaceForPositionalArguments.h
|
|
|
ReplaceQueryParameterVisitor.cpp
|
Merge pull request #47086 from pkit/pkit/insert_http_body
|
2023-03-15 17:41:05 -04:00 |
ReplaceQueryParameterVisitor.h
|
|
|
RequiredSourceColumnsData.cpp
|
|
|
RequiredSourceColumnsData.h
|
|
|
RequiredSourceColumnsVisitor.cpp
|
|
|
RequiredSourceColumnsVisitor.h
|
|
|
RewriteAnyFunctionVisitor.cpp
|
|
|
RewriteAnyFunctionVisitor.h
|
|
|
RewriteArrayExistsFunctionVisitor.cpp
|
|
|
RewriteArrayExistsFunctionVisitor.h
|
|
|
RewriteCountDistinctVisitor.cpp
|
|
|
RewriteCountDistinctVisitor.h
|
|
|
RewriteCountVariantsVisitor.cpp
|
|
|
RewriteCountVariantsVisitor.h
|
|
|
RewriteFunctionToSubcolumnVisitor.cpp
|
|
|
RewriteFunctionToSubcolumnVisitor.h
|
|
|
RewriteOrderByVisitor.cpp
|
|
|
RewriteOrderByVisitor.hpp
|
|
|
RewriteSumIfFunctionVisitor.cpp
|
|
|
RewriteSumIfFunctionVisitor.h
|
|
|
RowRefs.cpp
|
Fix ASOF LEFT JOIN performance degradation (#47544)
|
2023-03-18 23:53:00 +01:00 |
RowRefs.h
|
|
|
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
|
|
ServerAsynchronousMetrics.cpp
|
Add new metrics to system.asynchronous_metrics
|
2023-02-25 21:13:15 +01:00 |
ServerAsynchronousMetrics.h
|
Add new metrics to system.asynchronous_metrics
|
2023-02-25 21:13:15 +01:00 |
Session.cpp
|
fix
|
2023-03-02 02:59:27 +01:00 |
Session.h
|
fix
|
2023-03-02 02:59:27 +01:00 |
SessionLog.cpp
|
|
|
SessionLog.h
|
|
|
Set.cpp
|
|
|
Set.h
|
|
|
SetVariants.cpp
|
|
|
SetVariants.h
|
|
|
sortBlock.cpp
|
|
|
sortBlock.h
|
|
|
SortedBlocksWriter.cpp
|
|
|
SortedBlocksWriter.h
|
|
|
SquashingTransform.cpp
|
|
|
SquashingTransform.h
|
|
|
StorageID.cpp
|
|
|
StorageID.h
|
|
|
SubstituteColumnOptimizer.cpp
|
|
|
SubstituteColumnOptimizer.h
|
|
|
SynonymsExtensions.cpp
|
|
|
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
Set materialized_views_ignore_errors unconditionally for system.*_log tables
|
2023-02-21 16:33:15 +01:00 |
SystemLog.h
|
|
|
TableJoin.cpp
|
|
|
TableJoin.h
|
|
|
TableOverrideUtils.cpp
|
|
|
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
|
|
TablesStatus.h
|
|
|
TemporaryDataOnDisk.cpp
|
hide too noisy log messages, fix some tests
|
2023-03-14 00:23:36 +01:00 |
TemporaryDataOnDisk.h
|
|
|
TextLog.cpp
|
|
|
TextLog.h
|
|
|
threadPoolCallbackRunner.h
|
work with comments on PR
|
2023-03-16 19:55:58 +01:00 |
ThreadStatusExt.cpp
|
if no group then do attachInternalTextLogsQueue to the thread only
|
2023-03-17 15:56:30 +01:00 |
TraceCollector.cpp
|
|
|
TraceCollector.h
|
|
|
TraceLog.cpp
|
|
|
TraceLog.h
|
|
|
TransactionLog.cpp
|
release shared ptrs after finishing a transaction
|
2023-03-04 22:07:59 +01:00 |
TransactionLog.h
|
release shared ptrs after finishing a transaction
|
2023-03-04 22:07:59 +01:00 |
TransactionsInfoLog.cpp
|
|
|
TransactionsInfoLog.h
|
|
|
TransactionVersionMetadata.cpp
|
resolve race in getCSNAndAssert
|
2023-02-15 18:16:39 +01:00 |
TransactionVersionMetadata.h
|
|
|
TranslateQualifiedNamesVisitor.cpp
|
|
|
TranslateQualifiedNamesVisitor.h
|
|
|
TreeCNFConverter.cpp
|
|
|
TreeCNFConverter.h
|
|
|
TreeOptimizer.cpp
|
|
|
TreeOptimizer.h
|
|
|
TreeRewriter.cpp
|
Merge pull request #46487 from ClickHouse/45185_Inner_join_with_where
|
2023-02-20 11:38:31 +01:00 |
TreeRewriter.h
|
|
|
WhereConstraintsOptimizer.cpp
|
|
|
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
|
|
WindowDescription.h
|
|
|
ZooKeeperLog.cpp
|
|
|
ZooKeeperLog.h
|
|
|