.. |
Access
|
Merge pull request #57538 from MikhailBurdukov/ignore_on_cluster_for_grants
|
2023-12-12 14:59:58 +01:00 |
Cache
|
Merge pull request #57732 from ClickHouse/load-metadata-threads
|
2024-01-02 22:26:18 +01:00 |
ClusterProxy
|
New parallel replicas coordinator implementation (#57968)
|
2024-01-04 00:27:04 +01:00 |
examples
|
Clang-tidy detected problems
|
2023-11-27 11:00:27 +01:00 |
fuzzers
|
validation and left over fixes
|
2023-12-29 20:06:07 -08:00 |
JIT
|
Merge branch 'enable-jit-for-aggregation-without-key' of github.com:kitaisreal/ClickHouse into kitaisreal-enable-jit-for-aggregation-without-key
|
2024-01-02 22:01:59 +01:00 |
MySQL
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
tests
|
Replace std::iota with DB::iota where possible
|
2023-12-29 14:38:22 +01:00 |
ActionLocksManager.cpp
|
Overhaul RefreshTask
|
2023-12-28 17:56:04 +00:00 |
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Fixing tests.
|
2023-11-28 18:04:30 +00:00 |
ActionsDAG.h
|
Fix some test.
|
2023-12-28 17:34:28 +00:00 |
ActionsVisitor.cpp
|
Cleanup & comments
|
2023-12-23 11:44:02 +00:00 |
ActionsVisitor.h
|
|
|
AddDefaultDatabaseVisitor.h
|
Things
|
2023-12-28 17:56:05 +00:00 |
AddIndexConstraintsOptimizer.cpp
|
|
|
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
addMissingDefaults.h
|
|
|
addTypeConversionToAST.cpp
|
|
|
addTypeConversionToAST.h
|
|
|
AggregateDescription.cpp
|
|
|
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
|
|
AggregationUtils.cpp
|
|
|
AggregationUtils.h
|
|
|
Aggregator.cpp
|
Merge branch 'enable-jit-for-aggregation-without-key' of github.com:kitaisreal/ClickHouse into kitaisreal-enable-jit-for-aggregation-without-key
|
2024-01-02 22:01:59 +01:00 |
Aggregator.h
|
add setting
|
2023-12-18 13:57:07 +00:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
|
|
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
|
|
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
|
|
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
|
|
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
ArrayJoinAction.cpp
|
fix failed ut
|
2023-11-27 10:48:01 +08:00 |
ArrayJoinAction.h
|
|
|
ArrayJoinedColumnsVisitor.h
|
|
|
AsynchronousInsertLog.cpp
|
|
|
AsynchronousInsertLog.h
|
|
|
AsynchronousInsertQueue.cpp
|
Fix working with read buffers in StreamingFormatExecutor
|
2023-12-28 18:47:57 +00:00 |
AsynchronousInsertQueue.h
|
|
|
AsynchronousMetricLog.cpp
|
update AsynchronousMetricLog
|
2023-11-14 18:36:41 -08:00 |
AsynchronousMetricLog.h
|
remove hostname from getDefaultOrderBy()
|
2023-11-26 23:03:44 -08:00 |
BackupLog.cpp
|
Add base backup name to system.backups and system.backup_log tables
|
2023-12-23 11:08:50 +08:00 |
BackupLog.h
|
|
|
BlobStorageLog.cpp
|
Implement system table blob_storage_log
|
2023-11-21 09:18:25 +00:00 |
BlobStorageLog.h
|
Implement system table blob_storage_log
|
2023-11-21 09:18:25 +00:00 |
BloomFilter.cpp
|
|
|
BloomFilter.h
|
|
|
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
|
Fix build
|
2023-11-13 10:09:23 +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
|
|
|
ClusterDiscovery.h
|
|
|
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
|
|
CollectJoinOnKeysVisitor.h
|
|
|
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
|
Better logging in hash join
|
2023-12-22 15:52:47 +00:00 |
ConcurrentHashJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
Context_fwd.h
|
|
|
Context.cpp
|
Merge branch 'master' into reintroduce_is_deleted
|
2023-12-29 15:46:24 +01:00 |
Context.h
|
refreshable materialized views
|
2023-12-28 17:56:04 +00:00 |
convertFieldToType.cpp
|
|
|
convertFieldToType.h
|
|
|
ConvertFunctionOrLikeVisitor.cpp
|
|
|
ConvertFunctionOrLikeVisitor.h
|
|
|
ConvertStringsToEnumVisitor.cpp
|
|
|
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
Merge remote-tracking branch 'upstream/master' into ncb/hostname-system-log-tables
|
2023-11-16 11:17:45 -08:00 |
CrashLog.h
|
|
|
createBlockSelector.cpp
|
|
|
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
|
|
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Fix incorrect Exceptions
|
2023-12-24 21:26:32 +01:00 |
DatabaseCatalog.h
|
review fixes
|
2023-12-14 11:28:49 -08:00 |
DDLTask.cpp
|
fix build
|
2024-01-04 13:36:42 +01:00 |
DDLTask.h
|
fix build
|
2024-01-04 13:36:42 +01:00 |
DDLWorker.cpp
|
Merge branch 'master' into allow-not-resolving-hostnames
|
2024-01-04 13:22:15 +01:00 |
DDLWorker.h
|
Allow avoiding resolving hostnames in DDLWorker
|
2023-12-07 03:43:26 +00:00 |
DirectJoin.cpp
|
|
|
DirectJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
DNSCacheUpdater.cpp
|
|
|
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
|
|
|
EmbeddedDictionaries.h
|
Move symbols from src/* into namespace DB
|
2023-12-29 14:37:08 +08:00 |
evaluateConstantExpression.cpp
|
|
|
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
fix
|
2024-01-02 15:13:25 +01:00 |
executeDDLQueryOnCluster.h
|
|
|
executeQuery.cpp
|
Update executeQuery.cpp
|
2023-12-17 22:54:45 +03: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
|
|
|
ExpressionActions.cpp
|
|
|
ExpressionActions.h
|
|
|
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Merge pull request #57995 from yariks5s/paste_join
|
2023-12-22 12:56:06 +01:00 |
ExpressionAnalyzer.h
|
|
|
ExpressionJIT.cpp
|
|
|
ExternalDictionariesLoader.cpp
|
|
|
ExternalDictionariesLoader.h
|
|
|
ExternalLoader.cpp
|
|
|
ExternalLoader.h
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
|
|
ExternalLoaderXMLConfigRepository.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
|
|
FilesystemCacheLog.cpp
|
|
|
FilesystemCacheLog.h
|
|
|
FilesystemReadPrefetchesLog.cpp
|
|
|
FilesystemReadPrefetchesLog.h
|
|
|
FillingRow.cpp
|
|
|
FillingRow.h
|
|
|
formatWithPossiblyHidingSecrets.h
|
|
|
FullSortingMergeJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
FunctionMaskingArgumentCheckVisitor.h
|
|
|
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
GatherFunctionQuantileVisitor.h
|
|
|
GetAggregatesVisitor.cpp
|
|
|
GetAggregatesVisitor.h
|
|
|
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
getColumnFromBlock.cpp
|
|
|
getColumnFromBlock.h
|
|
|
getCustomKeyFilterForParallelReplicas.cpp
|
Remove storage as parameter dependency, only columns are needed
|
2023-11-21 12:14:12 +00:00 |
getCustomKeyFilterForParallelReplicas.h
|
Remove storage as parameter dependency, only columns are needed
|
2023-11-21 12:14:12 +00:00 |
getHeaderForProcessingStage.cpp
|
|
|
getHeaderForProcessingStage.h
|
|
|
getTableExpressions.cpp
|
|
|
getTableExpressions.h
|
|
|
getTableOverride.cpp
|
|
|
getTableOverride.h
|
|
|
GinFilter.cpp
|
|
|
GinFilter.h
|
|
|
GlobalSubqueriesVisitor.h
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
GraceHashJoin.cpp
|
Merge pull request #58237 from azat/build/fwd-decl-exception
|
2023-12-28 00:21:09 +01:00 |
GraceHashJoin.h
|
Better logging in hash join
|
2023-12-22 15:52:47 +00:00 |
GroupByFunctionKeysVisitor.h
|
|
|
GroupingSetsRewriterVisitor.cpp
|
|
|
GroupingSetsRewriterVisitor.h
|
|
|
HashJoin.cpp
|
Merge pull request #58237 from azat/build/fwd-decl-exception
|
2023-12-28 00:21:09 +01:00 |
HashJoin.h
|
Better logging in hash join
|
2023-12-22 15:52:47 +00:00 |
IdentifierSemantic.cpp
|
|
|
IdentifierSemantic.h
|
|
|
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
|
|
IExternalLoaderConfigRepository.h
|
|
|
IInterpreter.cpp
|
|
|
IInterpreter.h
|
|
|
IInterpreterUnionOrSelectQuery.cpp
|
|
|
IInterpreterUnionOrSelectQuery.h
|
|
|
IJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
IKeyValueEntity.h
|
|
|
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
|
|
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
|
|
inplaceBlockConversions.h
|
|
|
InternalTextLogsQueue.cpp
|
|
|
InternalTextLogsQueue.h
|
|
|
InterpreterAlterNamedCollectionQuery.cpp
|
|
|
InterpreterAlterNamedCollectionQuery.h
|
|
|
InterpreterAlterQuery.cpp
|
Things
|
2023-12-28 17:56:05 +00:00 |
InterpreterAlterQuery.h
|
|
|
InterpreterBackupQuery.cpp
|
|
|
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
|
|
InterpreterCheckQuery.h
|
|
|
InterpreterCreateFunctionQuery.cpp
|
Merge pull request #57906 from ClickHouse/create_index_normalize
|
2023-12-20 17:24:19 +01:00 |
InterpreterCreateFunctionQuery.h
|
|
|
InterpreterCreateIndexQuery.cpp
|
normalize function names in CREATE INDEX
|
2023-12-15 17:40:03 +01:00 |
InterpreterCreateIndexQuery.h
|
|
|
InterpreterCreateNamedCollectionQuery.cpp
|
|
|
InterpreterCreateNamedCollectionQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
Merge pull request #58365 from bharatnc/ncb/refactor-db-factory
|
2023-12-31 00:56:24 +01:00 |
InterpreterCreateQuery.h
|
Fix
|
2023-11-06 18:32:29 +01:00 |
InterpreterDeleteQuery.cpp
|
|
|
InterpreterDeleteQuery.h
|
|
|
InterpreterDescribeCacheQuery.cpp
|
Better
|
2023-12-07 12:12:10 +01:00 |
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
|
|
InterpreterDescribeQuery.h
|
|
|
InterpreterDropFunctionQuery.cpp
|
Refactoring for UserDefinedSQLObjectsLoader
|
2023-12-12 17:03:49 +03:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
|
|
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
|
|
InterpreterDropNamedCollectionQuery.h
|
|
|
InterpreterDropQuery.cpp
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
InterpreterDropQuery.h
|
|
|
InterpreterExistsQuery.cpp
|
|
|
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
Merge branch 'master' into hanfei/statistic
|
2023-11-27 23:31:23 +01:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
|
|
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
|
|
InterpreterFactory.h
|
|
|
InterpreterInsertQuery.cpp
|
Rename directory monitor concept into background INSERT (#55978)
|
2023-11-01 15:09:39 +01:00 |
InterpreterInsertQuery.h
|
|
|
InterpreterKillQueryQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
|
|
InterpreterRenameQuery.h
|
|
|
InterpreterSelectIntersectExceptQuery.cpp
|
|
|
InterpreterSelectIntersectExceptQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
Merge pull request #57872 from CurtizJ/optimize-aggregation-consecutive-keys
|
2023-12-27 15:44:22 +01:00 |
InterpreterSelectQuery.h
|
Add index to table system.numbers (#50909)
|
2023-12-01 19:59:25 +01:00 |
InterpreterSelectQueryAnalyzer.cpp
|
create interpreter with changed select_query_options
|
2023-11-19 14:28:33 +00:00 |
InterpreterSelectQueryAnalyzer.h
|
Analyzer log used row policies
|
2023-11-09 19:43:31 +03:00 |
InterpreterSelectWithUnionQuery.cpp
|
|
|
InterpreterSelectWithUnionQuery.h
|
|
|
InterpreterSetQuery.cpp
|
|
|
InterpreterSetQuery.h
|
|
|
InterpreterShowColumnsQuery.cpp
|
Merge pull request #56306 from ClickHouse/fix-backup-restore-flatten-nested
|
2023-11-10 11:43:17 +01:00 |
InterpreterShowColumnsQuery.h
|
|
|
InterpreterShowCreateQuery.cpp
|
|
|
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowEngineQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowEngineQuery.h
|
|
|
InterpreterShowFunctionsQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowFunctionsQuery.h
|
|
|
InterpreterShowIndexesQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowIndexesQuery.h
|
|
|
InterpreterShowProcesslistQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowSettingQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowSettingQuery.h
|
|
|
InterpreterShowTablesQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowTablesQuery.h
|
|
|
InterpreterSystemQuery.cpp
|
Remove pausing, enable multithreading, kick off refresh on table creation unless the query says EMPTY
|
2023-12-28 17:56:06 +00:00 |
InterpreterSystemQuery.h
|
refreshable materialized views
|
2023-12-28 17:56:04 +00:00 |
InterpreterTransactionControlQuery.cpp
|
|
|
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUndropQuery.cpp
|
Mark a setting obsolete (#57336)
|
2023-11-29 19:24:11 +01:00 |
InterpreterUndropQuery.h
|
|
|
InterpreterUseQuery.cpp
|
|
|
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Cleanup some known short messages
|
2023-12-26 12:58:50 +01:00 |
InterpreterWatchQuery.h
|
|
|
interpretSubquery.cpp
|
|
|
interpretSubquery.h
|
|
|
InterserverCredentials.cpp
|
|
|
InterserverCredentials.h
|
|
|
InterserverIOHandler.h
|
|
|
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
joinDispatch.h
|
|
|
JoinedTables.cpp
|
Fix direct join with range dictionary in
|
2023-11-28 11:01:38 +00:00 |
JoinedTables.h
|
|
|
JoinSwitcher.cpp
|
|
|
JoinSwitcher.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
JoinToSubqueryTransformVisitor.cpp
|
|
|
JoinToSubqueryTransformVisitor.h
|
|
|
JoinUtils.cpp
|
fix
|
2023-12-15 10:58:33 +00:00 |
JoinUtils.h
|
Fix MergeJoin lowcard keys support
|
2023-12-13 17:43:15 +00:00 |
Lemmatizers.cpp
|
|
|
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
Move Allocator code into module part
|
2023-12-27 15:42:08 +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
|
lowcard in join output
|
2023-12-14 15:28:19 +00:00 |
MergeJoin.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
MergeTreeTransaction.cpp
|
|
|
MergeTreeTransaction.h
|
|
|
MergeTreeTransactionHolder.cpp
|
|
|
MergeTreeTransactionHolder.h
|
|
|
MetricLog.cpp
|
|
|
MetricLog.h
|
|
|
misc.h
|
|
|
MonotonicityCheckVisitor.h
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
MutationsInterpreter.cpp
|
add docs
|
2023-12-13 17:29:34 +00:00 |
MutationsInterpreter.h
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
MutationsNonDeterministicHelpers.cpp
|
|
|
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
|
|
|
OpenTelemetrySpanLog.h
|
|
|
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
|
|
|
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h
|
|
|
OptimizeIfChains.cpp
|
|
|
OptimizeIfChains.h
|
|
|
OptimizeIfWithConstantConditionVisitor.cpp
|
|
|
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
|
|
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
parseColumnsListForTableFunction.cpp
|
Fix
|
2023-11-03 16:46:55 +01:00 |
parseColumnsListForTableFunction.h
|
|
|
PartLog.cpp
|
Add bytes_uncompressed to system.part_log
|
2023-12-22 18:35:33 +01:00 |
PartLog.h
|
|
|
PasteJoin.h
|
fixed suggestions
|
2023-12-19 19:00:37 +00: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
|
Cleanup & comments
|
2023-12-23 11:44:02 +00:00 |
PreparedSets.h
|
Fix typo
|
2023-12-23 12:05:02 +00:00 |
processColumnTransformers.cpp
|
|
|
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Optimize query uniqueness check in ProcessList - move after cancelled_cv.wait
|
2023-11-23 00:21:56 +01:00 |
ProcessList.h
|
Optimize query uniqueness check in ProcessList
|
2023-11-22 15:26:44 +01:00 |
ProcessorsProfileLog.cpp
|
|
|
ProcessorsProfileLog.h
|
|
|
ProfileEventsExt.cpp
|
|
|
ProfileEventsExt.h
|
|
|
QueryAliasesVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
QueryAliasesVisitor.h
|
|
|
QueryLog.cpp
|
|
|
QueryLog.h
|
|
|
QueryNormalizer.cpp
|
|
|
QueryNormalizer.h
|
|
|
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
|
|
QueryThreadLog.h
|
|
|
QueryViewsLog.cpp
|
|
|
QueryViewsLog.h
|
|
|
RedundantFunctionsInOrderByVisitor.h
|
|
|
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
|
|
removeOnClusterClauseIfNeeded.cpp
|
Merge pull request #57752 from chizhonkova/refactor_sql_udf_loader
|
2023-12-18 16:08:46 -05:00 |
removeOnClusterClauseIfNeeded.h
|
|
|
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
replaceForPositionalArguments.cpp
|
Revert "Merge pull request #57741 from ucasfl/negtive-position"
|
2023-12-13 13:09:36 +01:00 |
replaceForPositionalArguments.h
|
|
|
replaceMissedSubcolumnsInQuery.cpp
|
|
|
replaceMissedSubcolumnsInQuery.h
|
|
|
ReplaceQueryParameterVisitor.cpp
|
|
|
ReplaceQueryParameterVisitor.h
|
|
|
RequiredSourceColumnsData.cpp
|
|
|
RequiredSourceColumnsData.h
|
|
|
RequiredSourceColumnsVisitor.cpp
|
Literal aliases incorrectly classified as 'complex_aliases'.
|
2023-12-18 21:43:07 +08:00 |
RequiredSourceColumnsVisitor.h
|
|
|
RewriteArrayExistsFunctionVisitor.cpp
|
|
|
RewriteArrayExistsFunctionVisitor.h
|
|
|
RewriteCountDistinctVisitor.cpp
|
|
|
RewriteCountDistinctVisitor.h
|
|
|
RewriteCountVariantsVisitor.cpp
|
|
|
RewriteCountVariantsVisitor.h
|
|
|
RewriteFunctionToSubcolumnVisitor.cpp
|
|
|
RewriteFunctionToSubcolumnVisitor.h
|
|
|
RewriteOrderByVisitor.cpp
|
|
|
RewriteOrderByVisitor.hpp
|
|
|
RewriteSumIfFunctionVisitor.cpp
|
|
|
RewriteSumIfFunctionVisitor.h
|
|
|
RewriteUniqToCountVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
RewriteUniqToCountVisitor.h
|
|
|
RowRefs.cpp
|
|
|
RowRefs.h
|
|
|
S3QueueLog.cpp
|
|
|
S3QueueLog.h
|
|
|
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
|
|
ServerAsynchronousMetrics.cpp
|
add a clarification to docs
|
2023-12-19 08:35:14 -08:00 |
ServerAsynchronousMetrics.h
|
Fix data race on vptr (ctor/dtor vs virtual call) in AsynchronousMetrics
|
2023-12-10 18:32:40 +01:00 |
Session.cpp
|
Revert "Use CH Buffer for HTTP out stream, add metrics for interfaces"
|
2024-01-03 10:42:15 +01:00 |
Session.h
|
Revert "Use CH Buffer for HTTP out stream, add metrics for interfaces"
|
2024-01-03 10:42:15 +01:00 |
SessionLog.cpp
|
|
|
SessionLog.h
|
|
|
SessionTracker.cpp
|
|
|
SessionTracker.h
|
|
|
Set.cpp
|
|
|
Set.h
|
Add index to table system.numbers (#50909)
|
2023-12-01 19:59:25 +01:00 |
SetKeys.h
|
|
|
SetVariants.cpp
|
|
|
SetVariants.h
|
|
|
sortBlock.cpp
|
More iota
|
2023-12-29 17:20:18 +01:00 |
sortBlock.h
|
|
|
SortedBlocksWriter.cpp
|
|
|
SortedBlocksWriter.h
|
|
|
SquashingTransform.cpp
|
|
|
SquashingTransform.h
|
|
|
StorageID.cpp
|
|
|
StorageID.h
|
|
|
SubstituteColumnOptimizer.cpp
|
|
|
SubstituteColumnOptimizer.h
|
|
|
SynonymsExtensions.cpp
|
|
|
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
Implement system table blob_storage_log
|
2023-11-21 09:18:25 +00:00 |
SystemLog.h
|
Implement system table blob_storage_log
|
2023-11-21 09:18:25 +00:00 |
TableJoin.cpp
|
fix
|
2023-12-15 10:58:33 +00:00 |
TableJoin.h
|
lowcard in join output
|
2023-12-14 15:28:19 +00:00 |
TableOverrideUtils.cpp
|
|
|
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
|
|
TablesStatus.h
|
|
|
TemporaryDataOnDisk.cpp
|
fix race in operations with external temporary data in cache
|
2023-12-18 20:02:53 +00:00 |
TemporaryDataOnDisk.h
|
MergeTask uses temporary data storage
|
2023-11-29 16:18:32 +00:00 |
TextLog.cpp
|
|
|
TextLog.h
|
|
|
threadPoolCallbackRunner.h
|
Add metrics for the number of queued jobs, which is useful for the IO thread pool
|
2023-11-18 19:07:59 +01:00 |
ThreadStatusExt.cpp
|
Merge remote-tracking branch 'blessed/master' into log_message_string
|
2023-12-18 10:40:18 +01:00 |
TraceCollector.cpp
|
|
|
TraceCollector.h
|
|
|
TraceLog.cpp
|
|
|
TraceLog.h
|
|
|
TransactionLog.cpp
|
|
|
TransactionLog.h
|
|
|
TransactionsInfoLog.cpp
|
|
|
TransactionsInfoLog.h
|
|
|
TransactionVersionMetadata.cpp
|
|
|
TransactionVersionMetadata.h
|
|
|
TranslateQualifiedNamesVisitor.cpp
|
|
|
TranslateQualifiedNamesVisitor.h
|
|
|
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
|
Remove optimize_move_functions_out_of_any optimization
|
2023-11-24 12:20:46 +01:00 |
TreeOptimizer.h
|
|
|
TreeRewriter.cpp
|
Some fixups
|
2023-12-17 09:11:16 +00:00 |
TreeRewriter.h
|
|
|
WhereConstraintsOptimizer.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
|
|
WindowDescription.h
|
|
|
ZooKeeperLog.cpp
|
Merge pull request #57479 from mkmkme/mkmkme/zookeeper-read-only
|
2023-12-07 20:22:00 +01:00 |
ZooKeeperLog.h
|
|
|