.. |
Access
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
Cache
|
Merge branch 'master' into fs-cache-improvement
|
2023-11-21 11:24:52 +01:00 |
ClusterProxy
|
Revert "Revert "Add a setting max_execution_time_leaf to limit the execution time on shard for distributed query""
|
2023-11-14 11:40:48 +00:00 |
examples
|
Use pcg/randomSeed() random generator/seed instead of std::mt19937/std::random_device
|
2023-11-07 18:54:50 +00:00 |
fuzzers
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
JIT
|
Aggregator merge and destroy states in batch
|
2023-08-24 15:34:32 +03:00 |
MySQL
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
tests
|
Fix unit test
|
2023-11-22 08:33:41 +01:00 |
ActionLocksManager.cpp
|
add a test for no such key
|
2023-09-20 22:37:24 +02:00 |
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Remove C++ templates
|
2023-11-10 05:25:02 +01:00 |
ActionsDAG.h
|
Merge pull request #56254 from ClickHouse/aggregate-by-partition-analyzer
|
2023-11-09 12:49:25 +01:00 |
ActionsVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
ActionsVisitor.h
|
Merge branch 'master' into refactor-subqueries-for-in
|
2023-05-05 20:39:09 +02:00 |
AddDefaultDatabaseVisitor.h
|
|
|
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
|
|
|
addTypeConversionToAST.h
|
|
|
AggregateDescription.cpp
|
|
|
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
hashtable order fix for s390x
|
2023-09-07 07:37:43 -07:00 |
AggregationUtils.cpp
|
|
|
AggregationUtils.h
|
|
|
Aggregator.cpp
|
Fix error
|
2023-11-22 12:13:47 +01:00 |
Aggregator.h
|
Revert partial result
|
2023-10-21 03:14:22 +02:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
|
|
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
|
|
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
|
|
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
fix logic + better test
|
2023-02-22 13:30:57 +08:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
ArrayJoinAction.cpp
|
Respect max_block_size for array join to avoid possible OOM
|
2023-09-18 11:04:38 +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
|
|
|
AsynchronousInsertLog.cpp
|
Support asynchronous inserts for native protocol (#54730)
|
2023-10-20 18:39:48 +02:00 |
AsynchronousInsertLog.h
|
Support asynchronous inserts for native protocol (#54730)
|
2023-10-20 18:39:48 +02:00 |
AsynchronousInsertQueue.cpp
|
Add metrics for the number of queued jobs, which is useful for the IO thread pool
|
2023-11-18 19:07:59 +01:00 |
AsynchronousInsertQueue.h
|
Support asynchronous inserts for native protocol (#54730)
|
2023-10-20 18:39:48 +02:00 |
AsynchronousMetricLog.cpp
|
|
|
AsynchronousMetricLog.h
|
Remove the duplicate pair of parentheses
|
2023-05-28 12:59:34 +08:00 |
BackupLog.cpp
|
Replace event_time with event_time_microseconds
|
2023-08-17 16:42:22 +03:00 |
BackupLog.h
|
Replace event_time with event_time_microseconds
|
2023-08-17 16:42:22 +03:00 |
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
|
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
|
Fix build
|
2023-11-13 10:09:23 +01:00 |
ClientInfo.h
|
Revert "Add function getHttpHeader"
|
2023-10-29 19:50:39 +03:00 |
Cluster.cpp
|
Use pcg/randomSeed() random generator/seed instead of std::mt19937/std::random_device
|
2023-11-07 18:54:50 +00:00 |
Cluster.h
|
Revert "Merge pull request #54421 from evillique/cluster-groups"
|
2023-10-13 18:55:51 +02:00 |
ClusterDiscovery.cpp
|
fix cluster_discovery_faults
|
2023-09-04 10:54:59 +00:00 |
ClusterDiscovery.h
|
Fix cluster discovery initialization
|
2023-08-31 11:33:01 +00: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
|
|
|
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
|
addJoinedBlock -> addBlockToJoin
|
2023-07-05 17:03:18 +00:00 |
ConcurrentHashJoin.h
|
Get rid of unneeded include
|
2023-08-21 18:01:10 +08:00 |
Context_fwd.h
|
|
|
Context.cpp
|
support parts, tables, databases
|
2023-11-30 10:56:31 +08:00 |
Context.h
|
support parts, tables, databases
|
2023-11-30 10:56:31 +08:00 |
convertFieldToType.cpp
|
fix possible type mismatch with IPv4
|
2023-09-02 14:48:46 -07: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
|
|
|
ConvertStringsToEnumVisitor.cpp
|
Fix some typos
|
2023-10-15 15:43:02 +02:00 |
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
Fix build
|
2023-11-13 10:09:23 +01:00 |
CrashLog.h
|
System logs improvements
|
2023-07-28 07:23:34 +00: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
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
add error code INVALID_IDENTIFIER
|
2023-09-19 22:11:58 +00:00 |
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Add a check for empty metadata path
|
2023-11-22 15:04:54 +00:00 |
DatabaseCatalog.h
|
small refactor
|
2023-11-07 01:27:53 +00:00 |
DDLTask.cpp
|
Fix case with replicated database
|
2023-11-07 16:02:51 +01:00 |
DDLTask.h
|
Fix case with replicated database
|
2023-11-07 16:02:51 +01:00 |
DDLWorker.cpp
|
Add metrics for the number of queued jobs, which is useful for the IO thread pool
|
2023-11-18 19:07:59 +01:00 |
DDLWorker.h
|
caching skip-able entries in DDLWorker
|
2023-09-20 10:57:12 +00:00 |
DirectJoin.cpp
|
addJoinedBlock -> addBlockToJoin
|
2023-07-05 17:03:18 +00:00 |
DirectJoin.h
|
EXPLAIN actions for JOIN step
|
2023-08-03 18:55:15 +03:00 |
DNSCacheUpdater.cpp
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
DNSCacheUpdater.h
|
|
|
DuplicateOrderByVisitor.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
DuplicateOrderByVisitor.h
|
|
|
EmbeddedDictionaries.cpp
|
|
|
EmbeddedDictionaries.h
|
|
|
evaluateConstantExpression.cpp
|
Remove commented code.
|
2023-10-03 14:22:20 +00:00 |
evaluateConstantExpression.h
|
Merge branch 'master' into planner-prepare-filters-for-analysis-2
|
2023-09-11 16:14:03 +02:00 |
executeDDLQueryOnCluster.cpp
|
Revert "Merge pull request #54421 from evillique/cluster-groups"
|
2023-10-13 18:55:51 +02:00 |
executeDDLQueryOnCluster.h
|
Do not replicate ALTER TABLE t FREEZE on Replicated engine (#52064)
|
2023-08-02 14:39:54 +03:00 |
executeQuery.cpp
|
Merge pull request #56004 from ClickHouse/Fix_parameterized_view_explain_ast
|
2023-11-21 16:02:28 +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
|
Remove isReady from FutureSet iface.
|
2023-06-19 12:56:24 +00:00 |
ExpressionActions.h
|
ReadFromMergeTree explain prewhere and row policy actions
|
2023-03-14 18:02:56 +01:00 |
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Fix possible incorrect result with SimpleAggregateFunction in PREWHERE and FINAL
|
2023-09-23 20:55:06 +02:00 |
ExpressionAnalyzer.h
|
Slightly more changes
|
2023-07-16 03:14:44 +02:00 |
ExpressionJIT.cpp
|
JIT infrastructure refactoring
|
2023-06-20 11:42:22 +03:00 |
ExternalDictionariesLoader.cpp
|
trivial change
|
2023-05-11 13:49:02 +02:00 |
ExternalDictionariesLoader.h
|
address comments
|
2023-05-10 17:42:08 +02:00 |
ExternalLoader.cpp
|
Remove CurrentStatusInfo
|
2023-08-30 20:48:26 +02:00 |
ExternalLoader.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
Apply some CTAD
|
2023-03-02 13:36:47 +00:00 |
ExternalLoaderXMLConfigRepository.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
|
|
FilesystemCacheLog.cpp
|
Revert "Merge pull request #51917 from ClickHouse/revert-system-drop-filesystem-cache-by-key"
|
2023-07-30 13:39:54 +02:00 |
FilesystemCacheLog.h
|
Support clang-18 (Wmissing-field-initializers)
|
2023-08-23 15:53:45 +02:00 |
FilesystemReadPrefetchesLog.cpp
|
Merge branch 'master' into optimize_reading2
|
2023-05-28 18:04:44 +02:00 |
FilesystemReadPrefetchesLog.h
|
Merge branch 'master' into optimize_reading2
|
2023-05-28 18:04:44 +02: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
|
EXPLAIN actions for JOIN step
|
2023-08-03 18:55:15 +03:00 |
FunctionMaskingArgumentCheckVisitor.h
|
|
|
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
Remove dependencies
|
2023-11-11 06:59:20 +01:00 |
GatherFunctionQuantileVisitor.h
|
|
|
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
|
|
|
getClusterName.h
|
|
|
getColumnFromBlock.cpp
|
fix getting subcolumn from in-memory data
|
2023-04-11 14:26:31 +00:00 |
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
|
fix
|
2023-10-12 10:46:58 +00: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
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
GraceHashJoin.cpp
|
Ditch tons of garbage
|
2023-08-09 02:19:02 +02:00 |
GraceHashJoin.h
|
EXPLAIN actions for JOIN step
|
2023-08-03 18:55:15 +03:00 |
GroupByFunctionKeysVisitor.h
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
GroupingSetsRewriterVisitor.cpp
|
|
|
GroupingSetsRewriterVisitor.h
|
|
|
HashJoin.cpp
|
Handle case when clone resized block comsumes more memory, try to fix it for ColumnVector
|
2023-09-15 10:30:06 +00:00 |
HashJoin.h
|
hash join use memory tracker delta to decide on shrink to fit
|
2023-09-15 09:03:08 +00:00 |
IdentifierSemantic.cpp
|
|
|
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
|
Fix crash in EXPLAIN PIPELINE for Merge over Distributed
|
2023-04-02 10:48:23 +02:00 |
IInterpreterUnionOrSelectQuery.h
|
Fix crash in EXPLAIN PIPELINE for Merge over Distributed
|
2023-04-02 10:48:23 +02:00 |
IJoin.h
|
EXPLAIN actions for JOIN step
|
2023-08-03 18:55:15 +03:00 |
IKeyValueEntity.h
|
|
|
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
Merge remote-tracking branch 'rschu1ze/master' into clang-17
|
2023-09-21 14:45:55 +00:00 |
inplaceBlockConversions.h
|
Added a new column _block_number (#47532)
|
2023-09-20 11:31:12 +02:00 |
InternalTextLogsQueue.cpp
|
|
|
InternalTextLogsQueue.h
|
Remove broken lockless variant of re2
|
2023-09-14 16:40:42 +00:00 |
InterpreterAlterNamedCollectionQuery.cpp
|
|
|
InterpreterAlterNamedCollectionQuery.h
|
|
|
InterpreterAlterQuery.cpp
|
Merge pull request #56331 from ucasfl/alter
|
2023-11-18 17:23:11 +01:00 |
InterpreterAlterQuery.h
|
|
|
InterpreterBackupQuery.cpp
|
Move BackupsWorker::Info to a separate file BackupOperationInfo.h
|
2023-08-10 13:29:20 +03:00 |
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
upd
|
2023-10-30 11:51:31 +00:00 |
InterpreterCheckQuery.h
|
wip CHECK query for all tables
|
2023-10-27 15:22:10 +00:00 |
InterpreterCreateFunctionQuery.cpp
|
Add settings and processing code
|
2023-08-03 12:44:44 +03:00 |
InterpreterCreateFunctionQuery.h
|
|
|
InterpreterCreateIndexQuery.cpp
|
style
|
2023-07-19 15:03:48 +00:00 |
InterpreterCreateIndexQuery.h
|
|
|
InterpreterCreateNamedCollectionQuery.cpp
|
Fix named collections related statements #51609
|
2023-07-27 09:41:47 +03:00 |
InterpreterCreateNamedCollectionQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
Merge pull request #56000 from evillique/fix-replica-already-exists-storage
|
2023-11-16 12:51:50 +01:00 |
InterpreterCreateQuery.h
|
Fix
|
2023-11-03 16:46:55 +01:00 |
InterpreterDeleteQuery.cpp
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
InterpreterDeleteQuery.h
|
|
|
InterpreterDescribeCacheQuery.cpp
|
Add load_metadata_threads to describe filesystem cache
|
2023-10-23 09:01:12 +02:00 |
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
allow to include virtual columns into DESCRIBE query
|
2023-09-29 11:08:46 +00:00 |
InterpreterDescribeQuery.h
|
allow to include virtual columns into DESCRIBE query
|
2023-09-29 11:08:46 +00:00 |
InterpreterDropFunctionQuery.cpp
|
Add settings and processing code
|
2023-08-03 12:44:44 +03:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
|
|
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
Fix named collections related statements #51609
|
2023-07-27 09:41:47 +03:00 |
InterpreterDropNamedCollectionQuery.h
|
|
|
InterpreterDropQuery.cpp
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
InterpreterDropQuery.h
|
the worst fix for a deadlock ever
|
2023-08-17 00:42:51 +02:00 |
InterpreterExistsQuery.cpp
|
|
|
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
Update InterpreterExplainQuery.cpp
|
2023-11-10 12:34:25 +01:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
|
|
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
Split source and worker processors in InterpreterCheckQuery
|
2023-10-27 15:22:10 +00:00 |
InterpreterFactory.h
|
|
|
InterpreterInsertQuery.cpp
|
Rename directory monitor concept into background INSERT (#55978)
|
2023-11-01 15:09:39 +01:00 |
InterpreterInsertQuery.h
|
Fix using structure from insertion tables in case of defaults and explicit insert columns
|
2023-09-14 19:31:12 +00:00 |
InterpreterKillQueryQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
Support OPTIMIZE for temporary tables (#50710)
|
2023-06-09 14:31:49 +03:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
Check for punctuation
|
2023-07-25 06:10:04 +02: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
|
|
|
InterpreterSelectIntersectExceptQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
Merge pull request #55836 from azat/dist/limit-by-fix
|
2023-11-26 04:03:41 +01:00 |
InterpreterSelectQuery.h
|
Remove the old code for projection analysis (#55112)
|
2023-10-10 17:13:32 +02: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
|
Merge pull request #47725 from ClickHouse/46741_Parameterized_view_support_subquery
|
2023-03-22 09:05:26 +01:00 |
InterpreterSelectWithUnionQuery.h
|
|
|
InterpreterSetQuery.cpp
|
Implemented max sessions for user
|
2023-07-30 22:09:03 +00:00 |
InterpreterSetQuery.h
|
Ignore setting constraints for projection ASTs
|
2023-07-12 10:34:36 +08:00 |
InterpreterShowColumnsQuery.cpp
|
Merge pull request #56306 from ClickHouse/fix-backup-restore-flatten-nested
|
2023-11-10 11:43:17 +01:00 |
InterpreterShowColumnsQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterShowCreateQuery.cpp
|
setting and some docs
|
2023-02-27 13:18:21 +00:00 |
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
|
Add SHOW FUNCTIONS support to client
|
2023-09-07 14:08:50 -07:00 |
InterpreterShowIndexesQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowIndexesQuery.h
|
Initial version of SHOW INDEXES
|
2023-04-25 20:48:11 +00:00 |
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
|
Add SHOW SETTING query
|
2023-10-25 18:49:00 +03:00 |
InterpreterShowTablesQuery.cpp
|
Review fix
|
2023-11-09 16:03:51 +01:00 |
InterpreterShowTablesQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterSystemQuery.cpp
|
Implement system table blob_storage_log
|
2023-11-21 09:18:25 +00:00 |
InterpreterSystemQuery.h
|
better synchronisation of RESTART REPLICA
|
2023-09-01 16:27:21 +02:00 |
InterpreterTransactionControlQuery.cpp
|
|
|
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUndropQuery.cpp
|
monor improvements
|
2023-03-28 23:47:45 +02:00 |
InterpreterUndropQuery.h
|
support undrop table
|
2023-03-27 22:16:36 +08:00 |
InterpreterUseQuery.cpp
|
more parallel tests
|
2023-08-15 23:04:04 +02:00 |
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01: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
|
|
|
InterserverCredentials.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
InterserverIOHandler.h
|
|
|
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
joinDispatch.h
|
|
|
JoinedTables.cpp
|
disable direct join for range dictionary
|
2023-07-17 08:16:58 +00: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
|
EXPLAIN actions for JOIN step
|
2023-08-03 18:55:15 +03:00 |
JoinToSubqueryTransformVisitor.cpp
|
fix name clash for multi join rewrit
|
2023-09-21 16:33:52 +08:00 |
JoinToSubqueryTransformVisitor.h
|
|
|
JoinUtils.cpp
|
Fix crash in join on sparse column
|
2023-08-18 14:14:54 +00:00 |
JoinUtils.h
|
|
|
Lemmatizers.cpp
|
|
|
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
Add metrics for the number of queued jobs, which is useful for the IO thread pool
|
2023-11-18 19:07:59 +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
|
Fix Nullptr dereference in partial merge join with joined_subquery_requires_alias = 0
|
2023-11-21 12:15:12 +00:00 |
MergeJoin.h
|
EXPLAIN actions for JOIN step
|
2023-08-03 18:55:15 +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
|
Remove unneeded columns from logs
|
2023-08-20 04:11:39 +02:00 |
MetricLog.h
|
Remove unneeded columns from logs
|
2023-08-20 04:11:39 +02:00 |
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 scalars in all cases
|
2023-10-27 01:41:02 +08:00 |
MutationsInterpreter.h
|
rebuild indexes and projections when UPDATE compact parts with index_granularity_bytes > 0
|
2023-10-02 07:36:57 +00:00 |
MutationsNonDeterministicHelpers.cpp
|
allow to execute constant non-deterministic functions in mutations on initiator
|
2023-08-07 17:16:15 +00: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
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Optimize opentelemetry_span_log
|
2023-05-08 05:15:28 +02:00 |
OpenTelemetrySpanLog.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02: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
|
|
|
OptimizeIfWithConstantConditionVisitor.cpp
|
|
|
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
Fix some skip_unused_shards tests.
|
2023-08-24 11:07:17 +00:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
parseColumnsListForTableFunction.cpp
|
Fix
|
2023-11-03 16:46:55 +01:00 |
parseColumnsListForTableFunction.h
|
Geo types are production ready
|
2023-05-19 12:43:55 +02:00 |
PartLog.cpp
|
Update PartLog.cpp
|
2023-08-16 17:49:28 +00:00 |
PartLog.h
|
add partition format in the partlog
|
2023-08-16 17:49:28 +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
|
Fixed tests
|
2023-09-15 17:04:24 +03:00 |
PreparedSets.h
|
Fixed tests
|
2023-09-15 17:04:24 +03: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
|
System logs improvements
|
2023-07-28 07:23:34 +00:00 |
ProcessorsProfileLog.h
|
System logs improvements
|
2023-07-28 07:23:34 +00:00 |
ProfileEventsExt.cpp
|
Add peak memory usage (prototype)
|
2023-06-28 09:31:44 +00:00 |
ProfileEventsExt.h
|
Add peak memory usage (prototype)
|
2023-06-28 09:31:44 +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
|
Implemented peak_threads_usage
|
2023-09-07 01:32:39 +00:00 |
QueryLog.h
|
Update src/Interpreters/QueryLog.h
|
2023-09-12 10:10:05 +10:00 |
QueryNormalizer.cpp
|
QueryNormalizer only checks stack size
|
2023-10-16 10:33:04 +00:00 |
QueryNormalizer.h
|
|
|
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
Optimize the system.query_log and system.query_thread_log tables by applying LowCardinality when appropriate
|
2023-05-05 01:36:01 +02:00 |
QueryThreadLog.h
|
Use forward declaration of ThreadPool
|
2023-04-07 11:25:35 +02:00 |
QueryViewsLog.cpp
|
|
|
QueryViewsLog.h
|
Switch Block::NameMap to google::dense_hash_map over HashMap
|
2023-05-12 05:52:57 +02:00 |
RedundantFunctionsInOrderByVisitor.h
|
|
|
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
|
|
removeOnClusterClauseIfNeeded.cpp
|
Add settings and processing code
|
2023-08-03 12:44:44 +03:00 |
removeOnClusterClauseIfNeeded.h
|
Add settings and processing code
|
2023-08-03 12:44:44 +03:00 |
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
replaceForPositionalArguments.cpp
|
|
|
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
|
fix
|
2023-08-16 22:35:45 +02:00 |
ReplaceQueryParameterVisitor.h
|
fix
|
2023-08-16 22:35:45 +02:00 |
RequiredSourceColumnsData.cpp
|
|
|
RequiredSourceColumnsData.h
|
|
|
RequiredSourceColumnsVisitor.cpp
|
|
|
RequiredSourceColumnsVisitor.h
|
|
|
RewriteAnyFunctionVisitor.cpp
|
|
|
RewriteAnyFunctionVisitor.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
|
|
|
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
|
Add optimization uniq to count
|
2023-09-13 16:16:11 +08:00 |
RowRefs.cpp
|
Fix ASOF LEFT JOIN performance degradation (#47544)
|
2023-03-18 23:53:00 +01:00 |
RowRefs.h
|
Make the code in Join less disgusting
|
2023-03-19 07:35:56 +01:00 |
S3QueueLog.cpp
|
Update documentation
|
2023-10-13 13:21:50 +02:00 |
S3QueueLog.h
|
Minor changes
|
2023-09-28 16:18:00 +02:00 |
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
Ignore setting constraints for projection ASTs
|
2023-07-12 10:34:36 +08:00 |
ServerAsynchronousMetrics.cpp
|
Deprecate metadata cache, part 2
|
2023-09-03 03:56:11 +02:00 |
ServerAsynchronousMetrics.h
|
Add new metrics to system.asynchronous_metrics
|
2023-02-25 21:13:15 +01:00 |
Session.cpp
|
Revert "Add function getHttpHeader"
|
2023-10-29 19:50:39 +03:00 |
Session.h
|
Revert "Add function getHttpHeader"
|
2023-10-29 19:50:39 +03:00 |
SessionLog.cpp
|
Add external HTTP Basic authenticator (#55199)
|
2023-10-20 19:24:19 +02:00 |
SessionLog.h
|
Fixed inconsistency between login success and logout
|
2023-08-11 03:42:39 +00: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
|
Merge branch 'master' into planner-prepare-filters-for-analysis-2
|
2023-10-30 11:56:30 +01:00 |
Set.h
|
Merge branch 'master' into planner-prepare-filters-for-analysis-2
|
2023-10-30 11:56:30 +01:00 |
SetKeys.h
|
Cleanup.
|
2023-06-22 14:23:04 +00:00 |
SetVariants.cpp
|
|
|
SetVariants.h
|
|
|
sortBlock.cpp
|
Fixed build
|
2023-06-19 13:02:35 +03: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
|
|
|
SquashingTransform.cpp
|
|
|
SquashingTransform.h
|
|
|
StorageID.cpp
|
|
|
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
|
|
|
SynonymsExtensions.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
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
|
hash join use memory tracker delta to decide on shrink to fit
|
2023-09-15 09:03:08 +00:00 |
TableJoin.h
|
hash join use memory tracker delta to decide on shrink to fit
|
2023-09-15 09:03:08 +00:00 |
TableOverrideUtils.cpp
|
|
|
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
|
|
TablesStatus.h
|
|
|
TemporaryDataOnDisk.cpp
|
Optimise memory consumption when external group by generates ton of temporary files (#54798)
|
2023-10-02 13:09:40 +02:00 |
TemporaryDataOnDisk.h
|
Optimise memory consumption when external group by generates ton of temporary files (#54798)
|
2023-10-02 13:09:40 +02:00 |
TextLog.cpp
|
Remove unneeded columns from logs
|
2023-08-20 04:11:39 +02:00 |
TextLog.h
|
Remove unneeded columns from logs
|
2023-08-20 04:11:39 +02:00 |
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
|
cut the build dependency between commin_io and other libraries
|
2023-09-28 00:15:36 +02:00 |
TraceCollector.cpp
|
Merge branch 'master' into revert-44629-revert_flamegraph
|
2023-08-01 17:14:16 +00:00 |
TraceCollector.h
|
close pipe in run() if exception happens
|
2023-05-08 23:00:20 +00:00 |
TraceLog.cpp
|
|
|
TraceLog.h
|
|
|
TransactionLog.cpp
|
add a test for no such key
|
2023-09-20 22:37:24 +02:00 |
TransactionLog.h
|
release shared ptrs after finishing a transaction
|
2023-03-04 22:07:59 +01:00 |
TransactionsInfoLog.cpp
|
System logs improvements
|
2023-07-28 07:23:34 +00:00 |
TransactionsInfoLog.h
|
|
|
TransactionVersionMetadata.cpp
|
|
|
TransactionVersionMetadata.h
|
|
|
TranslateQualifiedNamesVisitor.cpp
|
Create new StorageView with substituted parameters for every SELECT query of a parameterized view
|
2023-07-25 14:04:55 +02: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
|
Start implementing constraint optimizer
|
2023-03-16 09:30:55 +00:00 |
TreeCNFConverter.h
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
TreeOptimizer.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
TreeOptimizer.h
|
fix crash with multiif and constant condition and nullable arguments
|
2023-05-22 23:31:50 +00:00 |
TreeRewriter.cpp
|
"optimise" --> "optimize". Sorry, friends from the UK.
|
2023-11-23 18:41:35 +00:00 |
TreeRewriter.h
|
Add scalars in all cases
|
2023-10-27 01:41:02 +08: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
|
Merge branch 'master' into keeper-operation-create-if-not-exists
|
2023-09-18 10:57:11 +00:00 |
ZooKeeperLog.h
|
|
|