.. |
Access
|
Review fixes
|
2023-02-24 14:44:47 +01:00 |
Cache
|
Fix squashing in query cache
|
2023-04-13 20:09:29 +00:00 |
ClusterProxy
|
Always communicate with local replica through loopback interface for parallel replicas (#48246)
|
2023-04-05 13:32:46 +02:00 |
examples
|
Fix -Wshorten-64-to-32 in examples
|
2022-10-21 13:25:43 +02:00 |
fuzzers
|
Add fuzzer for data formats
|
2023-03-13 04:51:50 +01:00 |
JIT
|
Optimize one nullable key aggregate performance (#45772)
|
2023-03-02 21:01:52 +01:00 |
MySQL
|
Improve file includes
|
2023-03-24 03:44:52 +01:00 |
tests
|
Test WriteBufferToFileSegment with several threads
|
2023-04-04 18:15:27 +00:00 |
ActionLocksManager.cpp
|
|
|
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Merge pull request #48427 from ClickHouse/update_sort_desc_follow_up
|
2023-04-12 13:59:37 +02:00 |
ActionsDAG.h
|
Merge pull request #48427 from ClickHouse/update_sort_desc_follow_up
|
2023-04-12 13:59:37 +02:00 |
ActionsVisitor.cpp
|
Use different types for referencing local set and set that is stored in cache shared between tasks
|
2023-04-14 16:12:18 +02:00 |
ActionsVisitor.h
|
Reworked, testing
|
2023-04-14 16:12:18 +02:00 |
AddDefaultDatabaseVisitor.h
|
Add parameterized RENAME queries
|
2023-02-14 13:01:06 +00:00 |
AddIndexConstraintsOptimizer.cpp
|
Add support for substitute column
|
2023-03-17 13:38:01 +00:00 |
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
|
|
addMissingDefaults.h
|
|
|
addTypeConversionToAST.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
addTypeConversionToAST.h
|
|
|
AggregateDescription.cpp
|
Refactor FunctionNode
|
2022-12-02 19:15:26 +00:00 |
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
AggregationCommon.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
AggregationUtils.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
AggregationUtils.h
|
|
|
Aggregator.cpp
|
Merge pull request #48543 from azat/mv-uniq-thread-group
|
2023-04-11 11:47:46 +02:00 |
Aggregator.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ApplyWithAliasVisitor.h
|
Global WITH and WITH propagation.
|
2020-10-08 15:03:34 +08:00 |
ApplyWithGlobalVisitor.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
fix logic + better test
|
2023-02-22 13:30:57 +08:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ArrayJoinAction.cpp
|
SIZES_OF_ARRAYS_DOESN_MATCH --> SIZES_OF_ARRAYS_DONT_MATCH
|
2023-02-27 08:31:40 +00:00 |
ArrayJoinAction.h
|
update getArrayJoinDataType/getArrayJoinColumn
|
2022-12-14 13:02:03 +00:00 |
ArrayJoinedColumnsVisitor.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
AsynchronousInsertLog.cpp
|
|
|
AsynchronousInsertLog.h
|
|
|
AsynchronousInsertQueue.cpp
|
add flush id and time for async insert with empty data
|
2023-04-12 20:57:55 +00:00 |
AsynchronousInsertQueue.h
|
Revert "Merge pull request #46622 from ClickHouse/async-insert-memory-fix"
|
2023-03-11 17:01:10 +01:00 |
AsynchronousMetricLog.cpp
|
Merge branch 'master' into keeper-prometheus
|
2022-11-15 12:00:02 +00:00 |
AsynchronousMetricLog.h
|
Merge branch 'master' into keeper-prometheus
|
2022-11-15 12:00:02 +00:00 |
BloomFilter.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
BloomFilter.h
|
|
|
BloomFilterHash.h
|
allow bloom filter for IPv4 and IPv6
|
2023-02-06 16:30:18 +00:00 |
CancellationCode.h
|
|
|
castColumn.cpp
|
Merge branch 'master' into cast_to_value_or_default
|
2021-09-28 14:04:10 +03:00 |
castColumn.h
|
Only fix LowCardinality for now
|
2022-10-22 15:47:13 +08:00 |
ClientInfo.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
ClientInfo.h
|
add member function getLastForwardedFor to ClientInfo
|
2022-12-23 18:32:29 +00:00 |
Cluster.cpp
|
Add allow_distributed_ddl_queries option to the cluster config
|
2023-03-29 18:15:46 +03:00 |
Cluster.h
|
Add allow_distributed_ddl_queries option to the cluster config
|
2023-03-29 18:15:46 +03:00 |
ClusterDiscovery.cpp
|
Do not set treat_local_port_as_remote in ClusterDiscovery
|
2022-11-02 15:34:06 +00:00 |
ClusterDiscovery.h
|
|
|
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
CollectJoinOnKeysVisitor.h
|
JoinIdentifierPos::Constant -> NotColumn
|
2022-12-15 15:14:03 +00:00 |
ColumnAliasesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ColumnAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ComparisonGraph.cpp
|
Some fixes with tests
|
2023-03-16 15:59:48 +00:00 |
ComparisonGraph.h
|
address PR review
|
2023-03-27 10:03:40 +00:00 |
ComparisonTupleEliminationVisitor.cpp
|
Better ComparisonTupleEliminationVisitor
|
2023-03-21 16:23:09 +00:00 |
ComparisonTupleEliminationVisitor.h
|
Add ComparisonTupleEliminationVisitor
|
2023-03-21 16:11:06 +00:00 |
ConcurrentHashJoin.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
ConcurrentHashJoin.h
|
BackgroundSchedulePool should not have any query context
|
2023-02-22 10:50:51 +01:00 |
Context_fwd.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
Context.cpp
|
Share PreparedSet-s between task of the same mutation to reduce mem usage
|
2023-04-14 16:12:18 +02:00 |
Context.h
|
Share PreparedSet-s between task of the same mutation to reduce mem usage
|
2023-04-14 16:12:18 +02:00 |
convertFieldToType.cpp
|
Add Decimal256 to a lot of places
|
2023-03-14 22:10:52 +01:00 |
convertFieldToType.h
|
|
|
ConvertFunctionOrLikeVisitor.cpp
|
Move likePatternToRegexp from Functions/ to Common/
|
2023-02-27 16:41:15 +00:00 |
ConvertFunctionOrLikeVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ConvertStringsToEnumVisitor.cpp
|
Add classes for new pass
|
2022-12-07 11:44:46 +00:00 |
ConvertStringsToEnumVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
CrashLog.cpp
|
initial solution
|
2023-03-06 19:35:00 +03:00 |
CrashLog.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
createBlockSelector.cpp
|
Update libdivide
|
2022-12-13 10:45:01 +01:00 |
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Fix typo
|
2023-03-14 12:48:00 +01:00 |
CrossToInnerJoinVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
DatabaseAndTableWithAlias.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
DatabaseAndTableWithAlias.h
|
Improve Asterisk and ColumnMatcher parser
|
2022-11-02 06:21:02 +00:00 |
DatabaseCatalog.cpp
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
DatabaseCatalog.h
|
better
|
2023-03-27 23:51:35 +08:00 |
DDLTask.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
DDLTask.h
|
Addition to prev change
|
2023-01-01 21:46:30 +01:00 |
DDLWorker.cpp
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
DDLWorker.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
DirectJoin.cpp
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
DirectJoin.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
DNSCacheUpdater.cpp
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
DNSCacheUpdater.h
|
|
|
DuplicateOrderByVisitor.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
DuplicateOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
EmbeddedDictionaries.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
EmbeddedDictionaries.h
|
|
|
evaluateConstantExpression.cpp
|
Simple fix logical error in evaluate constant expression
|
2023-03-20 15:10:50 +00:00 |
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
Merge remote-tracking branch 'blessed/master' into zk_retry_timeout
|
2023-04-03 10:26:18 +02:00 |
executeDDLQueryOnCluster.h
|
fix
|
2023-03-31 12:58:11 +02:00 |
executeQuery.cpp
|
Merge branch 'master' into qc-compression
|
2023-03-30 10:55:42 +02:00 |
executeQuery.h
|
add query_id header in all queries
|
2023-02-13 16:44:54 +00:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
Support for cte in parameterized views
Implementation:
|
2023-03-27 16:30:53 +02:00 |
ExecuteScalarSubqueriesVisitor.h
|
Support for cte in parameterized views
Implementation:
|
2023-03-27 16:30:53 +02:00 |
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
|
Use different types for referencing local set and set that is stored in cache shared between tasks
|
2023-04-14 16:12:18 +02:00 |
ExpressionAnalyzer.h
|
Remove unnecessary execute() while evaluating a constant expression.
|
2023-02-05 20:26:34 +01:00 |
ExpressionJIT.cpp
|
Fix ClangTidy build
|
2022-12-21 00:22:46 +00:00 |
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
|
Merge pull request #48543 from azat/mv-uniq-thread-group
|
2023-04-11 11:47:46 +02:00 |
ExternalLoader.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
ExternalLoaderDatabaseConfigRepository.h
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
Apply some CTAD
|
2023-03-02 13:36:47 +00:00 |
ExternalLoaderXMLConfigRepository.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
FilesystemCacheLog.cpp
|
|
|
FilesystemCacheLog.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
FilesystemReadPrefetchesLog.cpp
|
Resubmit prefetches
|
2023-02-08 21:26:24 +01:00 |
FilesystemReadPrefetchesLog.h
|
Resubmit prefetches
|
2023-02-08 21:26:24 +01:00 |
FillingRow.cpp
|
Move suffix generation code into one function
|
2023-04-05 10:12:42 +00:00 |
FillingRow.h
|
Move suffix generation code into one function
|
2023-04-05 10:12:42 +00:00 |
FullSortingMergeJoin.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
FunctionMaskingArgumentCheckVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
Merge remote-tracking branch 'upstream/master' into ncb/weighted-quantile-approx
|
2022-12-13 09:34:26 -08:00 |
GatherFunctionQuantileVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
GetAggregatesVisitor.cpp
|
|
|
GetAggregatesVisitor.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
getClusterName.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
getClusterName.h
|
Implement referential dependencies for table engine "Distributed"
|
2022-12-13 11:09:42 +01:00 |
getColumnFromBlock.cpp
|
fix getting subcolumn from in-memory data
|
2023-04-11 14:26:31 +00:00 |
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
|
Addressed review comments
|
2023-03-21 18:29:26 +01:00 |
getTableExpressions.h
|
Addressed review comments
|
2023-03-21 18:29:26 +01:00 |
getTableOverride.cpp
|
|
|
getTableOverride.h
|
|
|
GinFilter.cpp
|
Merge remote-tracking branch 'origin/master' into inv-index-cleanup
|
2023-01-24 10:09:42 +00:00 |
GinFilter.h
|
Update src/Interpreters/GinFilter.h
|
2023-01-23 20:49:25 +01:00 |
GlobalSubqueriesVisitor.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
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
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
HashJoin.cpp
|
Make the code in Join less disgusting
|
2023-03-19 07:32:29 +01:00 |
HashJoin.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
IdentifierSemantic.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
IdentifierSemantic.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
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
|
Fix crash in EXPLAIN PIPELINE for Merge over Distributed
|
2023-04-02 10:48:23 +02:00 |
IInterpreterUnionOrSelectQuery.h
|
Fix crash in EXPLAIN PIPELINE for Merge over Distributed
|
2023-04-02 10:48:23 +02:00 |
IJoin.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
IKeyValueEntity.h
|
|
|
InDepthNodeVisitor.h
|
Modifiy visitor
|
2022-11-23 13:32:36 +00:00 |
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
|
Modernize InternalTextLogsQueue::getPriorityName()
|
2023-01-20 11:09:35 +01:00 |
InternalTextLogsQueue.h
|
Modernize InternalTextLogsQueue::getPriorityName()
|
2023-01-20 11:09:35 +01:00 |
InterpreterAlterNamedCollectionQuery.cpp
|
Fix
|
2023-02-11 19:57:41 +01:00 |
InterpreterAlterNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterAlterQuery.cpp
|
Add error code
|
2023-04-03 15:17:06 +00:00 |
InterpreterAlterQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterBackupQuery.cpp
|
|
|
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
|
|
InterpreterCheckQuery.h
|
|
|
InterpreterCreateFunctionQuery.cpp
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterCreateFunctionQuery.h
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterCreateIndexQuery.cpp
|
|
|
InterpreterCreateIndexQuery.h
|
Support sql standard drop index in seprate parser files
|
2022-06-29 11:08:05 +08:00 |
InterpreterCreateNamedCollectionQuery.cpp
|
Fix
|
2023-02-11 19:57:41 +01:00 |
InterpreterCreateNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterCreateQuery.cpp
|
Revert "Make Schema inference works for CREATE AS SELECT"
|
2023-04-13 13:35:32 -04:00 |
InterpreterCreateQuery.h
|
monor improvements
|
2023-03-28 23:47:45 +02:00 |
InterpreterDeleteQuery.cpp
|
Enable lightweight delete support by default
|
2023-03-01 19:35:55 +01:00 |
InterpreterDeleteQuery.h
|
|
|
InterpreterDescribeCacheQuery.cpp
|
Rename
|
2022-09-19 14:02:51 +02:00 |
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
Analyzer support distributed queries processing
|
2023-01-12 12:07:58 +01:00 |
InterpreterDescribeQuery.h
|
|
|
InterpreterDropFunctionQuery.cpp
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
|
|
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
Fix
|
2023-02-11 19:57:41 +01:00 |
InterpreterDropNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterDropQuery.cpp
|
Fix race between DROP MatView and RESTART REPLICAS (#47863)
|
2023-04-01 15:26:00 +03:00 |
InterpreterDropQuery.h
|
Fix race between DROP MatView and RESTART REPLICAS (#47863)
|
2023-04-01 15:26:00 +03:00 |
InterpreterExistsQuery.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
Deprecate EXPLAIN QUERY TREE with disabled analyzer.
|
2023-03-29 14:59:01 +00:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
Merge pull request #48017 from ClickHouse/rs/show_columns
|
2023-03-31 15:50:23 +02:00 |
InterpreterFactory.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterInsertQuery.cpp
|
Revert "Make Schema inference works for CREATE AS SELECT"
|
2023-04-13 13:35:32 -04:00 |
InterpreterInsertQuery.h
|
Fix build src/Interpreters/InterpreterInsertQuery.h
|
2023-04-11 11:17:02 +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
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
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
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSelectIntersectExceptQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSelectQuery.cpp
|
Better
|
2023-04-05 15:19:45 +00: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
|
Merge remote-tracking branch 'origin/master' into optimize-compilation
|
2023-04-13 16:04:09 +02:00 |
InterpreterSelectWithUnionQuery.cpp
|
Merge pull request #47725 from ClickHouse/46741_Parameterized_view_support_subquery
|
2023-03-22 09:05:26 +01:00 |
InterpreterSelectWithUnionQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSetQuery.cpp
|
Improve file includes
|
2023-03-24 03:44:52 +01:00 |
InterpreterSetQuery.h
|
Apply settings for EXPLAIN earlier (in the same way we do for SELECT).
|
2023-03-10 15:24:47 +00:00 |
InterpreterShowColumnsQuery.cpp
|
Fix stylecheck
|
2023-03-28 20:07:26 +00:00 |
InterpreterShowColumnsQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterShowCreateQuery.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowEngineQuery.cpp
|
Sort output of SHOW <INFO> statements
|
2023-03-28 20:55:59 +00:00 |
InterpreterShowEngineQuery.h
|
Update InterpreterShowEngineQuery.h
|
2023-02-01 04:57:58 +03:00 |
InterpreterShowProcesslistQuery.cpp
|
Sort descendingly by elapsed time
|
2023-03-31 09:36:03 +00:00 |
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowTablesQuery.cpp
|
Merge pull request #48017 from ClickHouse/rs/show_columns
|
2023-03-31 15:50:23 +02:00 |
InterpreterShowTablesQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterSystemQuery.cpp
|
Remove -Wshadow suppression which leaked into global namespace
|
2023-04-13 08:46:40 +00:00 |
InterpreterSystemQuery.h
|
add 'strict' mode for sync replica, fix 00993
|
2023-03-16 16:04:42 +01:00 |
InterpreterTransactionControlQuery.cpp
|
|
|
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUndropQuery.cpp
|
monor improvements
|
2023-03-28 23:47:45 +02:00 |
InterpreterUndropQuery.h
|
support undrop table
|
2023-03-27 22:16:36 +08:00 |
InterpreterUseQuery.cpp
|
|
|
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
InterpreterWatchQuery.h
|
|
|
interpretSubquery.cpp
|
Parallel replicas. Part [2] (#43772)
|
2023-02-03 14:34:18 +01:00 |
interpretSubquery.h
|
|
|
InterserverCredentials.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
InterserverCredentials.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
InterserverIOHandler.h
|
Merge pull request #45007 from ClickHouse/cancellable-mutex-integration
|
2023-01-25 11:15:46 +01:00 |
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
Various cosmetic cleanups
|
2023-01-20 10:45:35 +00:00 |
joinDispatch.h
|
|
|
JoinedTables.cpp
|
Remove -Wshadow suppression which leaked into global namespace
|
2023-04-13 08:46:40 +00:00 |
JoinedTables.h
|
Addressed review comments
|
2023-03-21 18:29:26 +01:00 |
JoinSwitcher.cpp
|
Update JoinSwitcher::switchJoin
|
2023-01-17 12:21:55 +00:00 |
JoinSwitcher.h
|
JoinSwitcher don't use grace hash join
|
2022-10-26 16:09:11 +00:00 |
JoinToSubqueryTransformVisitor.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
JoinToSubqueryTransformVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
JoinUtils.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
JoinUtils.h
|
Review fixes
|
2023-01-20 16:30:34 +00:00 |
Lemmatizers.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
ThreadPool metrics introspection
|
2023-03-29 10:46:59 +02:00 |
loadMetadata.h
|
Referential dependencies for RESTORE (#43834)
|
2022-12-02 15:05:46 +01:00 |
LogicalExpressionsOptimizer.cpp
|
Add a comment.
|
2023-03-12 11:06:29 +00:00 |
LogicalExpressionsOptimizer.h
|
LogicalExpressionsOptimizer: optimze for LowCardinality
|
2022-11-02 16:56:58 +08:00 |
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
Fix crash on call dictGet() with bad arguments.
|
2021-07-02 14:46:12 +03:00 |
MergeJoin.cpp
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
MergeJoin.h
|
review fixes
|
2023-01-12 15:51:04 +00:00 |
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
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
MetricLog.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
misc.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
MonotonicityCheckVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
MutationsInterpreter.cpp
|
Merge pull request #48522 from ClickHouse/many-mutations-memory-limit
|
2023-04-10 12:50:42 +02:00 |
MutationsInterpreter.h
|
Update only affected rows in KV storage
|
2023-04-05 16:12:14 +00:00 |
NormalizeSelectWithUnionQueryVisitor.cpp
|
forbid old ctor of Exception
|
2023-01-23 22:18:05 +01:00 |
NormalizeSelectWithUnionQueryVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
NullableUtils.cpp
|
fix transform_null_in with sets of tuples
|
2020-11-05 21:07:44 +03:00 |
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Merge pull request #47499 from FrankChen021/span_kind
|
2023-03-13 11:35:03 +01:00 |
OpenTelemetrySpanLog.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
OptimizeIfChains.cpp
|
add checks
|
2023-03-09 12:37:57 +01:00 |
OptimizeIfChains.h
|
replace multiIf to if in case of one condition
|
2022-05-31 14:45:12 +00:00 |
OptimizeIfWithConstantConditionVisitor.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
|
|
OptimizeShardingKeyRewriteInVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
parseColumnsListForTableFunction.cpp
|
Better exception messages when schema_inference_hints is ill-formatted
|
2023-02-27 15:20:56 +00:00 |
parseColumnsListForTableFunction.h
|
Update the fuzzer
|
2023-03-13 05:21:48 +01: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
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
PreparedSets.cpp
|
Use different types for referencing local set and set that is stored in cache shared between tasks
|
2023-04-14 16:12:18 +02:00 |
PreparedSets.h
|
Use different types for referencing local set and set that is stored in cache shared between tasks
|
2023-04-14 16:12:18 +02:00 |
processColumnTransformers.cpp
|
|
|
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Rename ThreadGroupStatus to ThreadGroup
|
2023-04-07 15:31:48 +02:00 |
ProcessList.h
|
Rename ThreadGroupStatus to ThreadGroup
|
2023-04-07 15:31:48 +02:00 |
ProcessorsProfileLog.cpp
|
|
|
ProcessorsProfileLog.h
|
|
|
ProfileEventsExt.cpp
|
Merge remote-tracking branch 'origin/master' into optimize-compilation
|
2023-04-13 16:04:09 +02:00 |
ProfileEventsExt.h
|
Remove unused ProfileEventsExt::dumpToString
|
2023-02-14 14:11:11 +00:00 |
QueryAliasesVisitor.cpp
|
forbid old ctor of Exception
|
2023-01-23 22:18:05 +01:00 |
QueryAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
QueryLog.cpp
|
Resubmit prefetches
|
2023-02-08 21:26:24 +01:00 |
QueryLog.h
|
Resubmit prefetches
|
2023-02-08 21:26:24 +01:00 |
QueryNormalizer.cpp
|
Update aliases when clone happens
|
2023-02-20 19:08:54 +01:00 |
QueryNormalizer.h
|
Updated to support query parameters in different parts of query (SELECT, ORDERBY, GROUP BY), updated the approach in WHERE & HAVING, added tests for the same - 40907 Parameterized views as table functions
|
2022-11-28 19:05:01 +01:00 |
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
|
|
QueryThreadLog.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
QueryViewsLog.cpp
|
|
|
QueryViewsLog.h
|
|
|
RedundantFunctionsInOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
replaceForPositionalArguments.cpp
|
typo
|
2023-01-04 12:45:39 +01:00 |
replaceForPositionalArguments.h
|
|
|
ReplaceQueryParameterVisitor.cpp
|
Update src/Interpreters/ReplaceQueryParameterVisitor.cpp
|
2023-04-10 09:09:57 +02:00 |
ReplaceQueryParameterVisitor.h
|
|
|
RequiredSourceColumnsData.cpp
|
|
|
RequiredSourceColumnsData.h
|
|
|
RequiredSourceColumnsVisitor.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
RequiredSourceColumnsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteAnyFunctionVisitor.cpp
|
|
|
RewriteAnyFunctionVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteArrayExistsFunctionVisitor.cpp
|
fix build error
|
2023-02-10 11:27:10 +08:00 |
RewriteArrayExistsFunctionVisitor.h
|
add passes for rewriting arrayexists
|
2023-02-09 16:30:53 +08:00 |
RewriteCountDistinctVisitor.cpp
|
|
|
RewriteCountDistinctVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteCountVariantsVisitor.cpp
|
fix some bad logics in ast level optimization
|
2022-12-02 17:56:23 +08:00 |
RewriteCountVariantsVisitor.h
|
fix some bad logics in ast level optimization
|
2022-12-02 17:56:23 +08:00 |
RewriteFunctionToSubcolumnVisitor.cpp
|
|
|
RewriteFunctionToSubcolumnVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteOrderByVisitor.cpp
|
|
|
RewriteOrderByVisitor.hpp
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteSumIfFunctionVisitor.cpp
|
fix failed tests
|
2023-01-12 17:39:50 +08:00 |
RewriteSumIfFunctionVisitor.h
|
improve count if rewrite
|
2022-12-30 14:48:58 +08:00 |
RowRefs.cpp
|
Fix ASOF LEFT JOIN performance degradation (#47544)
|
2023-03-18 23:53:00 +01:00 |
RowRefs.h
|
Make the code in Join less disgusting
|
2023-03-19 07:35:56 +01:00 |
SelectIntersectExceptQueryVisitor.cpp
|
forbid old ctor of Exception
|
2023-01-23 22:18:05 +01:00 |
SelectIntersectExceptQueryVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
SelectQueryOptions.h
|
Moved is_create_parameterized_view out of Context , and added into ActionsMatcher::Data and SelectQueryInfo - 40907 Parameterized views as table functions
|
2022-10-21 14:45:28 +02:00 |
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 bad error messages
|
2023-04-04 20:21:22 +02:00 |
Session.h
|
fix
|
2023-03-02 02:59:27 +01:00 |
SessionLog.cpp
|
Add SSL_CERTIFICATE auth method to all places missing
|
2022-10-28 21:17:59 +02:00 |
SessionLog.h
|
|
|
Set.cpp
|
Unblock tests with ENGINE=Set
|
2023-04-14 16:12:18 +02:00 |
Set.h
|
Check that the set has been built before it is used
|
2023-04-14 16:12:18 +02:00 |
SetVariants.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
SetVariants.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
sortBlock.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
sortBlock.h
|
|
|
SortedBlocksWriter.cpp
|
Followup for TemporaryDataOnDisk
|
2022-10-12 15:25:23 +02:00 |
SortedBlocksWriter.h
|
|
|
SquashingTransform.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
SquashingTransform.h
|
|
|
StorageID.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
StorageID.h
|
Preparation for libcxx(abi), llvm, clang-tidy 16
|
2023-03-19 17:25:41 +00:00 |
SubstituteColumnOptimizer.cpp
|
Add support for substitute column
|
2023-03-17 13:38:01 +00:00 |
SubstituteColumnOptimizer.h
|
|
|
SynonymsExtensions.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
PR comments
|
2023-04-05 18:04:03 +02:00 |
SystemLog.h
|
Resubmit prefetches
|
2023-02-08 21:26:24 +01:00 |
TableJoin.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
TableJoin.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
TableOverrideUtils.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
TablesStatus.h
|
|
|
TemporaryDataOnDisk.cpp
|
Revert "Reset downloader for cache file segment in TemporaryFileStream"
|
2023-04-04 14:22:33 +00:00 |
TemporaryDataOnDisk.h
|
Use StrongTypedef for CurrentMetrics to avoid possible incorrect usage
|
2023-04-01 16:01:33 +02:00 |
TextLog.cpp
|
add a column with a message pattern to text_log
|
2022-12-23 15:06:30 +01:00 |
TextLog.h
|
add a column with a message pattern to text_log
|
2022-12-23 15:06:30 +01:00 |
threadPoolCallbackRunner.h
|
work with comments on PR
|
2023-03-16 19:55:58 +01:00 |
ThreadStatusExt.cpp
|
Revert "Add MemoryTracker for the background tasks"
|
2023-04-13 21:05:02 +03:00 |
TraceCollector.cpp
|
Fix exception fix in TraceCollector dtor
|
2023-01-05 18:27:07 +00:00 |
TraceCollector.h
|
allow to send profile events to trace_log
|
2022-11-24 20:12:16 +00:00 |
TraceLog.cpp
|
Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log"
|
2022-12-27 14:28:13 +01:00 |
TraceLog.h
|
Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log"
|
2022-12-27 14:28:13 +01:00 |
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
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
TranslateQualifiedNamesVisitor.h
|
Updated to get column data type based not function , not the query parameter type , added test for the same - 40907 Parameterized views as table functions
|
2022-12-19 15:05:38 +01:00 |
TreeCNFConverter.cpp
|
Start implementing constraint optimizer
|
2023-03-16 09:30:55 +00:00 |
TreeCNFConverter.h
|
Start implementing constraint optimizer
|
2023-03-16 09:30:55 +00:00 |
TreeOptimizer.cpp
|
remove useless code
|
2023-02-09 16:32:11 +08:00 |
TreeOptimizer.h
|
Merge branch 'master' into ch_canh_fix_normalize
|
2022-12-02 17:59:21 +08:00 |
TreeRewriter.cpp
|
Support for cte in parameterized views
Implementation:
|
2023-03-27 16:30:53 +02:00 |
TreeRewriter.h
|
Updated to get column data type based not function , not the query parameter type , added test for the same - 40907 Parameterized views as table functions
|
2022-12-19 15:05:38 +01:00 |
WhereConstraintsOptimizer.cpp
|
Add support for substitute column
|
2023-03-17 13:38:01 +00:00 |
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
Added WINDOW functions support
|
2022-10-24 10:22:20 +02:00 |
WindowDescription.h
|
Improve file includes
|
2023-03-24 03:44:52 +01:00 |
ZooKeeperLog.cpp
|
|
|
ZooKeeperLog.h
|
|
|