.. |
Access
|
Correct revoke for the partially granted rights. (#61115)
|
2024-03-22 02:13:51 -04:00 |
Cache
|
Merge pull request #62925 from ClickHouse/fix-temporary-data-in-cache-base-directory-creation
|
2024-04-26 10:17:45 +00:00 |
ClusterProxy
|
Cleanup #ci_set_analyzer
|
2024-03-20 10:47:15 +01:00 |
examples
|
Fix build of examples
|
2024-03-10 10:03:31 +01:00 |
fuzzers
|
Fix fuzzers
|
2024-03-17 15:44:36 +01:00 |
JIT
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
MySQL
|
Fix crash in index definition containing sql udf
|
2024-04-03 10:45:45 +00:00 |
tests
|
Don't access static members through instance, pt. II
|
2024-04-07 11:09:35 +00:00 |
ActionLocksManager.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Fixed tests
|
2024-04-11 11:09:08 +03:00 |
ActionsDAG.h
|
Fixed tests
|
2024-04-11 11:09:08 +03:00 |
ActionsVisitor.cpp
|
Don't access static members through instance, pt. II
|
2024-04-07 11:09:35 +00:00 |
ActionsVisitor.h
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
AddDefaultDatabaseVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
AddIndexConstraintsOptimizer.cpp
|
Fix most tests
|
2024-02-26 02:31:58 +08:00 |
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
addMissingDefaults.h
|
|
|
addTypeConversionToAST.cpp
|
|
|
addTypeConversionToAST.h
|
|
|
AggregatedData.h
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregatedDataVariants.cpp
|
fixed
|
2024-03-14 08:55:59 +08:00 |
AggregatedDataVariants.h
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregateDescription.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregateDescription.h
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregateFunctionOfGroupByKeysVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
AggregationCommon.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
AggregationMethod.cpp
|
too big translation unit in Aggregator
|
2024-03-12 16:17:33 +08:00 |
AggregationMethod.h
|
too big translation unit in Aggregator
|
2024-03-12 16:17:33 +08:00 |
AggregationUtils.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregationUtils.h
|
|
|
Aggregator.cpp
|
Don't access static members through instance, pt. II
|
2024-04-07 11:09:35 +00:00 |
Aggregator.h
|
Fixed code review issues
|
2024-03-28 15:04:14 +03:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
|
|
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
|
|
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ArithmeticOperationsInAgrFuncOptimize.cpp
|
|
|
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
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
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
AsynchronousInsertLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
AsynchronousInsertLog.h
|
Update to clang-19
|
2024-02-27 14:37:21 +01:00 |
AsynchronousInsertQueue.cpp
|
Merge branch 'master' into cannot_allocate_thread
|
2024-04-10 21:21:42 +02:00 |
AsynchronousInsertQueue.h
|
Update AsynchronousInsertQueue.h
|
2024-03-20 19:19:30 +01:00 |
AsynchronousMetricLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
AsynchronousMetricLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
BackupLog.cpp
|
add event_time to backup_log system table
|
2024-04-11 10:22:02 +01:00 |
BackupLog.h
|
Done
|
2024-04-15 16:19:54 +00:00 |
BlobStorageLog.cpp
|
fix: add missing hostname column to blob_storage_log system table
|
2024-04-09 17:50:28 +01:00 |
BlobStorageLog.h
|
Update to clang-19
|
2024-02-27 14:37:21 +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
|
Add function getClientHTTPHeader, part 1
|
2024-03-23 20:52:26 +01:00 |
ClientInfo.h
|
Add function getClientHTTPHeader, part 1
|
2024-03-23 20:52:26 +01: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
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
ColumnAliasesVisitor.cpp
|
|
|
ColumnAliasesVisitor.h
|
|
|
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
|
|
|
ComparisonTupleEliminationVisitor.h
|
|
|
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
|
|
|
Context.cpp
|
Merge pull request #62305 from Avogar/fix-scalar-data-race
|
2024-04-05 15:24:26 +02:00 |
Context.h
|
Better
|
2024-04-04 20:00:22 +00:00 |
convertFieldToType.cpp
|
Merge pull request #60004 from yariks5s/fix_datetime64_scale_conversion
|
2024-02-29 15:45:54 +01:00 |
convertFieldToType.h
|
|
|
ConvertFunctionOrLikeVisitor.cpp
|
|
|
ConvertFunctionOrLikeVisitor.h
|
|
|
ConvertStringsToEnumVisitor.cpp
|
Fix some typos
|
2023-10-15 15:43:02 +02:00 |
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
CrashLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
createBlockSelector.cpp
|
|
|
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Merge pull request #61534 from ClickHouse/fix-db-iterator-waits
|
2024-04-08 12:10:50 +02:00 |
DatabaseCatalog.h
|
fix build
|
2024-03-20 16:17:30 +00:00 |
DDLTask.cpp
|
batter
|
2024-03-26 13:02:12 +08: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
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00: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
|
|
|
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
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
evaluateConstantExpression.h
|
Merge branch 'master' into planner-prepare-filters-for-analysis-2
|
2023-09-11 16:14:03 +02:00 |
executeDDLQueryOnCluster.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
executeDDLQueryOnCluster.h
|
Move ZooKeeperRetries.h to Common
|
2024-01-30 19:02:17 +01:00 |
executeQuery.cpp
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +01:00 |
executeQuery.h
|
Fix writing exception message in output format in HTTP when http_wait_end_of_query is used
|
2024-03-22 16:03:28 +00:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
ExecuteScalarSubqueriesVisitor.h
|
|
|
ExpressionActions.cpp
|
Merge pull request #60196 from azat/preliminary-filters-fix
|
2024-02-29 10:17:05 -08:00 |
ExpressionActions.h
|
Fix actions execution during preliminary filtering (PK, partition pruning)
|
2024-02-22 15:01:57 +01:00 |
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExpressionAnalyzer.h
|
|
|
ExpressionJIT.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExternalDictionariesLoader.cpp
|
Add few notes and a debug check.
|
2024-03-19 22:07:13 +01:00 |
ExternalDictionariesLoader.h
|
Better code: remove unnecessary usage of const_cast and std::function.
|
2024-03-19 02:56:38 +01:00 |
ExternalLoader.cpp
|
Merge pull request #62320 from seandhaynes/shaynes/dictionary-source-type
|
2024-04-08 14:13:06 +02:00 |
ExternalLoader.h
|
Better code: remove unnecessary usage of const_cast and std::function.
|
2024-03-19 02:56:38 +01:00 |
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderDictionaryStorageConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderTempConfigRepository.cpp
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderTempConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderXMLConfigRepository.cpp
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderXMLConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
|
|
FilesystemCacheLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
FilesystemCacheLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
FilesystemReadPrefetchesLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
FilesystemReadPrefetchesLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
FillingRow.cpp
|
|
|
FillingRow.h
|
|
|
formatWithPossiblyHidingSecrets.h
|
|
|
FullSortingMergeJoin.h
|
fix review comments
|
2024-03-19 11:29:22 +08:00 |
FunctionMaskingArgumentCheckVisitor.h
|
|
|
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
fix bug of quantileGK
|
2024-01-31 12:14:04 +08:00 |
GatherFunctionQuantileVisitor.h
|
|
|
GetAggregatesVisitor.cpp
|
|
|
GetAggregatesVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
getColumnFromBlock.cpp
|
|
|
getColumnFromBlock.h
|
|
|
getCustomKeyFilterForParallelReplicas.cpp
|
Limit backtracking in parser
|
2024-03-17 19:54:45 +01:00 |
getCustomKeyFilterForParallelReplicas.h
|
Revert "Revert flaky"
|
2024-01-19 13:51:30 +01:00 |
getHeaderForProcessingStage.cpp
|
Merge branch 'master' into analyzer-refactor-constant-name
|
2024-03-06 17:55:52 +01:00 |
getHeaderForProcessingStage.h
|
|
|
getTableExpressions.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +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
|
Rename the setting
|
2024-03-07 13:38:00 +00:00 |
GraceHashJoin.cpp
|
Remove a bunch of transitive dependencies
|
2024-03-11 14:52:32 +01:00 |
GraceHashJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
GroupByFunctionKeysVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
GroupingSetsRewriterVisitor.cpp
|
|
|
GroupingSetsRewriterVisitor.h
|
|
|
HashJoin.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
HashJoin.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
IdentifierSemantic.cpp
|
|
|
IdentifierSemantic.h
|
Fix 01890_materialized_distributed_join
|
2023-10-12 10:45:57 +00:00 |
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
Merge pull request #61356 from vitlibar/fix-replace-dictionary
|
2024-03-21 16:45:06 +01:00 |
IExternalLoaderConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
IInterpreter.cpp
|
|
|
IInterpreter.h
|
|
|
IInterpreterUnionOrSelectQuery.cpp
|
Limit backtracking in parser
|
2024-03-17 19:54:45 +01:00 |
IInterpreterUnionOrSelectQuery.h
|
|
|
IJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
IKeyValueEntity.h
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
fix tests
|
2024-03-01 18:44:33 +00:00 |
inplaceBlockConversions.h
|
refactoring of virtual columns
|
2024-02-21 00:57:35 +00: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
|
|
|
InterpreterAlterQuery.cpp
|
Don't access static members through instance, pt. II
|
2024-04-07 11:09:35 +00:00 |
InterpreterAlterQuery.h
|
|
|
InterpreterBackupQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterCheckQuery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterCreateFunctionQuery.cpp
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
InterpreterCreateFunctionQuery.h
|
|
|
InterpreterCreateIndexQuery.cpp
|
Don't access static members through instance, pt. II
|
2024-04-07 11:09:35 +00:00 |
InterpreterCreateIndexQuery.h
|
|
|
InterpreterCreateNamedCollectionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterCreateNamedCollectionQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
Merge pull request #62117 from pamarcos/pamarcos/copy_comment_in_create_as_statement
|
2024-04-22 09:52:21 +00:00 |
InterpreterCreateQuery.h
|
skip more sanity checks for secondary create queries
|
2024-03-23 00:03:31 +01:00 |
InterpreterDeleteQuery.cpp
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
InterpreterDeleteQuery.h
|
|
|
InterpreterDescribeCacheQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterDescribeQuery.h
|
allow to include virtual columns into DESCRIBE query
|
2023-09-29 11:08:46 +00:00 |
InterpreterDropFunctionQuery.cpp
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDropNamedCollectionQuery.h
|
|
|
InterpreterDropQuery.cpp
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into better-stress-upgrade-checks
|
2024-04-08 13:58:14 +00:00 |
InterpreterDropQuery.h
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into better-stress-upgrade-checks
|
2024-04-03 12:07:22 +00:00 |
InterpreterExistsQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01: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
|
Disable analyzer for EXPLAIN SYNTAX queries
|
2024-03-21 15:27:39 +00:00 |
InterpreterFactory.h
|
Update to clang-19
|
2024-02-27 14:37:21 +01:00 |
InterpreterInsertQuery.cpp
|
Merge pull request #62333 from ClickHouse/vdimir/check_max_insert_threads_support
|
2024-04-10 11:14:13 +00:00 |
InterpreterInsertQuery.h
|
Fix logical error in RabbitMQ storage with MATERIALIZED columns
|
2024-03-13 16:41:35 +00:00 |
InterpreterKillQueryQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterRenameQuery.h
|
|
|
InterpreterSelectIntersectExceptQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterSelectIntersectExceptQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
Merge pull request #62264 from Algunenano/nested_includes_Ñ
|
2024-04-05 17:00:28 +02:00 |
InterpreterSelectQuery.h
|
Fix
|
2024-02-26 02:31:57 +08:00 |
InterpreterSelectQueryAnalyzer.cpp
|
Revert "Revert "Analyzer: Fix virtual columns in StorageMerge""
|
2024-03-18 14:00:20 +01:00 |
InterpreterSelectQueryAnalyzer.h
|
Analyzer log used row policies
|
2023-11-09 19:43:31 +03:00 |
InterpreterSelectWithUnionQuery.cpp
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
InterpreterSelectWithUnionQuery.h
|
|
|
InterpreterSetQuery.cpp
|
Fix inconsistent formatting of SET param_...
|
2024-02-26 02:11:51 +01:00 |
InterpreterSetQuery.h
|
|
|
InterpreterShowColumnsQuery.cpp
|
better interfaces for virtual columns
|
2024-03-01 22:29:56 +00:00 |
InterpreterShowColumnsQuery.h
|
|
|
InterpreterShowCreateQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowEngineQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowEngineQuery.h
|
|
|
InterpreterShowFunctionsQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterShowFunctionsQuery.h
|
Add SHOW FUNCTIONS support to client
|
2023-09-07 14:08:50 -07:00 |
InterpreterShowIndexesQuery.cpp
|
Revert "Fix wacky primary key sorting in SHOW INDEX "
|
2024-03-06 08:57:20 +01:00 |
InterpreterShowIndexesQuery.h
|
|
|
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
|
|
|
InterpreterSystemQuery.cpp
|
SYSTEM DROP uninitialized cache fix
|
2024-04-24 17:46:15 +03:00 |
InterpreterSystemQuery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterTransactionControlQuery.cpp
|
fix style check errors
|
2024-03-18 14:14:52 +00:00 |
InterpreterTransactionControlQuery.h
|
Add implicit_transaction setting
|
2022-06-23 15:23:37 +02:00 |
InterpreterUndropQuery.cpp
|
init
|
2024-03-21 18:39:05 +00:00 |
InterpreterUndropQuery.h
|
|
|
InterpreterUseQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterWatchQuery.h
|
Forward declaration of IStorage in InterpreterWatchQuery
|
2022-01-10 22:01:41 +03:00 |
interpretSubquery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
interpretSubquery.h
|
|
|
InterserverCredentials.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterserverCredentials.h
|
|
|
InterserverIOHandler.h
|
|
|
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
joinDispatch.h
|
Fix FastTest
|
2024-03-18 08:00:21 +00:00 |
JoinedTables.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
JoinedTables.h
|
|
|
JoinSwitcher.cpp
|
|
|
JoinSwitcher.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
JoinToSubqueryTransformVisitor.cpp
|
Remove it from remaining places
|
2024-03-19 19:55:59 +01:00 |
JoinToSubqueryTransformVisitor.h
|
|
|
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
|
|
|
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
loadMetadata.h
|
|
|
LogicalExpressionsOptimizer.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
LogicalExpressionsOptimizer.h
|
|
|
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
|
|
MergeJoin.cpp
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
MergeJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
MergeTreeTransaction.cpp
|
Block cannot allocate thread fault in noexcept functions in MergeTreeTransaction
|
2024-04-18 10:30:36 +00:00 |
MergeTreeTransaction.h
|
|
|
MergeTreeTransactionHolder.cpp
|
|
|
MergeTreeTransactionHolder.h
|
|
|
MetricLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
MetricLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
misc.h
|
|
|
MonotonicityCheckVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
MutationsInterpreter.cpp
|
Review fix
|
2024-03-26 22:02:50 +01:00 |
MutationsInterpreter.h
|
Fix and more tests for broken projections handling
|
2024-03-26 18:47:48 +01:00 |
MutationsNonDeterministicHelpers.cpp
|
Support query parameters in ALTER TABLE ... PART
|
2024-01-15 14:16:54 +03:00 |
MutationsNonDeterministicHelpers.h
|
|
|
NormalizeSelectWithUnionQueryVisitor.cpp
|
Fix incomplete query result for UNION in view() function.
|
2023-11-02 18:33:57 +00:00 |
NormalizeSelectWithUnionQueryVisitor.h
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
OpenTelemetrySpanLog.h
|
Fixing more headers
|
2024-02-29 15:40:30 +00:00 |
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
|
|
|
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h
|
|
|
OptimizeIfChains.cpp
|
|
|
OptimizeIfChains.h
|
|
|
OptimizeIfWithConstantConditionVisitor.cpp
|
Fixing tests.
|
2024-02-27 19:42:49 +00:00 |
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
Code cleanup
|
2024-03-18 14:24:06 +01:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
Code cleanup
|
2024-03-18 14:24:06 +01:00 |
parseColumnsListForTableFunction.cpp
|
Merge pull request #61999 from Avogar/variant-number-bool
|
2024-03-28 14:33:24 +01:00 |
parseColumnsListForTableFunction.h
|
Merge branch 'master' into variant-improvements
|
2024-02-28 17:38:54 +01:00 |
PartLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
PartLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +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
|
|
|
PreparedSets.cpp
|
Fix for clang-19
|
2024-03-22 22:12:59 +01:00 |
PreparedSets.h
|
Fix for clang-19
|
2024-03-22 22:12:59 +01:00 |
processColumnTransformers.cpp
|
better interfaces for virtual columns
|
2024-03-01 22:29:56 +00:00 |
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Merge branch 'master' into async-loader-waiters-limit
|
2024-03-21 10:58:22 +00:00 |
ProcessList.h
|
Merge branch 'master' into async-loader-waiters-limit
|
2024-03-21 10:58:22 +00:00 |
ProcessorsProfileLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
ProcessorsProfileLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +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
|
|
|
QueryLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
QueryLog.h
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +01:00 |
QueryNormalizer.cpp
|
QueryNormalizer only checks stack size
|
2023-10-16 10:33:04 +00:00 |
QueryNormalizer.h
|
|
|
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
QueryThreadLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
QueryViewsLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
QueryViewsLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
RedundantFunctionsInOrderByVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00: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
|
|
|
removeOnClusterClauseIfNeeded.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
removeOnClusterClauseIfNeeded.h
|
|
|
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
replaceForPositionalArguments.cpp
|
Fix typo
|
2024-01-30 07:01:07 +00:00 |
replaceForPositionalArguments.h
|
|
|
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
|
|
|
ReplaceQueryParameterVisitor.h
|
|
|
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
|
|
|
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
|
|
|
RewriteCountDistinctVisitor.h
|
|
|
RewriteCountVariantsVisitor.cpp
|
|
|
RewriteCountVariantsVisitor.h
|
|
|
RewriteFunctionToSubcolumnVisitor.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
RewriteFunctionToSubcolumnVisitor.h
|
|
|
RewriteOrderByVisitor.cpp
|
Fix crash
|
2024-04-03 12:18:54 +00:00 |
RewriteOrderByVisitor.hpp
|
|
|
RewriteSumFunctionWithSumAndCountVisitor.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
RewriteSumFunctionWithSumAndCountVisitor.h
|
Rewrite the AST of sum(column + literal) function
|
2023-12-15 01:28:47 +08:00 |
RewriteSumIfFunctionVisitor.cpp
|
|
|
RewriteSumIfFunctionVisitor.h
|
|
|
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
|
|
|
S3QueueLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
S3QueueLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
Fixing more headers
|
2024-02-29 15:40:30 +00:00 |
ServerAsynchronousMetrics.cpp
|
Apply review comments
|
2024-04-12 03:47:29 +02:00 |
ServerAsynchronousMetrics.h
|
Apply review comments
|
2024-04-12 03:47:29 +02:00 |
Session.cpp
|
Fix integration tests
|
2024-04-26 19:56:24 +02:00 |
Session.h
|
Fix comment
|
2024-04-26 19:58:34 +02:00 |
SessionLog.cpp
|
Add table system.keywords [Part 1] (#51808)
|
2024-03-18 16:58:57 +01:00 |
SessionLog.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
SessionTracker.cpp
|
|
|
SessionTracker.h
|
|
|
Set.cpp
|
Don't access static members through instance, pt. II
|
2024-04-07 11:09:35 +00:00 |
Set.h
|
Merge branch 'master' into non-ready-set-ttl
|
2024-02-07 11:29:04 +00:00 |
SetKeys.h
|
|
|
SetVariants.cpp
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
SetVariants.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
sortBlock.cpp
|
More iota
|
2023-12-29 17:20:18 +01:00 |
sortBlock.h
|
|
|
SortedBlocksWriter.cpp
|
Fix usage of temporary directories during RESTORE
|
2023-07-27 19:24:54 +02:00 |
SortedBlocksWriter.h
|
|
|
SquashingTransform.cpp
|
Style
|
2024-03-22 20:00:42 +00:00 |
SquashingTransform.h
|
|
|
StorageID.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
StorageID.h
|
|
|
SubstituteColumnOptimizer.cpp
|
|
|
SubstituteColumnOptimizer.h
|
Fix
|
2024-02-26 02:31:57 +08:00 |
SynonymsExtensions.cpp
|
|
|
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
Don't use ASTPtr for the comment following feedback in the PR
|
2024-04-14 17:58:55 +02:00 |
SystemLog.h
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01: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 |
TableNameHints.h
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
TableOverrideUtils.cpp
|
|
|
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
Do not try to INSERT into readonly replicas for Distributed engine
|
2024-03-26 11:21:38 +01:00 |
TablesStatus.h
|
Do not try to INSERT into readonly replicas for Distributed engine
|
2024-03-26 11:21:38 +01:00 |
TemporaryDataOnDisk.cpp
|
Fix
|
2024-04-24 18:51:45 +02:00 |
TemporaryDataOnDisk.h
|
Temporary data use temporary_files_codec setting
|
2024-03-19 19:07:45 +03:00 |
TextLog.cpp
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +01:00 |
TextLog.h
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +01:00 |
ThreadStatusExt.cpp
|
Simpler
|
2024-04-04 12:22:11 +02:00 |
TraceCollector.cpp
|
Fix real time query profiler on AArch64
|
2024-03-04 18:13:49 +01:00 |
TraceCollector.h
|
|
|
TraceLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
TraceLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
TransactionLog.cpp
|
Update TransactionLog.cpp
|
2024-04-15 17:32:28 +02:00 |
TransactionLog.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionsInfoLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
TransactionsInfoLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01: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
|
Remove it from remaining places
|
2024-03-19 19:55:59 +01:00 |
TranslateQualifiedNamesVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
TreeCNFConverter.cpp
|
Fix most tests
|
2024-02-26 02:31:58 +08:00 |
TreeCNFConverter.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
TreeOptimizer.cpp
|
Remove optimize_monotonous_functions_in_order_by
|
2024-04-25 21:46:15 +02:00 |
TreeOptimizer.h
|
|
|
TreeRewriter.cpp
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +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
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
WindowDescription.h
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
ZooKeeperLog.cpp
|
Fix error
|
2024-03-25 03:41:52 +01:00 |
ZooKeeperLog.h
|
Merge with master
|
2024-03-25 03:38:47 +01:00 |