.. |
Access
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
Cache
|
Merge pull request #57615 from ClickHouse/filecache-small-optimization
|
2024-01-25 15:50:09 +01:00 |
ClusterProxy
|
UNEXPECTED_CLUSTER error for cluster with more than 1 shard
|
2024-02-05 15:10:51 +00:00 |
examples
|
Clang-tidy detected problems
|
2023-11-27 11:00:27 +01:00 |
fuzzers
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
JIT
|
Revert "Merging #53757"
|
2024-01-05 13:46:18 +01:00 |
MySQL
|
Miscellaneous
|
2024-02-19 03:19:21 +01:00 |
tests
|
Update unit tests
|
2024-01-17 14:52:24 +01:00 |
ActionLocksManager.cpp
|
Overhaul RefreshTask
|
2023-12-28 17:56:04 +00:00 |
ActionLocksManager.h
|
Remove specialization global lock/unlock from ActionLocksManager (#39215)
|
2022-07-21 01:29:35 +02:00 |
ActionsDAG.cpp
|
Follow up for #58554. Cleanup.
|
2024-02-12 13:37:25 +00:00 |
ActionsDAG.h
|
Merge pull request #58554 from ClickHouse/try-to-always-push-down-prewhere-from-query-plan
|
2024-02-12 12:52:39 +01:00 |
ActionsVisitor.cpp
|
Disable parallel replicas JOIN with CTE (not analyzer)
|
2024-01-26 14:36:38 +01:00 |
ActionsVisitor.h
|
Merge branch 'master' into refactor-subqueries-for-in
|
2023-05-05 20:39:09 +02:00 |
AddDefaultDatabaseVisitor.h
|
Things
|
2023-12-28 17:56:05 +00:00 |
AddIndexConstraintsOptimizer.cpp
|
Add support for substitute column
|
2023-03-17 13:38:01 +00:00 |
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
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
|
hashtable order fix for s390x
|
2023-09-07 07:37:43 -07:00 |
AggregationUtils.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
AggregationUtils.h
|
fix style
|
2022-08-16 18:56:22 +02:00 |
Aggregator.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
Aggregator.h
|
Updated implementation
|
2024-01-25 14:31:49 +03: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
|
|
|
ApplyWithGlobalVisitor.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ApplyWithSubqueryVisitor.h
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
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
|
fix failed ut
|
2023-11-27 10:48:01 +08:00 |
ArrayJoinAction.h
|
Respect max_block_size for array join to avoid possible OOM
|
2023-09-18 11:04:38 +08:00 |
ArrayJoinedColumnsVisitor.h
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
AsynchronousInsertLog.cpp
|
Log timeout for entries processed asynchronously
|
2024-02-01 22:45:09 +00:00 |
AsynchronousInsertLog.h
|
Log timeout for entries processed asynchronously
|
2024-02-01 22:45:09 +00:00 |
AsynchronousInsertQueue.cpp
|
Better logging for adaptive async timeouts
|
2024-02-08 21:42:44 +00:00 |
AsynchronousInsertQueue.h
|
Better logging for adaptive async timeouts
|
2024-02-08 21:42:44 +00:00 |
AsynchronousMetricLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
AsynchronousMetricLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
BackupLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
BackupLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
BlobStorageLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
BlobStorageLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
BloomFilter.cpp
|
Reuse granule during skip index reading
|
2023-10-18 14:40:34 +08:00 |
BloomFilter.h
|
Reuse granule during skip index reading
|
2023-10-18 14:40:34 +08:00 |
BloomFilterHash.h
|
Adding a unit test
|
2023-11-22 08:33:41 +01:00 |
CancellationCode.h
|
|
|
castColumn.cpp
|
Remove C++ templates
|
2023-11-10 05:25:02 +01:00 |
castColumn.h
|
Remove C++ templates
|
2023-11-10 05:25:02 +01:00 |
ClientInfo.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
ClientInfo.h
|
Revert "add function getClientHTTPHeader"
|
2023-12-05 13:34:34 +03:00 |
Cluster.cpp
|
Fix addShard()
|
2023-12-05 18:07:51 +00:00 |
Cluster.h
|
Fix addShard()
|
2023-12-05 18:07:51 +00:00 |
ClusterDiscovery.cpp
|
Cleanups
|
2024-02-14 00:21:13 +01:00 |
ClusterDiscovery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
Support 'is not distinct from' in join on section
|
2023-08-28 11:41:36 +00:00 |
CollectJoinOnKeysVisitor.h
|
Support 'is not distinct from' in join on section
|
2023-08-28 11:41:36 +00:00 |
ColumnAliasesVisitor.cpp
|
|
|
ColumnAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ComparisonGraph.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
ComparisonGraph.h
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +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
|
Disable max_joined_block_rows in ConcurrentHashJoin
|
2024-01-08 10:20:39 +00:00 |
ConcurrentHashJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
Context_fwd.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
Context.cpp
|
Merge pull request #60080 from kitaisreal/temporary-table-already-exists-exception-message-fix
|
2024-02-17 05:17:39 +01:00 |
Context.h
|
Style check for abbreviations
|
2024-02-17 02:14:15 +01:00 |
convertFieldToType.cpp
|
Try a different approach
|
2024-01-12 14:04:47 +00:00 |
convertFieldToType.h
|
style convertFieldToTypeStrict
|
2023-08-04 09:45:13 +00:00 |
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
|
Fix some typos
|
2023-10-15 15:43:02 +02:00 |
ConvertStringsToEnumVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
CrashLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
CrashLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
createBlockSelector.cpp
|
Convert assert to LOGICAL_ERROR in createBlockSelector() for zero weight
|
2023-06-28 19:06:31 +02:00 |
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
CrossToInnerJoinVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
DatabaseAndTableWithAlias.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
DatabaseAndTableWithAlias.h
|
Improve Asterisk and ColumnMatcher parser
|
2022-11-02 06:21:02 +00:00 |
DatabaseCatalog.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DatabaseCatalog.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DDLTask.cpp
|
Address comments
|
2024-02-16 19:30:16 +00:00 |
DDLTask.h
|
Address comments
|
2024-02-16 19:30:16 +00:00 |
DDLWorker.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DDLWorker.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DirectJoin.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DirectJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DNSCacheUpdater.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DNSCacheUpdater.h
|
|
|
DuplicateOrderByVisitor.cpp
|
Move handling of RESPECT NULLS outside of the parser
|
2023-11-27 11:00:27 +01:00 |
DuplicateOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
EmbeddedDictionaries.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
EmbeddedDictionaries.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
evaluateConstantExpression.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
evaluateConstantExpression.h
|
Merge branch 'master' into planner-prepare-filters-for-analysis-2
|
2023-09-11 16:14:03 +02:00 |
executeDDLQueryOnCluster.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
executeDDLQueryOnCluster.h
|
Move ZooKeeperRetries.h to Common
|
2024-01-30 19:02:17 +01:00 |
executeQuery.cpp
|
Remove extensively aggressive check
|
2024-02-20 06:52:07 +01:00 |
executeQuery.h
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
ExecuteScalarSubqueriesVisitor.h
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
ExpressionActions.cpp
|
Add sanity checks for function return types
|
2024-01-30 14:10:20 +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
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExpressionAnalyzer.h
|
Slightly more changes
|
2023-07-16 03:14:44 +02:00 |
ExpressionJIT.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExternalDictionariesLoader.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExternalDictionariesLoader.h
|
address comments
|
2023-05-10 17:42:08 +02:00 |
ExternalLoader.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExternalLoader.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
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
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
FilesystemCacheLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
FilesystemReadPrefetchesLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
FilesystemReadPrefetchesLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
FillingRow.cpp
|
Fix suffix generation (see added test in commit 3355894 )
|
2023-05-14 15:52:49 +00:00 |
FillingRow.h
|
Fix suffix generation (see added test in commit 3355894 )
|
2023-05-14 15:52:49 +00:00 |
formatWithPossiblyHidingSecrets.h
|
separate name for format setting
|
2023-04-28 13:39:38 +00:00 |
FullSortingMergeJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
FunctionMaskingArgumentCheckVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
FunctionNameNormalizer.cpp
|
Function name normalization fix functions header
|
2022-10-04 17:29:33 +02:00 |
FunctionNameNormalizer.h
|
Add comments to FunctionNameNormalizer.
|
2022-09-19 22:07:04 +08:00 |
GatherFunctionQuantileVisitor.cpp
|
fix bug of quantileGK
|
2024-01-31 12:14:04 +08:00 |
GatherFunctionQuantileVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
GetAggregatesVisitor.cpp
|
Fix ORDER BY tuple of WINDOW functions
|
2023-07-16 02:52:06 +02:00 |
GetAggregatesVisitor.h
|
Support clang-18 (Wmissing-field-initializers)
|
2023-08-23 15:53:45 +02: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
|
Revert "Revert flaky"
|
2024-01-19 13:51:30 +01:00 |
getCustomKeyFilterForParallelReplicas.h
|
Revert "Revert flaky"
|
2024-01-19 13:51:30 +01:00 |
getHeaderForProcessingStage.cpp
|
Miscellaneous
|
2024-02-19 05:10:39 +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
|
Code refactoring according to code review
|
2023-10-16 17:52:39 -07:00 |
GinFilter.h
|
Code refactoring according to code review
|
2023-10-16 17:52:39 -07:00 |
GlobalSubqueriesVisitor.h
|
Fix problem detected by UBSAN
|
2024-02-01 11:46:59 +01:00 |
GraceHashJoin.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
GraceHashJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03: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
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
HashJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
IdentifierSemantic.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
IdentifierSemantic.h
|
Fix 01890_materialized_distributed_join
|
2023-10-12 10:45:57 +00: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
|
Seperate max_execution_time and max_estimated_execution_time
|
2024-01-07 12:32:42 +08:00 |
IInterpreterUnionOrSelectQuery.h
|
Fix crash in EXPLAIN PIPELINE for Merge over Distributed
|
2023-04-02 10:48:23 +02:00 |
IJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
IKeyValueEntity.h
|
better code for join with dict
|
2022-08-10 14:20:29 +00:00 |
InDepthNodeVisitor.h
|
Modifiy visitor
|
2022-11-23 13:32:36 +00:00 |
InJoinSubqueriesPreprocessor.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
Implement Variant data type
|
2023-12-19 16:45:15 +00:00 |
inplaceBlockConversions.h
|
Added a new column _block_number (#47532)
|
2023-09-20 11:31:12 +02:00 |
InternalTextLogsQueue.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InternalTextLogsQueue.h
|
Some fixups
|
2024-01-07 22:28:08 +00:00 |
InterpreterAlterNamedCollectionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterAlterNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterAlterQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterAlterQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterBackupQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterCheckQuery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterCreateFunctionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterCreateFunctionQuery.h
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterCreateIndexQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterCreateIndexQuery.h
|
|
|
InterpreterCreateNamedCollectionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterCreateNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterCreateQuery.cpp
|
Merge branch 'master' into Support_parameterized_view_with_analyzer
|
2024-02-13 13:08:35 +01:00 |
InterpreterCreateQuery.h
|
Fix
|
2023-11-06 18:32:29 +01:00 |
InterpreterDeleteQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDeleteQuery.h
|
Support delete from ... where syntax on mergetree tables
|
2022-07-15 12:32:41 +08:00 |
InterpreterDescribeCacheQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDescribeQuery.h
|
allow to include virtual columns into DESCRIBE query
|
2023-09-29 11:08:46 +00:00 |
InterpreterDropFunctionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDropNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterDropQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDropQuery.h
|
the worst fix for a deadlock ever
|
2023-08-17 00:42:51 +02:00 |
InterpreterExistsQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
Merge pull request #58195 from Unalian/feat-58127
|
2024-02-13 23:51:03 +01:00 |
InterpreterFactory.h
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterInsertQuery.cpp
|
Fixing tests.
|
2024-02-14 12:28:54 +00:00 |
InterpreterInsertQuery.h
|
Refactor Squashing for inserts.
|
2024-02-13 16:16:53 +00:00 |
InterpreterKillQueryQuery.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterRenameQuery.h
|
Don not produce warning if a system table was created on startup
|
2023-08-07 02:26:23 +02:00 |
InterpreterSelectIntersectExceptQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterSelectIntersectExceptQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSelectQuery.cpp
|
Use opd prewhere optimizaer for old analyzer.
|
2024-02-09 14:47:24 +00:00 |
InterpreterSelectQuery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterSelectQueryAnalyzer.cpp
|
Review fixes
|
2024-01-23 11:59:41 +01:00 |
InterpreterSelectQueryAnalyzer.h
|
Analyzer log used row policies
|
2023-11-09 19:43:31 +03:00 |
InterpreterSelectWithUnionQuery.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
InterpreterSelectWithUnionQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSetQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterSetQuery.h
|
Ignore setting constraints for projection ASTs
|
2023-07-12 10:34:36 +08:00 |
InterpreterShowColumnsQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowColumnsQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterShowCreateQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowEngineQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowEngineQuery.h
|
Update InterpreterShowEngineQuery.h
|
2023-02-01 04:57:58 +03:00 |
InterpreterShowFunctionsQuery.cpp
|
Style check for abbreviations
|
2024-02-17 02:14:15 +01:00 |
InterpreterShowFunctionsQuery.h
|
Add SHOW FUNCTIONS support to client
|
2023-09-07 14:08:50 -07:00 |
InterpreterShowIndexesQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowIndexesQuery.h
|
Initial version of SHOW INDEXES
|
2023-04-25 20:48:11 +00:00 |
InterpreterShowProcesslistQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowSettingQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowSettingQuery.h
|
Add SHOW SETTING query
|
2023-10-25 18:49:00 +03:00 |
InterpreterShowTablesQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowTablesQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterSystemQuery.cpp
|
Cleanups
|
2024-02-14 00:21:13 +01:00 |
InterpreterSystemQuery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterTransactionControlQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUndropQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterUndropQuery.h
|
support undrop table
|
2023-03-27 22:16:36 +08:00 |
InterpreterUseQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterWatchQuery.h
|
|
|
interpretSubquery.cpp
|
Revert "Trying to fix a test."
|
2023-06-15 16:42:38 +00:00 |
interpretSubquery.h
|
Revert "Trying to fix a test."
|
2023-06-15 16:42:38 +00:00 |
InterserverCredentials.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +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
|
More conversions
|
2022-07-31 22:06:02 +00:00 |
ITokenExtractor.h
|
Various cosmetic cleanups
|
2023-01-20 10:45:35 +00:00 |
joinDispatch.h
|
Join enums refactoring
|
2022-07-29 18:35:05 +02:00 |
JoinedTables.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
JoinedTables.h
|
Addressed review comments
|
2023-03-21 18:29:26 +01:00 |
JoinSwitcher.cpp
|
addJoinedBlock -> addBlockToJoin
|
2023-07-05 17:03:18 +00:00 |
JoinSwitcher.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
JoinToSubqueryTransformVisitor.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
JoinToSubqueryTransformVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
JoinUtils.cpp
|
Another fix join using nullable in old analyzer
|
2024-01-09 11:58:50 +00:00 |
JoinUtils.h
|
Fix MergeJoin lowcard keys support
|
2023-12-13 17:43:15 +00:00 |
Lemmatizers.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
Lemmatizers.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
loadMetadata.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
loadMetadata.h
|
fix
|
2023-05-12 20:27:41 +00:00 |
LogicalExpressionsOptimizer.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
LogicalExpressionsOptimizer.h
|
LogicalExpressionsOptimizer: optimze for LowCardinality
|
2022-11-02 16:56:58 +08:00 |
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
MergeJoin.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
MergeJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
MergeTreeTransaction.cpp
|
Update MergeTreeTransaction.cpp
|
2023-06-26 13:44:09 +03:00 |
MergeTreeTransaction.h
|
Fix MergeTreeTransaction::isReadOnly
|
2023-03-07 16:16:51 +00:00 |
MergeTreeTransactionHolder.cpp
|
|
|
MergeTreeTransactionHolder.h
|
|
|
MetricLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
MetricLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
misc.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
MonotonicityCheckVisitor.h
|
Revert "Merge pull request #59122 from arthurpassos/bring_back_attach_partition_pr"
|
2024-02-07 02:52:43 +01:00 |
MutationsInterpreter.cpp
|
Merge branch 'master' into broken-projections-better-handling
|
2024-01-26 16:27:23 +01:00 |
MutationsInterpreter.h
|
Merge branch 'master' into broken-projections-better-handling
|
2023-12-21 17:17:50 +01:00 |
MutationsNonDeterministicHelpers.cpp
|
Support query parameters in ALTER TABLE ... PART
|
2024-01-15 14:16:54 +03:00 |
MutationsNonDeterministicHelpers.h
|
allow to execute constant non-deterministic functions in mutations on initiator
|
2023-08-07 17:16:15 +00:00 |
NormalizeSelectWithUnionQueryVisitor.cpp
|
Fix incomplete query result for UNION in view() function.
|
2023-11-02 18:33:57 +00:00 |
NormalizeSelectWithUnionQueryVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
OpenTelemetrySpanLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
|
Update OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
|
2023-08-15 09:46:40 +03:00 |
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h
|
Revert "Revert "Merge pull request #50951 from ZhiguoZh/20230607-toyear-fix""
|
2023-07-04 17:38:53 +02:00 |
OptimizeIfChains.cpp
|
add checks
|
2023-03-09 12:37:57 +01:00 |
OptimizeIfChains.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
OptimizeIfWithConstantConditionVisitor.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
Fix some skip_unused_shards tests.
|
2023-08-24 11:07:17 +00:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
parseColumnsListForTableFunction.cpp
|
Implement Variant data type
|
2023-12-19 16:45:15 +00:00 |
parseColumnsListForTableFunction.h
|
Implement Variant data type
|
2023-12-19 16:45:15 +00:00 |
PartLog.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
PartLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
PasteJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
PredicateExpressionsOptimizer.cpp
|
Fixing tests.
|
2023-11-14 12:51:25 +00:00 |
PredicateExpressionsOptimizer.h
|
|
|
PredicateRewriteVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
PredicateRewriteVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
PreparedSets.cpp
|
Fix PreparedSets
|
2024-02-07 12:43:26 +00:00 |
PreparedSets.h
|
Fix PreparedSets
|
2024-02-07 12:43:26 +00:00 |
processColumnTransformers.cpp
|
|
|
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
ProcessList.h
|
Add server settings "shutdown_wait_backups_and_restores" (default=true)
|
2024-01-18 13:27:14 +01:00 |
ProcessorsProfileLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
ProcessorsProfileLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
ProfileEventsExt.cpp
|
Use FQDN as host name by default for TCP
|
2024-01-30 20:27:30 +00:00 |
ProfileEventsExt.h
|
Use FQDN as host name by default for TCP
|
2024-01-30 20:27:30 +00:00 |
QueryAliasesVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
QueryAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
QueryLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
QueryLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
QueryNormalizer.cpp
|
QueryNormalizer only checks stack size
|
2023-10-16 10:33:04 +00: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
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
QueryThreadLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
QueryViewsLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
QueryViewsLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
RedundantFunctionsInOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
registerInterpreters.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
registerInterpreters.h
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
removeOnClusterClauseIfNeeded.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
removeOnClusterClauseIfNeeded.h
|
Add settings and processing code
|
2023-08-03 12:44:44 +03: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
|
Fix typo
|
2024-01-30 07:01:07 +00:00 |
replaceForPositionalArguments.h
|
Fix
|
2022-07-30 18:42:22 +03:00 |
replaceMissedSubcolumnsInQuery.cpp
|
Replace missed Object(Nullable(json)) subcolumns
|
2023-09-19 09:55:45 +08:00 |
replaceMissedSubcolumnsInQuery.h
|
Replace missed Object(Nullable(json)) subcolumns
|
2023-09-19 09:55:45 +08:00 |
ReplaceQueryParameterVisitor.cpp
|
fix
|
2023-08-16 22:35:45 +02:00 |
ReplaceQueryParameterVisitor.h
|
fix
|
2023-08-16 22:35:45 +02:00 |
RequiredSourceColumnsData.cpp
|
|
|
RequiredSourceColumnsData.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
RequiredSourceColumnsVisitor.cpp
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
RequiredSourceColumnsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteArrayExistsFunctionVisitor.cpp
|
Fix build
|
2023-09-08 05:22:21 +02:00 |
RewriteArrayExistsFunctionVisitor.h
|
Better
|
2023-09-07 02:35:21 +00:00 |
RewriteCountDistinctVisitor.cpp
|
implement intersect + except distinct
|
2022-08-30 18:09:01 +08:00 |
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
|
Support function to subcolumns optimization for Variant, better text priority for reading Bool
|
2023-12-27 20:04:14 +00:00 |
RewriteFunctionToSubcolumnVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteOrderByVisitor.cpp
|
Fix: rewrite only outer braces
|
2022-07-06 10:23:05 +00:00 |
RewriteOrderByVisitor.hpp
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteSumFunctionWithSumAndCountVisitor.cpp
|
Maintain function alias in RewriteSumFunctionWithSumAndCountVisitor
|
2024-02-06 19:09:28 +01:00 |
RewriteSumFunctionWithSumAndCountVisitor.h
|
Rewrite the AST of sum(column + literal) function
|
2023-12-15 01:28:47 +08: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 |
RewriteUniqToCountVisitor.cpp
|
Fix optimize_uniq_to_count removing the column alias
|
2024-02-15 14:10:55 +01:00 |
RewriteUniqToCountVisitor.h
|
Add optimization uniq to count
|
2023-09-13 16:16:11 +08:00 |
RowRefs.cpp
|
Fixed code review issues
|
2024-02-13 15:41:17 +03:00 |
RowRefs.h
|
Make the code in Join less disgusting
|
2023-03-19 07:35:56 +01:00 |
S3QueueLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
S3QueueLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +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
|
remove old code of projection analysis
|
2023-10-12 23:25:20 +00:00 |
ServerAsynchronousMetrics.cpp
|
Add statement 'SYSTEM RELOAD ASYNCHRONOUS METRICS'
|
2024-01-22 17:14:58 +00:00 |
ServerAsynchronousMetrics.h
|
Add statement 'SYSTEM RELOAD ASYNCHRONOUS METRICS'
|
2024-01-22 17:14:58 +00:00 |
Session.cpp
|
Style check for abbreviations
|
2024-02-17 02:14:15 +01:00 |
Session.h
|
Style check for abbreviations
|
2024-02-17 02:14:15 +01:00 |
SessionLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
SessionLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
SessionTracker.cpp
|
Implemented max sessions for user
|
2023-07-30 22:09:03 +00:00 |
SessionTracker.h
|
Implemented max sessions for user
|
2023-07-30 22:09:03 +00:00 |
Set.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
Set.h
|
Merge branch 'master' into non-ready-set-ttl
|
2024-02-07 11:29:04 +00:00 |
SetKeys.h
|
Cleanup.
|
2023-06-22 14:23:04 +00:00 |
SetVariants.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
SetVariants.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
sortBlock.cpp
|
More iota
|
2023-12-29 17:20:18 +01:00 |
sortBlock.h
|
Sort block improvements
|
2023-06-18 12:52:08 +03:00 |
SortedBlocksWriter.cpp
|
Fix usage of temporary directories during RESTORE
|
2023-07-27 19:24:54 +02:00 |
SortedBlocksWriter.h
|
Upd TemporaryFileOnDisk
|
2022-08-24 16:15:54 +00:00 |
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
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
SystemLog.cpp
|
Make comments for system tables also available in local mode and enforce comments not to be empty (#59493)
|
2024-02-05 11:17:58 +01:00 |
SystemLog.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TableJoin.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TableJoin.h
|
Fix join using nullable in old analyzer
|
2024-01-09 11:45:34 +00:00 |
TableOverrideUtils.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
TablesStatus.h
|
|
|
TemporaryDataOnDisk.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TemporaryDataOnDisk.h
|
Minor
|
2024-01-24 18:44:13 +01:00 |
TextLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
TextLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
ThreadStatusExt.cpp
|
fix data race in SensitiveDataMasker
|
2024-01-17 08:10:50 +02:00 |
TraceCollector.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TraceCollector.h
|
close pipe in run() if exception happens
|
2023-05-08 23:00:20 +00:00 |
TraceLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
TraceLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
TransactionLog.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionLog.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionsInfoLog.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionsInfoLog.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionVersionMetadata.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionVersionMetadata.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TranslateQualifiedNamesVisitor.cpp
|
Miscellaneous
|
2024-02-19 02:58:51 +01:00 |
TranslateQualifiedNamesVisitor.h
|
Create new StorageView with substituted parameters for every SELECT query of a parameterized view
|
2023-07-25 14:04:55 +02:00 |
TreeCNFConverter.cpp
|
Fix incorrect Exceptions
|
2023-12-24 21:26:32 +01:00 |
TreeCNFConverter.h
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
TreeOptimizer.cpp
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into negtive-position
|
2024-01-30 04:03:35 +00:00 |
TreeOptimizer.h
|
fix crash with multiif and constant condition and nullable arguments
|
2023-05-22 23:31:50 +00:00 |
TreeRewriter.cpp
|
Fix inconsistent formatting of SELECT ... FROM (EXPLAIN ...)
|
2024-02-18 05:38:34 +01:00 |
TreeRewriter.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
WhereConstraintsOptimizer.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
Allow Floats as boundaries for RANGE is nonsense
|
2023-07-30 23:19:54 +00:00 |
WindowDescription.h
|
Improve file includes
|
2023-03-24 03:44:52 +01:00 |
ZooKeeperLog.cpp
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
ZooKeeperLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |