.. |
Access
|
Merge branch 'master' into fix_settings_constraints
|
2022-12-13 20:33:16 +01:00 |
Cache
|
Fix build and unit test
|
2022-12-22 13:08:54 +00:00 |
ClusterProxy
|
Add a separate optimisation to enable memory bound aggregation.
|
2022-11-30 14:31:39 +00:00 |
examples
|
Fix -Wshorten-64-to-32 in examples
|
2022-10-21 13:25:43 +02:00 |
fuzzers
|
Make disks checks only for clickhouse-server
|
2022-11-20 16:28:35 +01:00 |
JIT
|
Refactor FunctionNode
|
2022-12-02 19:15:26 +00:00 |
MySQL
|
Merge branch 'master' into perf_experiment
|
2022-12-13 17:15:07 +01:00 |
tests
|
Fix build and unit test
|
2022-12-22 13:08:54 +00:00 |
ActionLocksManager.cpp
|
Remove specialization global lock/unlock from ActionLocksManager (#39215)
|
2022-07-21 01:29:35 +02:00 |
ActionLocksManager.h
|
Remove specialization global lock/unlock from ActionLocksManager (#39215)
|
2022-07-21 01:29:35 +02:00 |
ActionsDAG.cpp
|
formatting of some exception messages
|
2023-01-17 20:03:56 +01:00 |
ActionsDAG.h
|
Fixed code review issues
|
2023-01-12 12:07:58 +01:00 |
ActionsVisitor.cpp
|
Removed flag from ExpressionAnalyzer and added a check in MutationsInterpreter::addStreamsForLaterStages - 42637 Disallow arrayJoin in mutations
|
2023-01-04 09:56:44 +01:00 |
ActionsVisitor.h
|
Removed flag from ExpressionAnalyzer and added a check in MutationsInterpreter::addStreamsForLaterStages - 42637 Disallow arrayJoin in mutations
|
2023-01-04 09:56:44 +01:00 |
AddDefaultDatabaseVisitor.h
|
Add ability to rewrite only JOIN tables in AddDefaultDatabaseVisitor
|
2022-01-14 11:18:52 +03:00 |
AddIndexConstraintsOptimizer.cpp
|
minor fixes in constraints
|
2021-11-17 18:43:02 +03:00 |
AddIndexConstraintsOptimizer.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
addMissingDefaults.cpp
|
ActionsDAG rename index to outputs
|
2022-08-08 18:01:32 +02:00 |
addMissingDefaults.h
|
Add check for columns sizes match
|
2021-04-23 19:09:09 +00:00 |
addTypeConversionToAST.cpp
|
Introduce CAST for internal usage
|
2021-08-07 09:03:10 +00:00 |
addTypeConversionToAST.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
AggregateDescription.cpp
|
Refactor FunctionNode
|
2022-12-02 19:15:26 +00:00 |
AggregateDescription.h
|
Move updateInputStream to ITransformingStep (#37393)
|
2022-06-27 13:16:52 +02:00 |
AggregateFunctionOfGroupByKeysVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
AggregationCommon.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
AggregationUtils.cpp
|
Refactor FunctionNode
|
2022-12-02 19:15:26 +00:00 |
AggregationUtils.h
|
fix style
|
2022-08-16 18:56:22 +02:00 |
Aggregator.cpp
|
Apply preallocation optimisation more carefully (#44455)
|
2023-01-09 13:30:48 +01:00 |
Aggregator.h
|
Fixes for -Wshorten-64-to-32
|
2022-10-21 13:25:19 +02:00 |
Aliases.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
applyTableOverride.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
applyTableOverride.h
|
Remove the possibility of adding columns with table overrides
|
2021-12-22 08:20:14 +01:00 |
ApplyWithAliasVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ApplyWithAliasVisitor.h
|
Global WITH and WITH propagation.
|
2020-10-08 15:03:34 +08:00 |
ApplyWithGlobalVisitor.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
ApplyWithGlobalVisitor.h
|
Fix
|
2021-11-01 16:33:19 +03:00 |
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
|
Merge pull request #36444 from rschu1ze/clang-tidy-fixes
|
2022-04-21 16:11:27 +02:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ArrayJoinAction.cpp
|
update getArrayJoinDataType/getArrayJoinColumn
|
2022-12-14 13:02:03 +00:00 |
ArrayJoinAction.h
|
update getArrayJoinDataType/getArrayJoinColumn
|
2022-12-14 13:02:03 +00:00 |
ArrayJoinedColumnsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
AsynchronousInsertLog.cpp
|
slightly better
|
2022-10-04 14:19:05 +00:00 |
AsynchronousInsertLog.h
|
slightly better
|
2022-10-04 14:19:05 +00:00 |
AsynchronousInsertQueue.cpp
|
fix test 02015_async_inserts_2
|
2022-12-27 17:01:30 +00:00 |
AsynchronousInsertQueue.h
|
Merge branch 'master' into hanfei/aysnc-insert
|
2022-11-25 17:27:56 +01:00 |
AsynchronousMetricLog.cpp
|
Merge branch 'master' into keeper-prometheus
|
2022-11-15 12:00:02 +00:00 |
AsynchronousMetricLog.h
|
Merge branch 'master' into keeper-prometheus
|
2022-11-15 12:00:02 +00:00 |
BloomFilter.cpp
|
Updated bloom filter index for map type to work with mapKeys function
|
2021-09-22 12:45:48 +03:00 |
BloomFilter.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
BloomFilterHash.h
|
Less use of CH-specific bit_cast()
|
2022-11-04 15:52:48 +00:00 |
CancellationCode.h
|
|
|
castColumn.cpp
|
Only fix LowCardinality for now
|
2022-10-22 15:47:13 +08:00 |
castColumn.h
|
Only fix LowCardinality for now
|
2022-10-22 15:47:13 +08:00 |
ClientInfo.cpp
|
Fix -Wshorten-64-to-32 on FreeBSD
|
2022-12-12 08:05:28 +01:00 |
ClientInfo.h
|
add member function getLastForwardedFor to ClientInfo
|
2022-12-23 18:32:29 +00:00 |
Cluster.cpp
|
Fixes for -Wshorten-64-to-32
|
2022-10-21 13:25:19 +02:00 |
Cluster.h
|
update tcp protocol, add quota_key
|
2022-08-03 15:44:08 -04:00 |
ClusterDiscovery.cpp
|
Do not set treat_local_port_as_remote in ClusterDiscovery
|
2022-11-02 15:34:06 +00:00 |
ClusterDiscovery.h
|
Add observer mode to (zoo)keeper cluster discovery feature
|
2022-08-12 13:26:12 +00:00 |
CMakeLists.txt
|
Done
|
2021-10-04 17:57:58 +00:00 |
CollectJoinOnKeysVisitor.cpp
|
JoinIdentifierPos::Constant -> NotColumn
|
2022-12-15 15:14:03 +00:00 |
CollectJoinOnKeysVisitor.h
|
JoinIdentifierPos::Constant -> NotColumn
|
2022-12-15 15:14:03 +00:00 |
ColumnAliasesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ColumnAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ComparisonGraph.cpp
|
abort instead of __builtin_unreachable in debug builds
|
2022-10-07 21:49:08 +02:00 |
ComparisonGraph.h
|
Replace std::vector with absl inlined_vector
|
2022-10-13 21:50:11 +02:00 |
ConcurrentHashJoin.cpp
|
Merge branch 'master' into grace_hash_join
|
2022-10-26 12:25:50 +00:00 |
ConcurrentHashJoin.h
|
fix delayed blocks for grace hash join
|
2022-10-18 11:43:01 +00:00 |
Context_fwd.h
|
Remove old code
|
2021-07-06 05:31:09 +03:00 |
Context.cpp
|
Moved settings inside backups section - Updated backup/restore status when concurrent backups & restores are not allowed
|
2023-01-23 08:59:44 +01:00 |
Context.h
|
Revert "Revert "Custom reading for mutation""
|
2023-01-10 16:31:01 +01:00 |
convertFieldToType.cpp
|
make only IPv4 as numeric, fix hash functions for IPv6, add more hash functions to test
|
2023-01-10 02:03:06 +00:00 |
convertFieldToType.h
|
|
|
ConvertFunctionOrLikeVisitor.cpp
|
Updated finished_asts to fix fast test fails with Normalise AST is too deep and updated ConvertFunctionOrLikeData to merge conditions by aliasorColumnName instead of ASTPtr - 42452 Bug fix for parent node corrupted
|
2022-11-02 19:35:22 +01:00 |
ConvertFunctionOrLikeVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ConvertStringsToEnumVisitor.cpp
|
Add classes for new pass
|
2022-12-07 11:44:46 +00:00 |
ConvertStringsToEnumVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
CrashLog.cpp
|
Generate config_version.h into ${CONFIG_INCLUDE_PATH}
|
2022-09-28 12:48:26 +00:00 |
CrashLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
createBlockSelector.cpp
|
Update libdivide
|
2022-12-13 10:45:01 +01:00 |
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Replace std::vector with absl inlined_vector
|
2022-10-13 21:50:11 +02:00 |
CrossToInnerJoinVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
DatabaseAndTableWithAlias.cpp
|
Improve Asterisk and ColumnMatcher parser
|
2022-11-02 06:21:02 +00:00 |
DatabaseAndTableWithAlias.h
|
Improve Asterisk and ColumnMatcher parser
|
2022-11-02 06:21:02 +00:00 |
DatabaseCatalog.cpp
|
formatting of some exception messages
|
2023-01-17 20:03:56 +01:00 |
DatabaseCatalog.h
|
Referential dependencies for RESTORE (#43834)
|
2022-12-02 15:05:46 +01:00 |
DDLTask.cpp
|
Addition to prev change
|
2023-01-01 21:46:30 +01:00 |
DDLTask.h
|
Addition to prev change
|
2023-01-01 21:46:30 +01:00 |
DDLWorker.cpp
|
Addition to prev change
|
2023-01-01 21:48:37 +01:00 |
DDLWorker.h
|
Wipe passwords from distributed queries too.
|
2022-10-31 10:50:33 +01:00 |
DirectJoin.cpp
|
Added JOIN support for different algorithm
|
2022-10-24 10:22:21 +02:00 |
DirectJoin.h
|
Merge branch 'master' into grace_hash_join
|
2022-10-26 12:25:50 +00:00 |
DNSCacheUpdater.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
DNSCacheUpdater.h
|
DNS cache: Add option to drop elements after several consecutive failures
|
2022-04-05 13:00:27 +02:00 |
DuplicateOrderByVisitor.cpp
|
Reduce dependencies on ASTLiteral.h
|
2021-11-26 17:54:57 +01:00 |
DuplicateOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
EmbeddedDictionaries.cpp
|
Don't use std::unique_lock unless we have to
|
2022-06-28 19:19:06 +00:00 |
EmbeddedDictionaries.h
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
evaluateConstantExpression.cpp
|
Continue: ContextPtr -> const ContextPtr & in parameters
|
2022-07-06 13:13:19 +00:00 |
evaluateConstantExpression.h
|
Continue: ContextPtr -> const ContextPtr & in parameters
|
2022-07-06 13:13:19 +00:00 |
executeDDLQueryOnCluster.cpp
|
Merge branch 'master' into on_cluster_dll
|
2022-09-22 09:58:10 +08:00 |
executeDDLQueryOnCluster.h
|
ignore cluster if equals to db name
|
2022-07-06 19:54:05 +02:00 |
executeQuery.cpp
|
fix
|
2023-01-18 14:30:20 +01:00 |
executeQuery.h
|
Remove DataStreams folder.
|
2021-10-15 23:18:20 +03:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
Fix some tests.
|
2022-05-27 20:47:35 +00:00 |
ExecuteScalarSubqueriesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ExpressionActions.cpp
|
Analyzer aggregation without column fix
|
2023-01-10 16:49:55 +01:00 |
ExpressionActions.h
|
Analyzer aggregation without column fix
|
2023-01-10 16:49:55 +01:00 |
ExpressionActionsSettings.cpp
|
Fix performance, make only one setting
|
2021-08-16 14:30:56 +03:00 |
ExpressionActionsSettings.h
|
Fix performance, make only one setting
|
2021-08-16 14:30:56 +03:00 |
ExpressionAnalyzer.cpp
|
Merge pull request #41687 from ClickHouse/40907_Parameterized_views_as_table_functions
|
2023-01-12 14:24:32 +01:00 |
ExpressionAnalyzer.h
|
Merge pull request #41687 from ClickHouse/40907_Parameterized_views_as_table_functions
|
2023-01-12 14:24:32 +01:00 |
ExpressionJIT.cpp
|
Fix ClangTidy build
|
2022-12-21 00:22:46 +00:00 |
ExternalDictionariesLoader.cpp
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
ExternalDictionariesLoader.h
|
Fixed tests
|
2021-10-14 22:12:06 +03:00 |
ExternalLoader.cpp
|
Fix incorrect trace log line on dict reload
|
2022-10-24 11:58:37 +02:00 |
ExternalLoader.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ExternalLoaderDatabaseConfigRepository.h
|
Fixed tests
|
2021-04-26 13:52:41 +03:00 |
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
Fixed tests
|
2021-04-26 13:52:41 +03:00 |
ExternalLoaderDictionaryStorageConfigRepository.h
|
Fixed tests
|
2021-04-26 13:52:41 +03:00 |
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
ExternalLoaderXMLConfigRepository.cpp
|
Update ExternalLoaderXMLConfigRepository.cpp
|
2021-10-02 16:26:13 +03:00 |
ExternalLoaderXMLConfigRepository.h
|
Merge branch 'master' into rename-common
|
2021-10-02 17:15:10 +03:00 |
ExtractExpressionInfoVisitor.cpp
|
Reduce dependencies on ASTIdentifier.h
|
2021-11-26 16:49:40 +01:00 |
ExtractExpressionInfoVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
FilesystemCacheLog.cpp
|
abort instead of __builtin_unreachable in debug builds
|
2022-10-07 21:49:08 +02:00 |
FilesystemCacheLog.h
|
Fix
|
2022-08-29 17:50:27 +02:00 |
FillingRow.cpp
|
do not fill 'to' boundary
|
2022-06-14 22:26:50 -04:00 |
FillingRow.h
|
remove last mentions of data streams
|
2022-05-09 19:15:24 +00:00 |
FullSortingMergeJoin.h
|
fix delayed blocks for grace hash join
|
2022-10-18 11:43:01 +00: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
|
Merge remote-tracking branch 'upstream/master' into ncb/weighted-quantile-approx
|
2022-12-13 09:34:26 -08:00 |
GatherFunctionQuantileVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
GetAggregatesVisitor.cpp
|
Allow to use higher-order functions in window expressions
|
2022-07-11 23:47:46 +00:00 |
GetAggregatesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
getClusterName.cpp
|
Implement referential dependencies for table engine "Distributed"
|
2022-12-13 11:09:42 +01:00 |
getClusterName.h
|
Implement referential dependencies for table engine "Distributed"
|
2022-12-13 11:09:42 +01:00 |
getColumnFromBlock.cpp
|
minor fixes
|
2022-03-14 17:29:18 +00:00 |
getColumnFromBlock.h
|
fix unit test
|
2022-02-16 17:18:03 +03:00 |
getHeaderForProcessingStage.cpp
|
Fixed tests
|
2022-10-24 10:22:20 +02:00 |
getHeaderForProcessingStage.h
|
Fix refcnt for unused MergeTree parts in SELECT queries
|
2022-06-08 07:04:53 +03:00 |
getTableExpressions.cpp
|
Containers iteration fix erase
|
2021-12-20 13:42:31 +03:00 |
getTableExpressions.h
|
Minor style changes in JoinedTables
|
2021-07-08 13:49:13 +03:00 |
getTableOverride.cpp
|
Fix
|
2021-12-21 01:19:51 +03:00 |
getTableOverride.h
|
Move to Interpreters
|
2021-12-17 22:19:10 +03:00 |
GinFilter.cpp
|
Addressed more review comments and ClangTidy errors
|
2023-01-17 06:29:13 -08:00 |
GinFilter.h
|
Addressed more review comments and ClangTidy errors
|
2023-01-17 06:29:13 -08:00 |
GlobalSubqueriesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
GraceHashJoin.cpp
|
update
|
2022-12-16 18:33:01 +00:00 |
GraceHashJoin.h
|
Add IJoin::initialize
|
2022-11-29 17:11:00 +00:00 |
GroupByFunctionKeysVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
GroupingSetsRewriterVisitor.cpp
|
Rewrite queries GROUPING SETS (foo, bar) to GROUP BY foo, bar
|
2022-05-27 17:44:51 +03:00 |
GroupingSetsRewriterVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
HashJoin.cpp
|
Fix wrong column nullability in StoreageJoin
|
2023-01-11 16:17:21 +00:00 |
HashJoin.h
|
wip grace hash
|
2022-10-19 10:20:41 +00:00 |
IdentifierSemantic.cpp
|
Replace std::vector with absl inlined_vector
|
2022-10-13 21:50:11 +02:00 |
IdentifierSemantic.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
Update IExternalLoadable interface
|
2022-01-16 00:06:10 +00:00 |
IExternalLoaderConfigRepository.h
|
ExternalLoaderRepository fix arcadia
|
2021-04-28 14:40:35 +03:00 |
IInterpreter.cpp
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
IInterpreter.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
IInterpreterUnionOrSelectQuery.cpp
|
Removed extendQueryLogElemImplImpl .
|
2022-10-27 10:42:25 +03:00 |
IInterpreterUnionOrSelectQuery.h
|
Merge pull request #42829 from ClickHouse/read-in-order-from-query-plan
|
2022-11-11 12:15:20 +01:00 |
IJoin.h
|
Add IJoin::initialize
|
2022-11-29 17:11:00 +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
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
InJoinSubqueriesPreprocessor.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
inplaceBlockConversions.cpp
|
try to fix filling of missed Nested columns with multiple levels
|
2022-09-08 00:20:11 +00:00 |
inplaceBlockConversions.h
|
try to fix filling of missed Nested columns with multiple levels
|
2022-09-06 13:56:32 +00:00 |
InternalTextLogsQueue.cpp
|
Modernize InternalTextLogsQueue::getPriorityName()
|
2023-01-20 11:09:35 +01:00 |
InternalTextLogsQueue.h
|
Modernize InternalTextLogsQueue::getPriorityName()
|
2023-01-20 11:09:35 +01:00 |
InterpreterAlterNamedCollectionQuery.cpp
|
Replace old named collections code for url
|
2022-12-17 00:24:05 +01:00 |
InterpreterAlterNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterAlterQuery.cpp
|
Added force_wait parameter to IStorage::mutate()
|
2022-12-30 16:23:03 +01:00 |
InterpreterAlterQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterBackupQuery.cpp
|
Rename column "uuid" -> "id" in system.backups and allow user to set it in a query.
|
2022-07-27 09:04:10 +02:00 |
InterpreterBackupQuery.h
|
Added new commands BACKUP and RESTORE.
|
2021-08-23 23:41:45 +03:00 |
InterpreterCheckQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterCheckQuery.h
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterpreterCreateFunctionQuery.cpp
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterCreateFunctionQuery.h
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterCreateIndexQuery.cpp
|
make tryEnqueueReplicatedDDL virtual
|
2022-09-16 16:25:32 +02:00 |
InterpreterCreateIndexQuery.h
|
Support sql standard drop index in seprate parser files
|
2022-06-29 11:08:05 +08:00 |
InterpreterCreateNamedCollectionQuery.cpp
|
Replace old named collections code for url
|
2022-12-17 00:24:05 +01:00 |
InterpreterCreateNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterCreateQuery.cpp
|
Merge branch 'master' into ftsearch
|
2023-01-19 11:34:11 -05:00 |
InterpreterCreateQuery.h
|
fix race between DROP and short form of ATTACH
|
2022-09-14 18:03:36 +02:00 |
InterpreterDeleteQuery.cpp
|
Merge branch 'master' into lwd_mutation_always_sync
|
2023-01-05 21:20:14 +01:00 |
InterpreterDeleteQuery.h
|
Support delete from ... where syntax on mergetree tables
|
2022-07-15 12:32:41 +08:00 |
InterpreterDescribeCacheQuery.cpp
|
Rename
|
2022-09-19 14:02:51 +02:00 |
InterpreterDescribeCacheQuery.h
|
Add describe cache command
|
2022-06-21 16:07:39 +02:00 |
InterpreterDescribeQuery.cpp
|
Analyzer support distributed queries processing
|
2023-01-12 12:07:58 +01:00 |
InterpreterDescribeQuery.h
|
Small refactoring.
|
2021-09-15 22:35:48 +03:00 |
InterpreterDropFunctionQuery.cpp
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterDropFunctionQuery.h
|
Fixed integration tests
|
2021-08-23 17:31:58 +03:00 |
InterpreterDropIndexQuery.cpp
|
make tryEnqueueReplicatedDDL virtual
|
2022-09-16 16:25:32 +02:00 |
InterpreterDropIndexQuery.h
|
Support sql standard drop index in seprate parser files
|
2022-06-29 11:08:05 +08:00 |
InterpreterDropNamedCollectionQuery.cpp
|
Replace old named collections code for url
|
2022-12-17 00:24:05 +01:00 |
InterpreterDropNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterDropQuery.cpp
|
less empty patterns
|
2023-01-17 01:19:44 +01:00 |
InterpreterDropQuery.h
|
Delete parts over replacing them with empty parts
|
2022-11-23 15:16:08 +00:00 |
InterpreterExistsQuery.cpp
|
Merge branch 'master' into query_parameters
|
2021-11-11 11:43:00 +00:00 |
InterpreterExistsQuery.h
|
Small refactoring.
|
2021-09-15 22:35:48 +03:00 |
InterpreterExplainQuery.cpp
|
Merge pull request #44641 from ClickHouse/vdimir/view_explain_2
|
2023-01-16 13:39:53 +03:00 |
InterpreterExplainQuery.h
|
add EXPLAIN CURRENT TRANSACTION
|
2022-02-14 22:47:17 +03:00 |
InterpreterExternalDDLQuery.cpp
|
to MaterializeMySQL_support_drop_mulit_table
|
2022-11-18 17:50:44 +08:00 |
InterpreterExternalDDLQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterFactory.cpp
|
Analyzer support distributed queries processing
|
2023-01-12 12:07:58 +01:00 |
InterpreterFactory.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterInsertQuery.cpp
|
Parallel distributed insert select with s3Cluster [3] (#44955)
|
2023-01-09 13:30:32 +01:00 |
InterpreterInsertQuery.h
|
Fix a destruction order for views ThreadStatus
|
2022-09-21 18:37:40 +00:00 |
InterpreterKillQueryQuery.cpp
|
Remove some methods
|
2022-09-10 05:04:40 +02:00 |
InterpreterKillQueryQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterOptimizeQuery.cpp
|
fix
|
2022-10-02 00:44:46 +02:00 |
InterpreterOptimizeQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterRenameQuery.cpp
|
Referential dependencies for RESTORE (#43834)
|
2022-12-02 15:05:46 +01:00 |
InterpreterRenameQuery.h
|
Check grants for databases in case of renaming databases (#40906)
|
2022-09-05 12:38:44 +02:00 |
InterpreterSelectIntersectExceptQuery.cpp
|
Fix build.
|
2022-11-09 13:51:27 +01:00 |
InterpreterSelectIntersectExceptQuery.h
|
Review fixes.
|
2022-10-27 10:42:22 +03:00 |
InterpreterSelectQuery.cpp
|
Merge branch 'master' into fix-disabled-two-level-agg
|
2023-01-19 20:54:04 +00:00 |
InterpreterSelectQuery.h
|
Reworked changes to std::shared_ptr<const RowPolicyFilter> .
|
2022-10-27 10:42:55 +03:00 |
InterpreterSelectQueryAnalyzer.cpp
|
Fixing build
|
2023-01-20 13:49:50 +00:00 |
InterpreterSelectQueryAnalyzer.h
|
Analyzer support distributed queries processing
|
2023-01-12 12:07:58 +01:00 |
InterpreterSelectWithUnionQuery.cpp
|
Merge pull request #41687 from ClickHouse/40907_Parameterized_views_as_table_functions
|
2023-01-12 14:24:32 +01:00 |
InterpreterSelectWithUnionQuery.h
|
Merge branch 'master' into 40907_Parameterized_views_as_table_functions
|
2022-11-11 19:04:35 +01:00 |
InterpreterSetQuery.cpp
|
move default settings to different part of ast
|
2022-10-11 18:25:28 +00:00 |
InterpreterSetQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterShowCreateQuery.cpp
|
Remove unused argument hilite in formatWithSecretHidden().
|
2022-11-17 18:16:33 +01:00 |
InterpreterShowCreateQuery.h
|
Small refactoring.
|
2021-09-15 22:35:48 +03:00 |
InterpreterShowProcesslistQuery.cpp
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterpreterShowProcesslistQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowTablesQuery.cpp
|
Add full option for SHOW query
|
2022-12-03 20:42:18 +00:00 |
InterpreterShowTablesQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterSystemQuery.cpp
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2023-01-05 14:12:02 +00:00 |
InterpreterSystemQuery.h
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2023-01-05 14:12:02 +00:00 |
InterpreterTransactionControlQuery.cpp
|
abort instead of __builtin_unreachable in debug builds
|
2022-10-07 21:49:08 +02:00 |
InterpreterTransactionControlQuery.h
|
Add implicit_transaction setting
|
2022-06-23 15:23:37 +02:00 |
InterpreterUseQuery.cpp
|
Move access-rights' source files needed for parser to a separate target.
|
2021-11-01 19:13:49 +03:00 |
InterpreterUseQuery.h
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterpreterWatchQuery.cpp
|
less empty patterns
|
2023-01-17 01:19:44 +01:00 |
InterpreterWatchQuery.h
|
Forward declaration of IStorage in InterpreterWatchQuery
|
2022-01-10 22:01:41 +03:00 |
interpretSubquery.cpp
|
Merge branch 'master' into ast-table-identifier-2
|
2021-04-12 20:23:28 +03:00 |
interpretSubquery.h
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterserverCredentials.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InterserverCredentials.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InterserverIOHandler.h
|
Mark Context::getInterserverIOHandler() as const
|
2022-05-12 16:54:01 +03:00 |
ITokenExtractor.cpp
|
More conversions
|
2022-07-31 22:06:02 +00:00 |
ITokenExtractor.h
|
Initial Checkin of full text search
|
2022-12-31 18:00:17 -08:00 |
joinDispatch.h
|
Join enums refactoring
|
2022-07-29 18:35:05 +02:00 |
JoinedTables.cpp
|
Better implementation
|
2022-11-30 02:23:26 +00:00 |
JoinedTables.h
|
Improve using structure from insertion table in table functions
|
2022-10-14 15:09:35 +00:00 |
JoinSwitcher.cpp
|
JoinSwitcher don't use grace hash join
|
2022-10-26 16:09:11 +00:00 |
JoinSwitcher.h
|
JoinSwitcher don't use grace hash join
|
2022-10-26 16:09:11 +00:00 |
JoinToSubqueryTransformVisitor.cpp
|
Fix build
|
2023-01-15 13:46:55 +00:00 |
JoinToSubqueryTransformVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
JoinUtils.cpp
|
Fix logical error in right storage join witn using
|
2022-12-06 11:46:54 +00:00 |
JoinUtils.h
|
Fix logical error in right storage join witn using
|
2022-12-06 11:46:54 +00:00 |
Lemmatizers.cpp
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
Lemmatizers.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
loadMetadata.cpp
|
Fix amusing error in conversion from Ordinary to Atomic
|
2022-09-21 07:10:33 +02:00 |
loadMetadata.h
|
Referential dependencies for RESTORE (#43834)
|
2022-12-02 15:05:46 +01:00 |
LogicalExpressionsOptimizer.cpp
|
Merge branch 'master' into logical-optimizer-lowcardinality
|
2023-01-12 18:51:05 +01:00 |
LogicalExpressionsOptimizer.h
|
LogicalExpressionsOptimizer: optimze for LowCardinality
|
2022-11-02 16:56:58 +08:00 |
MarkTableIdentifiersVisitor.cpp
|
Reduce dependencies on ASTIdentifier.h
|
2021-11-26 16:49:40 +01:00 |
MarkTableIdentifiersVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
MergeJoin.cpp
|
Fix logical error in right storage join witn using
|
2022-12-06 11:46:54 +00:00 |
MergeJoin.h
|
fix delayed blocks for grace hash join
|
2022-10-18 11:43:01 +00:00 |
MergeTreeTransaction.cpp
|
add query for waiting of loading parts and fix test_transactions
|
2022-12-12 14:33:42 +00:00 |
MergeTreeTransaction.h
|
disable transactions with Ordinary database
|
2022-07-15 15:36:01 +02:00 |
MergeTreeTransactionHolder.cpp
|
better waiting, add fault injection
|
2022-05-20 22:10:01 +02:00 |
MergeTreeTransactionHolder.h
|
more comments, minor fixes
|
2022-03-18 12:01:26 +01:00 |
MetricLog.cpp
|
add system table asynchronous_inserts_log
|
2022-10-03 21:35:55 +00:00 |
MetricLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
misc.h
|
Refactor joinGet and implement multi-key lookup.
|
2020-07-28 22:38:52 +08:00 |
MonotonicityCheckVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
MutationsInterpreter.cpp
|
Update MutationsInterpreter.cpp
|
2023-01-10 18:19:38 +01:00 |
MutationsInterpreter.h
|
Revert "Revert "Custom reading for mutation""
|
2023-01-10 16:31:01 +01:00 |
NormalizeSelectWithUnionQueryVisitor.cpp
|
Fix normalization of UNION inside DESCRIBE query
|
2022-10-24 10:22:37 +02:00 |
NormalizeSelectWithUnionQueryVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
NullableUtils.cpp
|
Minor changes related to JOIN ON ORs
|
2021-09-28 14:11:31 +03:00 |
NullableUtils.h
|
fix transform_null_in with sets of tuples
|
2020-11-05 21:07:44 +03:00 |
OpenTelemetrySpanLog.cpp
|
Fix code
|
2022-07-07 17:44:19 +08:00 |
OpenTelemetrySpanLog.h
|
Remove using namespace from header
|
2022-08-25 20:20:13 +08:00 |
OptimizeIfChains.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
OptimizeIfChains.h
|
replace multiIf to if in case of one condition
|
2022-05-31 14:45:12 +00:00 |
OptimizeIfWithConstantConditionVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
OptimizeIfWithConstantConditionVisitor.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
OptimizeShardingKeyRewriteInVisitor.cpp
|
Fix implicit cast for optimize_skip_unused_shards_rewrite_in
|
2022-05-12 16:17:30 +03:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
parseColumnsListForTableFunction.cpp
|
Better
|
2022-12-21 21:23:12 +00:00 |
parseColumnsListForTableFunction.h
|
Don't check internal CAST
|
2022-12-21 23:47:56 +00:00 |
PartLog.cpp
|
Add table_uuid to system.parts (resubmit)
|
2022-11-26 20:16:38 +01:00 |
PartLog.h
|
Add table_uuid to system.parts (resubmit)
|
2022-11-26 20:16:38 +01:00 |
PredicateExpressionsOptimizer.cpp
|
Fix exponential query rewrite in case of lots of cross joins with where
|
2022-09-12 15:05:34 +00:00 |
PredicateExpressionsOptimizer.h
|
Reduce dependencies on ASTSelectQuery.h
|
2021-11-26 18:35:24 +01:00 |
PredicateRewriteVisitor.cpp
|
Merge branch 'master' into another_fix_for_an_ast_optimization
|
2022-09-21 19:05:08 +03:00 |
PredicateRewriteVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
PreparedSets.cpp
|
upd PreparedSets: rename/change signature of methods, add comments
|
2022-07-27 11:22:16 +00:00 |
PreparedSets.h
|
Fixed tests
|
2022-10-24 10:22:20 +02:00 |
processColumnTransformers.cpp
|
revert unnecesarry change
|
2022-02-08 00:14:15 +00:00 |
processColumnTransformers.h
|
OPTIMIZE DEDUPLICATE BY columns
|
2020-12-07 09:44:07 +03:00 |
ProcessList.cpp
|
formatting of some exception messages
|
2023-01-17 20:03:56 +01:00 |
ProcessList.h
|
Unify query elapsed time measurements (#43455)
|
2022-12-28 21:01:41 +01:00 |
ProcessorsProfileLog.cpp
|
processor profile
|
2022-08-11 21:03:34 +08:00 |
ProcessorsProfileLog.h
|
processor profile
|
2022-08-11 21:03:34 +08:00 |
ProfileEventsExt.cpp
|
fix build with clang-15
|
2022-08-01 18:00:54 +02:00 |
ProfileEventsExt.h
|
finish dev
|
2022-03-01 15:54:23 +08:00 |
QueryAliasesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
QueryAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
QueryLog.cpp
|
Removed UUID's.
|
2022-10-27 10:42:26 +03:00 |
QueryLog.h
|
make error patterns more useful
|
2023-01-17 20:04:25 +01:00 |
QueryNormalizer.cpp
|
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 |
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
|
Less include <Common/Stopwatch.h>
|
2021-08-11 16:20:59 +02:00 |
QueryThreadLog.cpp
|
Fix writting is_secure
|
2022-03-30 06:39:40 +00:00 |
QueryThreadLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
QueryViewsLog.cpp
|
Fix query_views_log with Window views
|
2022-09-09 13:46:53 +02:00 |
QueryViewsLog.h
|
Fix a destruction order for views ThreadStatus
|
2022-09-21 18:37:40 +00:00 |
RedundantFunctionsInOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RemoveInjectiveFunctionsVisitor.cpp
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
RemoveInjectiveFunctionsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RenameColumnVisitor.cpp
|
Reduce dependencies on ASTIdentifier.h
|
2021-11-26 16:49:40 +01:00 |
RenameColumnVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
replaceAliasColumnsInQuery.cpp
|
Skip JOIN OR/USING sections in replaceAliasColumnsInQuery
|
2021-09-14 14:13:19 +03:00 |
replaceAliasColumnsInQuery.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
replaceForPositionalArguments.cpp
|
typo
|
2023-01-04 12:45:39 +01:00 |
replaceForPositionalArguments.h
|
Fix
|
2022-07-30 18:42:22 +03:00 |
ReplaceQueryParameterVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ReplaceQueryParameterVisitor.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
RequiredSourceColumnsData.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
RequiredSourceColumnsData.h
|
Fixing a test with indexHint
|
2022-07-28 12:24:16 +00:00 |
RequiredSourceColumnsVisitor.cpp
|
Fix unused columns introduced by with stmt
|
2022-08-24 00:40:01 +08:00 |
RequiredSourceColumnsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteAnyFunctionVisitor.cpp
|
Small refactoring
|
2022-06-16 15:41:04 +00:00 |
RewriteAnyFunctionVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01: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
|
Remove some methods
|
2022-09-10 05:04:40 +02: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 |
RewriteSumIfFunctionVisitor.cpp
|
Fix sumIf rewrite
|
2022-01-16 06:25:11 +00:00 |
RewriteSumIfFunctionVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RowRefs.cpp
|
Fixes for -Wshorten-64-to-32
|
2022-10-21 13:25:19 +02:00 |
RowRefs.h
|
Review fixes
|
2022-10-21 22:40:13 +02:00 |
SelectIntersectExceptQueryVisitor.cpp
|
implement intersect + except distinct
|
2022-08-30 18:09:01 +08:00 |
SelectIntersectExceptQueryVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
SelectQueryOptions.h
|
Moved is_create_parameterized_view out of Context , and added into ActionsMatcher::Data and SelectQueryInfo - 40907 Parameterized views as table functions
|
2022-10-21 14:45:28 +02:00 |
ServerAsynchronousMetrics.cpp
|
Minor code polishing
|
2022-12-22 14:31:42 +01:00 |
ServerAsynchronousMetrics.h
|
Bring back heavy metrics
|
2022-11-10 12:56:27 +01:00 |
Session.cpp
|
work with the latest remarks
|
2022-11-23 15:16:09 +00:00 |
Session.h
|
pass session certificate for showCertificate()
|
2022-09-18 07:11:52 +00:00 |
SessionLog.cpp
|
Add SSL_CERTIFICATE auth method to all places missing
|
2022-10-28 21:17:59 +02:00 |
SessionLog.h
|
review suggestions
|
2022-05-23 21:55:17 +02:00 |
Set.cpp
|
Fix create set with wrong header when data type is lowcardinality
|
2022-10-22 16:17:05 +00:00 |
Set.h
|
Cleanup code
|
2022-12-02 19:15:26 +00:00 |
SetVariants.cpp
|
abort instead of __builtin_unreachable in debug builds
|
2022-10-07 21:49:08 +02:00 |
SetVariants.h
|
Normalize BigInt implementation
|
2021-01-27 03:54:57 +03:00 |
sortBlock.cpp
|
Make SortDescription::column_name always non-empty (#35805)
|
2022-04-04 14:17:15 +02:00 |
sortBlock.h
|
Sort block refactoring
|
2022-01-29 15:50:55 +00:00 |
SortedBlocksWriter.cpp
|
Followup for TemporaryDataOnDisk
|
2022-10-12 15:25:23 +02:00 |
SortedBlocksWriter.h
|
Upd TemporaryFileOnDisk
|
2022-08-24 16:15:54 +00:00 |
SquashingTransform.cpp
|
Remove memory reservation for SquashingTransform
|
2022-04-29 17:04:56 +03:00 |
SquashingTransform.h
|
Remove memory reservation for SquashingTransform
|
2022-04-29 17:04:56 +03:00 |
StorageID.cpp
|
Referential dependencies for RESTORE (#43834)
|
2022-12-02 15:05:46 +01:00 |
StorageID.h
|
Referential dependencies for RESTORE (#43834)
|
2022-12-02 15:05:46 +01:00 |
SubstituteColumnOptimizer.cpp
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
SubstituteColumnOptimizer.h
|
minor fixes in constraints
|
2021-11-17 18:43:02 +03:00 |
SynonymsExtensions.cpp
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
SynonymsExtensions.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
SystemLog.cpp
|
Add <storage_policy> config parameter for system logs
|
2023-01-19 10:25:28 +01:00 |
SystemLog.h
|
add system table asynchronous_inserts_log
|
2022-10-03 21:35:55 +00:00 |
TableJoin.cpp
|
Fix wrong column nullability in StoreageJoin
|
2023-01-11 16:17:21 +00:00 |
TableJoin.h
|
Join engine works with analyzer
|
2022-12-12 12:19:47 +00:00 |
TableOverrideUtils.cpp
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
TableOverrideUtils.h
|
Implement EXPLAIN TABLE OVERRIDE for pre-validating overrides.
|
2021-12-30 09:02:27 +01:00 |
TablesStatus.cpp
|
Revert "Fix errors of CheckTriviallyCopyableMove type"
|
2022-06-07 13:53:10 +02:00 |
TablesStatus.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
TemporaryDataOnDisk.cpp
|
Resolve code review comments
|
2022-12-22 10:22:58 +00:00 |
TemporaryDataOnDisk.h
|
Fixes
|
2022-12-22 10:22:57 +00:00 |
TextLog.cpp
|
add a column with a message pattern to text_log
|
2022-12-23 15:06:30 +01:00 |
TextLog.h
|
add a column with a message pattern to text_log
|
2022-12-23 15:06:30 +01:00 |
threadPoolCallbackRunner.h
|
Better async buffer from remote
|
2023-01-03 15:27:37 +01:00 |
ThreadStatusExt.cpp
|
Deallocate memory of profile events out of critical section
|
2023-01-11 09:58:30 +08:00 |
TraceCollector.cpp
|
Fix exception fix in TraceCollector dtor
|
2023-01-05 18:27:07 +00:00 |
TraceCollector.h
|
allow to send profile events to trace_log
|
2022-11-24 20:12:16 +00:00 |
TraceLog.cpp
|
Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log"
|
2022-12-27 14:28:13 +01:00 |
TraceLog.h
|
Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log"
|
2022-12-27 14:28:13 +01:00 |
TransactionLog.cpp
|
Define methods for multi read requests
|
2022-09-29 09:19:47 +00:00 |
TransactionLog.h
|
Define methods for multi read requests
|
2022-09-29 09:19:47 +00:00 |
TransactionsInfoLog.cpp
|
First try at reducing the use of StringRef
|
2022-07-17 17:26:02 +00:00 |
TransactionsInfoLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
TransactionVersionMetadata.cpp
|
canBeRemoved take into account creation_csn then no txn
|
2022-11-23 15:16:09 +00:00 |
TransactionVersionMetadata.h
|
more comments, minor fixes
|
2022-03-18 12:01:26 +01:00 |
TranslateQualifiedNamesVisitor.cpp
|
Merge remote-tracking branch 'upstream/master' into better_asterisk_parser
|
2023-01-13 19:15:55 +00:00 |
TranslateQualifiedNamesVisitor.h
|
Updated to get column data type based not function , not the query parameter type , added test for the same - 40907 Parameterized views as table functions
|
2022-12-19 15:05:38 +01:00 |
TreeCNFConverter.cpp
|
fix some typos and clang-tidy warnings
|
2022-09-05 09:50:24 +08:00 |
TreeCNFConverter.h
|
fix some typos and clang-tidy warnings
|
2022-09-05 09:50:24 +08:00 |
TreeOptimizer.cpp
|
Remove optimizeFuseQuantileFunctions
|
2022-12-29 14:43:33 +00:00 |
TreeOptimizer.h
|
Merge branch 'master' into ch_canh_fix_normalize
|
2022-12-02 17:59:21 +08:00 |
TreeRewriter.cpp
|
Merge branch 'master' into logical-optimizer-lowcardinality
|
2023-01-12 18:51:05 +01:00 |
TreeRewriter.h
|
Updated to get column data type based not function , not the query parameter type , added test for the same - 40907 Parameterized views as table functions
|
2022-12-19 15:05:38 +01:00 |
WhereConstraintsOptimizer.cpp
|
fix some typos and clang-tidy warnings
|
2022-09-05 09:50:24 +08:00 |
WhereConstraintsOptimizer.h
|
Reduce dependencies on ASTSelectQuery.h
|
2021-11-26 18:35:24 +01:00 |
WindowDescription.cpp
|
Added WINDOW functions support
|
2022-10-24 10:22:20 +02:00 |
WindowDescription.h
|
Added WINDOW functions support
|
2022-10-24 10:22:20 +02:00 |
ZooKeeperLog.cpp
|
Fix zookeeper_log
|
2022-09-27 12:36:59 +00:00 |
ZooKeeperLog.h
|
Add duration_ms into system.zookeeper_log
|
2022-07-28 22:34:51 +03:00 |