..
Access
fix style check
2022-06-02 15:27:32 +02:00
ClusterProxy
when using clang12 compile, the unused filed shard_count will cause compile error. So delete it.
2022-06-16 10:43:31 +08:00
examples
Prefix overridden add_executable() command with "clickhouse_"
2022-07-11 19:36:18 +02:00
fuzzers
Prefix overridden add_executable() command with "clickhouse_"
2022-07-11 19:36:18 +02:00
JIT
Fixed tests
2022-05-11 21:59:51 +02:00
MySQL
Merge branch 'master' into mysqldump-format
2022-04-28 15:58:18 +02:00
tests
fix all the stateless test
2022-01-13 15:27:41 +08:00
ActionLocksManager.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
ActionLocksManager.h
Rename "common" to "base"
2021-10-02 10:13:14 +03:00
ActionsDAG.cpp
Move updateInputStream
to ITransformingStep
( #37393 )
2022-06-27 13:16:52 +02:00
ActionsDAG.h
Simplify code a little bit.
2022-05-10 16:00:00 +00:00
ActionsVisitor.cpp
Allow to use higher-order functions in window expressions
2022-07-11 23:47:46 +00:00
ActionsVisitor.h
Fix ActionsDAG for window expressions
2022-07-11 23:18:44 +00: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
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +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
Move updateInputStream
to ITransformingStep
( #37393 )
2022-06-27 13:16:52 +02:00
AggregateDescription.h
Move updateInputStream
to ITransformingStep
( #37393 )
2022-06-27 13:16:52 +02:00
AggregateFunctionOfGroupByKeysVisitor.h
Reduce dependencies on ASTSelectQuery.h
2021-11-26 18:35:24 +01:00
AggregationCommon.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
Aggregator.cpp
Fix only_merge header
2022-07-01 23:31:45 +08:00
Aggregator.h
Move updateInputStream
to ITransformingStep
( #37393 )
2022-06-27 13:16:52 +02:00
Aliases.h
Rename "common" to "base"
2021-10-02 10:13:14 +03:00
applyTableOverride.cpp
Remove the possibility of adding columns with table overrides
2021-12-22 08:20:14 +01:00
applyTableOverride.h
Remove the possibility of adding columns with table overrides
2021-12-22 08:20:14 +01:00
ApplyWithAliasVisitor.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
ApplyWithAliasVisitor.h
Global WITH and WITH propagation.
2020-10-08 15:03:34 +08:00
ApplyWithGlobalVisitor.cpp
Add comment for visiting children of select in ApplyWithGlobalVisitor
2022-05-13 10:53:26 +00:00
ApplyWithGlobalVisitor.h
Fix
2021-11-01 16:33:19 +03:00
ApplyWithSubqueryVisitor.cpp
Reduce dependencies on ASTSelectWithUnionQuery.h
2021-11-26 19:27:16 +01:00
ApplyWithSubqueryVisitor.h
Fix CTE in view.
2021-04-06 11:32:16 +08:00
ArithmeticOperationsInAgrFuncOptimize.cpp
Merge pull request #36444 from rschu1ze/clang-tidy-fixes
2022-04-21 16:11:27 +02:00
ArithmeticOperationsInAgrFuncOptimize.h
rewrite avg for algebraic optimization
2021-02-07 14:41:41 +00:00
ArrayJoinAction.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
ArrayJoinAction.h
Replace all Context references with std::weak_ptr ( #22297 )
2021-04-11 02:33:54 +03:00
ArrayJoinedColumnsVisitor.h
Change signature of ASTSelectQuery::arrayJoinExpressionList
2021-08-31 15:27:44 +03:00
asof.h
AsynchronousInsertQueue.cpp
Don't use std::unique_lock unless we have to
2022-06-28 19:19:06 +00:00
AsynchronousInsertQueue.h
deprecate Ordinary database
2022-06-23 10:20:14 +02:00
AsynchronousMetricLog.cpp
Round values for the log
2022-04-17 22:07:50 +02:00
AsynchronousMetricLog.h
Remove useless codec from system.asynchronous_metric_log
2022-06-25 07:16:25 +02:00
AsynchronousMetrics.cpp
Merge pull request #38072 from lingpeng0314/master
2022-07-10 09:39:57 +02:00
AsynchronousMetrics.h
Implement MemoryStatisticsOS for FreeBSD
2022-02-25 14:05:00 +03: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
Rename "common" to "base"
2021-10-02 10:13:14 +03:00
CancellationCode.h
castColumn.cpp
Merge branch 'master' into cast_to_value_or_default
2021-09-28 14:04:10 +03:00
castColumn.h
Fixed compilation timeout
2020-12-17 21:32:25 +03:00
CatBoostModel.cpp
Use compile-time check for Exception messages, fix wrong messages
2022-03-29 13:16:11 +00:00
CatBoostModel.h
ExternalModelsLoader refactoring
2022-03-23 20:05:17 +01:00
ClientInfo.cpp
Fix various clang-tidy warnings
2022-04-20 10:29:05 +02:00
ClientInfo.h
Slightly better mysql handler
2022-04-27 18:28:09 +08:00
Cluster.cpp
More accurate access checking for RESTORE.
2022-06-19 11:26:41 +02:00
Cluster.h
More accurate access checking for RESTORE.
2022-06-19 11:26:41 +02:00
ClusterDiscovery.cpp
base should not depend on Common
2022-04-29 10:26:35 +08:00
ClusterDiscovery.h
Log exception on cluster discovery initial update
2021-12-27 18:24:25 +03:00
CMakeLists.txt
Done
2021-10-04 17:57:58 +00:00
CollectJoinOnKeysVisitor.cpp
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +01:00
CollectJoinOnKeysVisitor.h
Support conditions in JOIN ON section ( #24420 )
2021-07-21 20:03:33 +03:00
ColumnAliasesVisitor.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
ColumnAliasesVisitor.h
Skip JOIN OR/USING sections in replaceAliasColumnsInQuery
2021-09-14 14:13:19 +03:00
ComparisonGraph.cpp
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
ComparisonGraph.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
ConcurrentHashJoin.cpp
Update toPowerOfTwo in ConcurrentHashJoin
2022-07-12 20:22:35 +02:00
ConcurrentHashJoin.h
upd ConcurrentHashJoin
2022-07-12 20:22:35 +02:00
Context_fwd.h
Remove old code
2021-07-06 05:31:09 +03:00
Context.cpp
add function tryGetKeeperDispatcher for context
2022-07-04 13:35:08 +08:00
Context.h
add function tryGetKeeperDispatcher for context
2022-07-04 13:35:08 +08:00
convertFieldToType.cpp
fix ConvertDecimalType unexpected behavior
2022-04-24 23:35:58 +08:00
convertFieldToType.h
fix some logical errors
2020-06-24 23:51:17 +03:00
ConvertFunctionOrLikeVisitor.cpp
Fix new occurrences of new clang-tidy warnings
2022-05-16 11:31:36 +02:00
ConvertFunctionOrLikeVisitor.h
Fix new occurrences of new clang-tidy warnings
2022-05-16 11:31:36 +02:00
ConvertStringsToEnumVisitor.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
ConvertStringsToEnumVisitor.h
Fix a bunch of warnings from PVS-Studio
2021-05-08 19:13:10 +03:00
CrashLog.cpp
More consistent use of platform macros
2022-06-10 10:22:31 +02:00
CrashLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
createBlockSelector.cpp
Optimize most important parts with NEON SIMD
2022-06-15 13:19:29 +00:00
createBlockSelector.h
CrossToInnerJoinVisitor.cpp
Upd cross_to_inner_join_rewrite setting, add test
2022-05-11 10:56:43 +00:00
CrossToInnerJoinVisitor.h
Upd cross_to_inner_join_rewrite setting, add test
2022-05-11 10:56:43 +00:00
DatabaseAndTableWithAlias.cpp
Merge branch 'master' into ast-table-identifier-2
2021-04-09 17:56:15 +03:00
DatabaseAndTableWithAlias.h
Rename "common" to "base"
2021-10-02 10:13:14 +03:00
DatabaseCatalog.cpp
Fix NOEXCEPT_SCOPE (before it calls std::terminate and looses the exception)
2022-07-14 17:16:18 +03:00
DatabaseCatalog.h
Improve handling predefined databases and tables.
2022-06-30 08:37:17 +02:00
DDLTask.cpp
better code
2022-06-01 16:49:26 +02:00
DDLTask.h
fix sync database replica
2022-05-06 18:37:20 +02:00
DDLWorker.cpp
Merge branch 'master' into remove-useless-code-2
2022-06-03 13:58:45 +00:00
DDLWorker.h
add some TSA aanotations
2022-06-27 22:48:27 +02:00
DictionaryReader.cpp
ORs in JOINs
2021-09-28 14:11:28 +03:00
DictionaryReader.h
Replace all Context references with std::weak_ptr ( #22297 )
2021-04-11 02:33:54 +03:00
DirectJoin.cpp
better
2022-07-05 10:46:08 +00:00
DirectJoin.h
better
2022-07-05 10:46:08 +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
Fix bad optimization of ORDER BY in subquery if it contains WITH FILL
2021-09-12 01:24:20 +03: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
Fix build.
2022-06-20 03:44:59 +02:00
executeDDLQueryOnCluster.h
Merge branch 'master' into refactor-read-metrics-and-callbacks
2022-05-25 16:27:40 +02:00
executeQuery.cpp
another one
2022-07-05 17:36:45 +00: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
Comment
2022-01-26 17:36:45 +01:00
ExpressionActions.cpp
Merge pull request #37336 from vdimir/fix_clash_const_aggegate_join
2022-05-23 17:09:30 +02:00
ExpressionActions.h
Perserve constness in ExpressionActionsChain::JoinStep
2022-05-20 11:31:58 +00: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
Allow to use higher-order functions in window expressions
2022-07-11 23:47:46 +00:00
ExpressionAnalyzer.h
Fix ActionsDAG for window expressions
2022-07-11 23:18:44 +00:00
ExpressionJIT.cpp
base should not depend on Common
2022-04-29 10:26:35 +08:00
ExternalDictionariesLoader.cpp
More logs on unsuccessful part removal
2022-04-04 13:17:33 +02:00
ExternalDictionariesLoader.h
Fixed tests
2021-10-14 22:12:06 +03:00
ExternalLoader.cpp
base should not depend on Common
2022-04-29 10:26:35 +08: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
ExternalModelsLoader.cpp
Replace all Context references with std::weak_ptr ( #22297 )
2021-04-11 02:33:54 +03:00
ExternalModelsLoader.h
base should not depend on Common
2022-04-29 10:26:35 +08:00
ExternalUserDefinedExecutableFunctionsLoader.cpp
Disable parameters for non direct executable user defined functions
2022-06-16 16:29:04 +02:00
ExternalUserDefinedExecutableFunctionsLoader.h
Added user defined executable functions to system.functions
2021-09-17 18:43:00 +03:00
ExtractExpressionInfoVisitor.cpp
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +01:00
ExtractExpressionInfoVisitor.h
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +01:00
FilesystemCacheLog.cpp
Fixing some warnings
2022-05-16 20:59:27 +02:00
FilesystemCacheLog.h
Fixing some warnings
2022-05-16 20:59: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
Pushdown filter to the right side of sorting join
2022-07-13 11:36:25 +00:00
FunctionNameNormalizer.cpp
Reduce dependencies on ASTFunction.h
2021-11-26 18:21:54 +01:00
FunctionNameNormalizer.h
Reduce dependencies on ASTFunction.h
2021-11-26 18:21:54 +01:00
GatherFunctionQuantileVisitor.cpp
Reduce dependencies on ASTFunction.h
2021-11-26 18:21:54 +01:00
GatherFunctionQuantileVisitor.h
Reduce dependencies on ASTFunction.h
2021-11-26 18:21:54 +01:00
GetAggregatesVisitor.cpp
Allow to use higher-order functions in window expressions
2022-07-11 23:47:46 +00:00
GetAggregatesVisitor.h
Small refactoring
2022-06-16 15:41:04 +00:00
getClusterName.cpp
Better exception messages on wrong table engines/functions argument types
2022-06-23 20:04:06 +00:00
getClusterName.h
getClusterName: Use std::string over String (since it includes only <string>)
2021-03-03 23:29:11 +03: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
Merge remote-tracking branch 'upstream/master' into HEAD
2022-03-03 22:25:28 +00: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
GlobalSubqueriesVisitor.h
Don't materialize external tables if it's explain statement
2022-04-08 09:00:55 +08:00
GroupByFunctionKeysVisitor.h
Reduce dependencies on ASTSelectQuery.h
2021-11-26 18:35:24 +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
Rewrite queries GROUPING SETS (foo, bar) to GROUP BY foo, bar
2022-05-27 17:44:51 +03:00
HashJoin.cpp
upd ConcurrentHashJoin
2022-07-12 20:22:35 +02:00
HashJoin.h
Fix build
2022-07-06 15:11:23 +00:00
IdentifierSemantic.cpp
fixed bugs
2022-06-17 15:13:31 +08:00
IdentifierSemantic.h
fixed bugs
2022-06-17 15:13:31 +08: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
Cleanup
2022-06-02 10:34:40 +00:00
IInterpreterUnionOrSelectQuery.h
Simple cleanup: context ptr usage in interpreters
2022-07-06 12:29:20 +00:00
IJoin.h
Minor updates for full soring merge join
2022-07-06 14:28:05 +00:00
InDepthNodeVisitor.h
Rework expressions with window functions
2022-06-16 13:29:56 +00:00
InJoinSubqueriesPreprocessor.cpp
Apply suggestions from code review
2021-11-10 14:44:35 +03:00
InJoinSubqueriesPreprocessor.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
inplaceBlockConversions.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
inplaceBlockConversions.h
support dynamic subcolumns for Memory engine
2022-02-09 03:18:53 +03:00
InternalTextLogsQueue.cpp
Text log source regexp
2022-07-13 17:52:14 +08:00
InternalTextLogsQueue.h
Text log source regexp
2022-07-13 17:52:14 +08:00
InterpreterAlterQuery.cpp
Support sql standard drop index in seprate parser files
2022-06-29 11:08:05 +08:00
InterpreterAlterQuery.h
throw exception on non-transactional queries
2022-02-01 01:27:55 +03:00
InterpreterBackupQuery.cpp
Improved using ThreadPool for making backup or restoring, changed columns in system.backups.
2022-05-03 11:03:13 +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
Validate that function had been passed in CREATE FUNCTION
2022-05-01 19:01:03 +03:00
InterpreterCreateFunctionQuery.h
SQLUserDefinedFunctions support lambdas
2021-10-20 12:43:03 +03:00
InterpreterCreateIndexQuery.cpp
SQL create drop index fix formatting
2022-07-01 22:35:20 +02:00
InterpreterCreateIndexQuery.h
Support sql standard drop index in seprate parser files
2022-06-29 11:08:05 +08:00
InterpreterCreateQuery.cpp
Review and style fixes
2022-06-29 20:29:50 +02:00
InterpreterCreateQuery.h
Extract schema only once on table creation and add it to metadata ( #34684 )
2022-03-04 21:23:19 +03:00
InterpreterDescribeCacheQuery.cpp
Better
2022-06-23 17:46:27 +02:00
InterpreterDescribeCacheQuery.h
Add describe cache command
2022-06-21 16:07:39 +02:00
InterpreterDescribeQuery.cpp
use snapshots for semistructured data, durability fixes
2022-03-17 18:26:18 +01:00
InterpreterDescribeQuery.h
Small refactoring.
2021-09-15 22:35:48 +03:00
InterpreterDropFunctionQuery.cpp
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
2022-04-25 16:34:33 +02:00
InterpreterDropFunctionQuery.h
Fixed integration tests
2021-08-23 17:31:58 +03:00
InterpreterDropIndexQuery.cpp
SQL create drop index fix formatting
2022-07-01 22:35:20 +02:00
InterpreterDropIndexQuery.h
Support sql standard drop index in seprate parser files
2022-06-29 11:08:05 +08:00
InterpreterDropQuery.cpp
deprecate Ordinary database
2022-06-23 10:20:14 +02:00
InterpreterDropQuery.h
deprecate Ordinary database
2022-06-23 10:20:14 +02: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
Rename setting after_rewrite
-> rewrite
2022-07-06 17:29:30 +00:00
InterpreterExplainQuery.h
add EXPLAIN CURRENT TRANSACTION
2022-02-14 22:47:17 +03:00
InterpreterExternalDDLQuery.cpp
Fix typo in USE_MYSQL check
2021-11-10 11:38:03 +03:00
InterpreterExternalDDLQuery.h
Make ContextPtr const by default.
2021-05-31 17:49:02 +03:00
InterpreterFactory.cpp
Support sql standard drop index in seprate parser files
2022-06-29 11:08:05 +08:00
InterpreterFactory.h
Make ContextPtr const by default.
2021-05-31 17:49:02 +03:00
InterpreterInsertQuery.cpp
Fix parallel_view_processing with optimize_trivial_insert_select=1
2022-07-03 15:14:05 +03:00
InterpreterInsertQuery.h
throw exception on non-transactional queries
2022-02-01 01:27:55 +03:00
InterpreterKillQueryQuery.cpp
Move some resources
2022-05-20 19:49:31 +00:00
InterpreterKillQueryQuery.h
Make ContextPtr const by default.
2021-05-31 17:49:02 +03:00
InterpreterOptimizeQuery.cpp
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
2022-04-25 16:34:33 +02:00
InterpreterOptimizeQuery.h
throw exception on non-transactional queries
2022-02-01 01:27:55 +03:00
InterpreterRenameQuery.cpp
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
2022-04-25 16:34:33 +02:00
InterpreterRenameQuery.h
Merge branch 'master' into check_dependencies_on_drop
2021-11-15 13:35:45 +03:00
InterpreterSelectIntersectExceptQuery.cpp
Cleanup
2022-06-02 10:34:40 +00:00
InterpreterSelectIntersectExceptQuery.h
Cleanup
2022-06-02 10:34:40 +00:00
InterpreterSelectQuery.cpp
Pushdown filter to the right side of sorting join
2022-07-13 11:36:25 +00:00
InterpreterSelectQuery.h
Continue: ContextPtr -> const ContextPtr & in parameters
2022-07-06 13:13:19 +00:00
InterpreterSelectWithUnionQuery.cpp
+ use DistinctSorted for final distinct step
2022-06-30 13:03:39 +00:00
InterpreterSelectWithUnionQuery.h
Simple cleanup: interpreters and parsers
2022-07-05 22:13:39 +00:00
InterpreterSetQuery.cpp
Remove unnecessary changes.
2021-09-07 01:37:28 +03:00
InterpreterSetQuery.h
throw exception on non-transactional queries
2022-02-01 01:27:55 +03:00
InterpreterShowCreateQuery.cpp
Merge branch 'master' into query_parameters
2021-11-11 11:43:00 +00: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
Better
2022-06-23 17:46:27 +02:00
InterpreterShowTablesQuery.h
Make ContextPtr const by default.
2021-05-31 17:49:02 +03:00
InterpreterSystemQuery.cpp
Merge master
2022-06-23 21:40:01 +02:00
InterpreterSystemQuery.h
fix flaky tests
2022-05-26 14:17:05 +02:00
InterpreterTransactionControlQuery.cpp
fix race on queue processing
2022-06-15 16:21:26 +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
Refactor a little bit more.
2022-05-31 14:43:38 +00: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
Add support for PowerPC build
2021-10-12 01:47:57 +03:00
ITokenExtractor.h
Fixed build
2021-10-06 23:22:29 +03:00
join_common.cpp
full sort join: check key types, more tests
2022-07-06 14:26:19 +00:00
join_common.h
Fix LowCardinality using key for join_use_nulls in pipeline
2022-02-15 11:11:59 +00:00
joinDispatch.h
Rename "common" to "base"
2021-10-02 10:13:14 +03:00
JoinedTables.cpp
do not call setStorageJoin when setting isn't set
2022-07-04 17:28:15 +00:00
JoinedTables.h
Minimize changes, improve scalar subquery for MVs
2022-01-26 17:36:45 +01:00
JoinSwitcher.cpp
Fix cast lowcard of nullable in JoinSwitcher
2022-05-23 13:05:59 +00:00
JoinSwitcher.h
Remove BlockInputStream interfaces.
2021-10-14 13:25:43 +03:00
JoinToSubqueryTransformVisitor.cpp
Add setting multiple_joins_try_to_keep_original_names
2022-06-16 15:50:03 +00:00
JoinToSubqueryTransformVisitor.h
Add setting multiple_joins_try_to_keep_original_names
2022-06-16 15:50:03 +00:00
Lemmatizers.cpp
Remove cruft
2021-10-28 02:10:39 +03:00
Lemmatizers.h
Remove cruft
2021-10-28 02:10:39 +03:00
loadMetadata.cpp
fix
2022-06-28 00:26:52 +02:00
loadMetadata.h
automatically convert system database to Atomic
2022-06-23 21:38:43 +02:00
LogicalExpressionsOptimizer.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
LogicalExpressionsOptimizer.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
MarkTableIdentifiersVisitor.cpp
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +01:00
MarkTableIdentifiersVisitor.h
Fix crash on call dictGet() with bad arguments.
2021-07-02 14:46:12 +03:00
MergeJoin.cpp
get/setTotas to IJoin
2022-07-04 17:28:13 +00:00
MergeJoin.h
get/setTotas to IJoin
2022-07-04 17:28:13 +00:00
MergeTreeTransaction.cpp
Fix NOEXCEPT_SCOPE (before it calls std::terminate and looses the exception)
2022-07-14 17:16:18 +03:00
MergeTreeTransaction.h
add some TSA aanotations
2022-06-27 22:48:27 +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
Remove microseconds from system.asynchronous_metric_log
2022-04-17 22:01:58 +02: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
Small refactoring
2022-06-16 15:41:04 +00:00
MutationsInterpreter.cpp
Merge branch 'master' into fix-mutations-again
2022-06-03 14:17:05 +02:00
MutationsInterpreter.h
Better.
2022-05-24 20:06:08 +00:00
NormalizeSelectWithUnionQueryVisitor.cpp
Reduce dependencies on ASTSelectWithUnionQuery.h
2021-11-26 19:27:16 +01:00
NormalizeSelectWithUnionQueryVisitor.h
Reduce dependencies on ASTSelectWithUnionQuery.h
2021-11-26 19:27:16 +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
Update src/Interpreters/OpenTelemetrySpanLog.cpp
2022-07-04 17:52:06 +02:00
OpenTelemetrySpanLog.h
Use native Map
2022-07-04 14:07:29 +00:00
OptimizeIfChains.cpp
Reduce dependencies on ASTLiteral.h
2021-11-26 17:54:57 +01:00
OptimizeIfChains.h
replace multiIf to if in case of one condition
2022-05-31 14:45:12 +00:00
OptimizeIfWithConstantConditionVisitor.cpp
Remove Arcadia
2022-04-16 00:20:47 +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
Refactor code around optimize_skip_unused_shards_rewrite_in a little
2021-07-07 00:17:39 +03:00
PartLog.cpp
Cleanup.
2022-06-20 18:18:17 +00:00
PartLog.h
FR: Expose what triggered the merge in system.part_log #26255
2022-06-01 16:58:06 +02:00
PredicateExpressionsOptimizer.cpp
Reduce dependencies on ASTSelectWithUnionQuery.h
2021-11-26 19:27:16 +01:00
PredicateExpressionsOptimizer.h
Reduce dependencies on ASTSelectQuery.h
2021-11-26 18:35:24 +01:00
PredicateRewriteVisitor.cpp
Fix column matcher and column transformer
2022-04-20 01:22:04 +08:00
PredicateRewriteVisitor.h
Reduce dependencies on ASTSelectQuery.h
2021-11-26 18:35:24 +01:00
PreparedSets.h
Fix trailing whitespace
2020-10-26 22:12:40 +03: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
Print query in one line on fatal errors
2022-06-03 18:55:53 +03:00
ProcessList.h
Set is_all_data_sent on exceptions too
2022-04-30 13:00:44 +03:00
ProcessorsProfileLog.cpp
base should not depend on Common
2022-04-29 10:26:35 +08:00
ProcessorsProfileLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
ProfileEventsExt.cpp
Fix build
2022-04-20 13:34:17 +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
QueryLog.cpp
Fix various clang-tidy warnings
2022-04-20 10:29:05 +02:00
QueryLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
QueryNormalizer.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
QueryNormalizer.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
QueryParameterVisitor.cpp
Remove ANALYZE and AST queries ( #16536 )
2020-11-02 15:47:12 +03:00
QueryParameterVisitor.h
Even more
2020-09-19 18:02:11 +03: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
Move code around to avoid dlsym on Musl
2021-12-24 12:25:27 +03:00
QueryViewsLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
RedundantFunctionsInOrderByVisitor.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
RemoveInjectiveFunctionsVisitor.cpp
Rename ContextConstPtr to ContextPtr.
2021-06-01 15:20:52 +03:00
RemoveInjectiveFunctionsVisitor.h
Rename ContextConstPtr to ContextPtr.
2021-06-01 15:20:52 +03:00
RenameColumnVisitor.cpp
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +01:00
RenameColumnVisitor.h
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +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
ReplaceQueryParameterVisitor.cpp
Add comment
2022-01-25 10:10:04 +03: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
Rename "common" to "base"
2021-10-02 10:13:14 +03:00
RequiredSourceColumnsVisitor.cpp
Activate clang-tidy warning "readability-container-contains"
2022-04-18 23:53:11 +02:00
RequiredSourceColumnsVisitor.h
Fix lambdas with multiple_joins_rewriter v2 ( #11587 )
2020-06-16 19:32:32 +03:00
RewriteAnyFunctionVisitor.cpp
Small refactoring
2022-06-16 15:41:04 +00:00
RewriteAnyFunctionVisitor.h
Fix move_functions_out_of_any optimisation with lambda ( #12664 )
2020-07-23 18:15:22 +03:00
RewriteCountDistinctVisitor.cpp
Activated a bunch of LLVM 12/13/14 clang-tidy warnings
2022-05-03 09:22:11 +02:00
RewriteCountDistinctVisitor.h
Count distinct optimization by using subquery of group by ( #35993 )
2022-04-28 14:55:37 +02:00
RewriteCountVariantsVisitor.cpp
Reduce dependencies on ASTIdentifier.h
2021-11-26 16:49:40 +01:00
RewriteCountVariantsVisitor.h
Fix
2021-02-10 12:48:41 +08:00
RewriteFunctionToSubcolumnVisitor.cpp
fix #33798
2022-03-06 12:02:17 +08:00
RewriteFunctionToSubcolumnVisitor.h
Reduce dependencies on ASTFunction.h
2021-11-26 18:21:54 +01:00
RewriteOrderByVisitor.cpp
Fix: rewrite only outer braces
2022-07-06 10:23:05 +00:00
RewriteOrderByVisitor.hpp
Fix: clear children in order by element during rewriting
2022-07-05 22:48:48 +00:00
RewriteSumIfFunctionVisitor.cpp
Fix sumIf rewrite
2022-01-16 06:25:11 +00:00
RewriteSumIfFunctionVisitor.h
Rewrite sum(if())
and sumIf
to countIf
in special cases ( #17041 )
2021-01-21 12:01:35 +03:00
RowRefs.cpp
improve performace of insertion to columns of type JSON
2022-06-22 17:45:51 +00:00
RowRefs.h
Improve performance of ASOF join
2022-03-23 12:19:38 +01:00
SelectIntersectExceptQueryVisitor.cpp
Reduce dependencies on ASTSelectWithUnionQuery.h
2021-11-26 19:27:16 +01:00
SelectIntersectExceptQueryVisitor.h
Reduce dependencies on ASTSelectWithUnionQuery.h
2021-11-26 19:27:16 +01:00
SelectQueryOptions.h
Revert "Fix converting types for UNION queries (may produce LOGICAL_ERROR)"
2022-06-28 22:50:01 +03:00
Session.cpp
better code
2022-06-01 16:49:26 +02:00
Session.h
review suggestions
2022-05-23 21:55:17 +02:00
SessionLog.cpp
review suggestions
2022-05-23 21:55:17 +02:00
SessionLog.h
review suggestions
2022-05-23 21:55:17 +02:00
Set.cpp
Don't use std::unique_lock unless we have to
2022-06-28 19:19:06 +00:00
Set.h
base should not depend on Common
2022-04-29 10:26:35 +08:00
SetVariants.cpp
Normalize BigInt implementation
2021-01-27 03:54:57 +03: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
MergeTree merge disable batch optimization
2022-07-05 16:15:00 +02:00
SortedBlocksWriter.h
Move some files.
2021-10-16 17:03:50 +03: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
Merge branch 'master' into query_parameters
2021-10-18 17:34:20 +03:00
StorageID.h
More clang-tidy fixes
2022-06-28 11:50:05 +00:00
SubqueryForSet.cpp
clang-tidy check performance-noexcept-move-constructor fix
2022-03-02 18:15:27 +00:00
SubqueryForSet.h
clang-tidy check performance-noexcept-move-constructor fix
2022-03-02 18:15:27 +00:00
SubstituteColumnOptimizer.cpp
fix tests
2021-11-19 17:14:56 +03:00
SubstituteColumnOptimizer.h
minor fixes in constraints
2021-11-17 18:43:02 +03:00
SynonymsExtensions.cpp
Remove cruft
2021-10-28 02:10:39 +03:00
SynonymsExtensions.h
Remove cruft
2021-10-28 02:10:39 +03:00
SystemLog.cpp
review suggestions
2022-05-23 21:55:17 +02:00
SystemLog.h
fix
2022-05-01 19:45:16 +08:00
TableJoin.cpp
Disable parallel hash join for asof
2022-07-12 20:22:35 +02:00
TableJoin.h
upd full sorting join
2022-07-06 14:28:05 +00:00
TableOverrideUtils.cpp
Merge remote-tracking branch 'upstream/master' into HEAD
2022-01-21 20:11:18 +03: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
TextLog.cpp
base should not depend on Common
2022-04-29 10:26:35 +08:00
TextLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
threadPoolCallbackRunner.cpp
base should not depend on Common
2022-04-29 10:26:35 +08:00
threadPoolCallbackRunner.h
Better
2022-04-07 18:48:35 +02:00
ThreadStatusExt.cpp
Fix NOEXCEPT_SCOPE (before it calls std::terminate and looses the exception)
2022-07-14 17:16:18 +03:00
TraceCollector.cpp
base should not depend on Common
2022-04-29 10:26:35 +08:00
TraceCollector.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
TraceLog.cpp
Add ability to trace peak memory usage (with new trace_type - MemoryPeak)
2021-10-07 21:13:56 +03:00
TraceLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
TransactionLog.cpp
Fix NOEXCEPT_SCOPE (before it calls std::terminate and looses the exception)
2022-07-14 17:16:18 +03:00
TransactionLog.h
add some TSA aanotations
2022-06-27 22:48:27 +02:00
TransactionsInfoLog.cpp
write part version before other files
2022-02-15 02:24:51 +03:00
TransactionsInfoLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00
TransactionVersionMetadata.cpp
fix race on queue processing
2022-06-15 16:21:26 +02:00
TransactionVersionMetadata.h
more comments, minor fixes
2022-03-18 12:01:26 +01:00
TranslateQualifiedNamesVisitor.cpp
update codes based on review comment
2022-07-01 10:15:35 +08:00
TranslateQualifiedNamesVisitor.h
update codes based on review comment
2022-07-01 10:15:35 +08:00
TreeCNFConverter.cpp
Merge pull request #32748 from CurtizJ/read-in-order-fixed-prefix
2022-02-03 18:17:08 +03:00
TreeCNFConverter.h
Fix clang-tidy warnings in Interpreters, IO folders
2022-03-14 18:17:35 +00:00
TreeOptimizer.cpp
replace multiIf to if in case of one condition
2022-05-31 14:45:12 +00:00
TreeOptimizer.h
Apply optimizeCountConstantAndSumOne before JOINs
2022-05-10 14:30:33 +00:00
TreeRewriter.cpp
Merge pull request #35796 from vdimir/full-sorting-merge-join
2022-07-07 19:16:49 +02:00
TreeRewriter.h
Merge pull request #37913 from azat/parts-refcnt
2022-06-21 22:56:26 +02:00
UserDefinedExecutableFunction.cpp
Fixing some warnings
2022-05-16 20:59:27 +02:00
UserDefinedExecutableFunction.h
Executable user defined functions support parameters
2022-06-03 18:05:37 +02:00
UserDefinedExecutableFunctionFactory.cpp
Executable user defined functions extract parameters name and type from command value
2022-06-03 18:06:59 +02:00
UserDefinedExecutableFunctionFactory.h
Executable user defined functions support parameters
2022-06-03 18:05:37 +02:00
UserDefinedSQLFunctionFactory.cpp
Fix evaluateConstantExpression for subqueries
2022-04-28 22:09:29 +02:00
UserDefinedSQLFunctionFactory.h
Updated UserDefinedSQLFunctionFactory
2021-10-27 18:49:18 +03:00
UserDefinedSQLFunctionVisitor.cpp
support explain create function query
2022-01-20 16:23:52 +08:00
UserDefinedSQLFunctionVisitor.h
Fix recursive user defined functions crash
2021-11-25 19:03:56 +03:00
UserDefinedSQLObjectsLoader.cpp
SQLUserDefinedFunctionsLoader allow symlinks in user_defined directory
2022-06-17 17:43:42 +02:00
UserDefinedSQLObjectsLoader.h
SQLUserDefinedFunctions support CREATE OR REPLACE, CREATE IF NOT EXISTS
2021-10-20 17:56:46 +03:00
WhereConstraintsOptimizer.cpp
minor fixes in constraints
2021-11-17 18:43:02 +03:00
WhereConstraintsOptimizer.h
Reduce dependencies on ASTSelectQuery.h
2021-11-26 18:35:24 +01:00
WindowDescription.cpp
Initial: replacing hardcoded toString for enums with magic_enum
2021-09-06 16:24:03 +02:00
WindowDescription.h
Added optimize_read_in_window_order
setting.
2022-06-20 05:15:07 +03:00
ZooKeeperLog.cpp
Fixing some warnings
2022-05-16 20:59:27 +02:00
ZooKeeperLog.h
Custom column list for system.asynchronous_metric_log
2022-04-17 23:49:39 +02:00