.. |
Access
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
ClusterProxy
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
examples
|
contrib/libmetrohash: add ALIAS library
|
2022-01-21 10:11:23 +03:00 |
fuzzers
|
|
|
JIT
|
Add ability to pass range of rows to Aggregator
|
2022-04-29 06:57:55 +03: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
|
|
|
ActionsDAG.cpp
|
Merge remote-tracking branch 'origin/master' into erase_if3
|
2022-04-20 10:02:59 +02:00 |
ActionsDAG.h
|
stash
|
2022-04-04 14:33:57 +02:00 |
ActionsVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ActionsVisitor.h
|
Remove Arcadia
|
2022-04-15 23:59:49 +02:00 |
AddDefaultDatabaseVisitor.h
|
Add ability to rewrite only JOIN tables in AddDefaultDatabaseVisitor
|
2022-01-14 11:18:52 +03:00 |
AddIndexConstraintsOptimizer.cpp
|
|
|
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
|
|
|
addTypeConversionToAST.h
|
|
|
AggregateDescription.cpp
|
|
|
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
Aggregator.cpp
|
Merge branch 'master' into aggregator-jit-lock-fix
|
2022-05-02 16:16:36 +00:00 |
Aggregator.h
|
Merge pull request #35111 from azat/optimize_aggregation_in_order-prefix
|
2022-05-02 17:49:48 +02:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
|
|
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
|
|
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
Merge pull request #36444 from rschu1ze/clang-tidy-fixes
|
2022-04-21 16:11:27 +02:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
ArrayJoinAction.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ArrayJoinAction.h
|
|
|
ArrayJoinedColumnsVisitor.h
|
|
|
asof.h
|
dbms/ → src/
|
2020-04-03 18:14:31 +03:00 |
AsynchronousInsertQueue.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
AsynchronousInsertQueue.h
|
Fix race between INSERT async_insert=1 and system.asynchronous_inserts
|
2022-03-02 15:28:06 +03:00 |
AsynchronousMetricLog.cpp
|
Round values for the log
|
2022-04-17 22:07:50 +02:00 |
AsynchronousMetricLog.h
|
Avoid recreation of system.asynchronous_metric_log (due to difference in codec)
|
2022-04-30 12:19:29 +03:00 |
AsynchronousMetrics.cpp
|
Predict size of hash table for GROUP BY (#33439)
|
2022-03-30 22:47:51 +02:00 |
AsynchronousMetrics.h
|
Implement MemoryStatisticsOS for FreeBSD
|
2022-02-25 14:05:00 +03:00 |
BloomFilter.cpp
|
|
|
BloomFilter.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
BloomFilterHash.h
|
|
|
CancellationCode.h
|
|
|
castColumn.cpp
|
|
|
castColumn.h
|
|
|
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
|
Added an ability to specify cluster secret in replicated database (#35333)
|
2022-03-25 00:14:26 +01:00 |
Cluster.h
|
Added an ability to specify cluster secret in replicated database (#35333)
|
2022-03-25 00:14:26 +01:00 |
ClusterDiscovery.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ClusterDiscovery.h
|
|
|
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
|
|
CollectJoinOnKeysVisitor.h
|
|
|
ColumnAliasesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ColumnAliasesVisitor.h
|
|
|
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 |
Context_fwd.h
|
|
|
Context.cpp
|
Merge pull request #36859 from ClickHouse/revert-36858-revert-35637-memory-overcommit-free
|
2022-05-04 23:43:00 +02:00 |
Context.h
|
fix
|
2022-05-01 19:45:16 +08:00 |
convertFieldToType.cpp
|
fix ConvertDecimalType unexpected behavior
|
2022-04-24 23:35:58 +08:00 |
convertFieldToType.h
|
|
|
ConvertStringsToEnumVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ConvertStringsToEnumVisitor.h
|
|
|
CrashLog.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
CrashLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
createBlockSelector.cpp
|
|
|
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
|
|
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Fix build, pt. II
|
2022-05-04 10:15:25 +02:00 |
DatabaseCatalog.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
DDLTask.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
DDLTask.h
|
Merge branch 'master' into improve_create_or_replace
|
2021-08-03 11:39:07 +00:00 |
DDLWorker.cpp
|
Merge pull request #36715 from amosbird/refactorbase
|
2022-04-30 09:40:58 +03:00 |
DDLWorker.h
|
fix too strict assertion
|
2022-03-23 11:55:28 +01:00 |
DictionaryReader.cpp
|
|
|
DictionaryReader.h
|
|
|
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
|
|
|
DuplicateOrderByVisitor.h
|
|
|
EmbeddedDictionaries.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
EmbeddedDictionaries.h
|
|
|
evaluateConstantExpression.cpp
|
Fix build
|
2022-05-02 14:27:00 +02:00 |
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
executeDDLQueryOnCluster.h
|
Implement BACKUP/RESTORE ON CLUSTER.
|
2022-04-25 16:34:33 +02:00 |
executeQuery.cpp
|
Add Other Time Microseconds Profile Event
|
2022-05-02 17:13:57 +02:00 |
executeQuery.h
|
|
|
ExecuteScalarSubqueriesVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ExecuteScalarSubqueriesVisitor.h
|
Comment
|
2022-01-26 17:36:45 +01:00 |
ExpressionActions.cpp
|
Fix glitch
|
2022-04-19 14:59:47 +02:00 |
ExpressionActions.h
|
|
|
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
|
|
ExpressionAnalyzer.cpp
|
Fix "Cannot find column" error for distributed queries with LIMIT BY
|
2022-04-20 15:23:24 +03:00 |
ExpressionAnalyzer.h
|
Merge pull request #35631 from amosbird/projection-fix1
|
2022-04-21 15:32:52 +02: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
|
|
|
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
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
|
|
ExternalLoaderXMLConfigRepository.h
|
|
|
ExternalModelsLoader.cpp
|
|
|
ExternalModelsLoader.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
ExternalUserDefinedExecutableFunctionsLoader.cpp
|
clang-tidy check performance-move-const-arg fix
|
2022-03-02 18:15:27 +00:00 |
ExternalUserDefinedExecutableFunctionsLoader.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
|
|
FilesystemCacheLog.cpp
|
Better
|
2022-05-03 15:55:36 +02:00 |
FilesystemCacheLog.h
|
Better
|
2022-05-03 15:55:36 +02:00 |
FillingRow.cpp
|
fixed Nullable, tests added
|
2022-04-08 10:52:10 -04:00 |
FillingRow.h
|
major refactoring, simplified, optimized, bugs fixed
|
2022-03-27 14:32:09 -04:00 |
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GatherFunctionQuantileVisitor.cpp
|
|
|
GatherFunctionQuantileVisitor.h
|
|
|
GetAggregatesVisitor.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
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
|
|
|
getTableExpressions.cpp
|
|
|
getTableExpressions.h
|
Minor style changes in JoinedTables
|
2021-07-08 13:49:13 +03:00 |
getTableOverride.cpp
|
|
|
getTableOverride.h
|
|
|
GlobalSubqueriesVisitor.h
|
Don't materialize external tables if it's explain statement
|
2022-04-08 09:00:55 +08:00 |
GroupByFunctionKeysVisitor.h
|
|
|
HashJoin.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
HashJoin.h
|
Merge branch 'master' into asof_ftw
|
2022-03-02 13:20:50 +00:00 |
IdentifierSemantic.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
IdentifierSemantic.h
|
|
|
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
Update IExternalLoadable interface
|
2022-01-16 00:06:10 +00:00 |
IExternalLoaderConfigRepository.h
|
|
|
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
|
Forward declaration of IStorage in InterpreterWatchQuery
|
2022-01-10 22:01:41 +03:00 |
IInterpreterUnionOrSelectQuery.h
|
Fix performance regression of scalar query
|
2022-04-06 17:50:22 +08:00 |
IJoin.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00:00 |
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
|
|
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
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InternalTextLogsQueue.h
|
|
|
InterpreterAlterQuery.cpp
|
Fixed clang-tidy check "bugprone-branch-clone"
|
2022-04-30 19:40:28 +02:00 |
InterpreterAlterQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterBackupQuery.cpp
|
Fix build again
|
2022-04-29 14:45:27 +08:00 |
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterCheckQuery.h
|
|
|
InterpreterCreateFunctionQuery.cpp
|
Validate that function had been passed in CREATE FUNCTION
|
2022-05-01 19:01:03 +03:00 |
InterpreterCreateFunctionQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
Merge pull request #36803 from CurtizJ/fix-unflatten-nested
|
2022-05-02 13:58:16 +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 |
InterpreterDescribeQuery.cpp
|
use snapshots for semistructured data, durability fixes
|
2022-03-17 18:26:18 +01:00 |
InterpreterDescribeQuery.h
|
|
|
InterpreterDropFunctionQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterDropQuery.h
|
|
|
InterpreterExistsQuery.cpp
|
|
|
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
Merge branch 'master' into master2
|
2022-04-13 11:51:43 +00:00 |
InterpreterExplainQuery.h
|
add EXPLAIN CURRENT TRANSACTION
|
2022-02-14 22:47:17 +03:00 |
InterpreterExternalDDLQuery.cpp
|
|
|
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
|
|
InterpreterFactory.h
|
|
|
InterpreterInsertQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterInsertQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterKillQueryQuery.cpp
|
Add shard_index and replica_index to params of executeDDLQueryOnCluster().
|
2022-04-25 16:34:33 +02:00 |
InterpreterKillQueryQuery.h
|
|
|
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
|
|
|
InterpreterSelectIntersectExceptQuery.cpp
|
Better scalar cache handling
|
2022-01-26 17:36:45 +01:00 |
InterpreterSelectIntersectExceptQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
InterpreterSelectQuery.h
|
Made parallel_reading_from_replicas work with localhost replica (#36281)
|
2022-04-22 15:52:38 +02:00 |
InterpreterSelectWithUnionQuery.cpp
|
Fix various clang-tidy warnings
|
2022-04-20 10:29:05 +02:00 |
InterpreterSelectWithUnionQuery.h
|
throw exception on non-transactional queries
|
2022-02-01 01:27:55 +03:00 |
InterpreterSetQuery.cpp
|
|
|
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
|
|
|
InterpreterShowProcesslistQuery.cpp
|
|
|
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowTablesQuery.cpp
|
|
|
InterpreterShowTablesQuery.h
|
|
|
InterpreterSystemQuery.cpp
|
Merge pull request #36802 from KinderRiven/local_cache_trace
|
2022-05-02 00:16:04 +02:00 |
InterpreterSystemQuery.h
|
Added SYSTEM SYNC DATABASE query (#35944)
|
2022-05-01 15:40:18 +02:00 |
InterpreterTransactionControlQuery.cpp
|
more introspection
|
2022-03-18 14:33:59 +01:00 |
InterpreterTransactionControlQuery.h
|
more introspection
|
2022-03-18 14:33:59 +01:00 |
InterpreterUseQuery.cpp
|
|
|
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Forward declaration of IStorage in InterpreterWatchQuery
|
2022-01-10 22:01:41 +03:00 |
InterpreterWatchQuery.h
|
Forward declaration of IStorage in InterpreterWatchQuery
|
2022-01-10 22:01:41 +03:00 |
interpretSubquery.cpp
|
|
|
interpretSubquery.h
|
|
|
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
|
|
|
ITokenExtractor.cpp
|
|
|
ITokenExtractor.h
|
|
|
join_common.cpp
|
Fix assertion in join
|
2022-04-29 09:15:00 +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
|
|
|
JoinedTables.cpp
|
Get rid of duplicate query planing.
|
2022-03-08 00:02:58 +08:00 |
JoinedTables.h
|
Minimize changes, improve scalar subquery for MVs
|
2022-01-26 17:36:45 +01:00 |
JoinSwitcher.cpp
|
|
|
JoinSwitcher.h
|
|
|
JoinToSubqueryTransformVisitor.cpp
|
Merge branch 'master' into fixcolumnmatcher
|
2022-04-21 02:15:25 +03:00 |
JoinToSubqueryTransformVisitor.h
|
|
|
Lemmatizers.cpp
|
|
|
Lemmatizers.h
|
|
|
loadMetadata.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
loadMetadata.h
|
|
|
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
|
|
|
MarkTableIdentifiersVisitor.h
|
|
|
MergeJoin.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
MergeJoin.h
|
Remove nullable_left/right_side flags from Hash/MergeJoin
|
2022-02-15 11:15:50 +00:00 |
MergeTreeTransaction.cpp
|
slightly beter fix
|
2022-04-11 16:25:59 +02:00 |
MergeTreeTransaction.h
|
fix a race condition
|
2022-04-07 18:17:43 +02:00 |
MergeTreeTransactionHolder.cpp
|
review fixes
|
2022-03-16 21:05:34 +01: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
|
|
|
MonotonicityCheckVisitor.h
|
|
|
MutationsInterpreter.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
MutationsInterpreter.h
|
|
|
NormalizeSelectWithUnionQueryVisitor.cpp
|
|
|
NormalizeSelectWithUnionQueryVisitor.h
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Improve the opentelemetry span logs for INSERT on distributed table (#34480)
|
2022-03-03 12:53:29 +01:00 |
OpenTelemetrySpanLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:53:28 +02:00 |
OptimizeIfChains.cpp
|
|
|
OptimizeIfChains.h
|
|
|
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 optimize_skip_unused_shards_rewrite_in for signed columns
|
2022-03-09 08:29:28 +03:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
PartLog.cpp
|
Remove microseconds from system.asynchronous_metric_log
|
2022-04-17 22:01:58 +02:00 |
PartLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
PredicateExpressionsOptimizer.cpp
|
|
|
PredicateExpressionsOptimizer.h
|
|
|
PredicateRewriteVisitor.cpp
|
Fix column matcher and column transformer
|
2022-04-20 01:22:04 +08:00 |
PredicateRewriteVisitor.h
|
|
|
PreparedSets.h
|
|
|
processColumnTransformers.cpp
|
revert unnecesarry change
|
2022-02-08 00:14:15 +00:00 |
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Revert "Revert "Memory overcommit: continue query execution if memory is available""
|
2022-05-03 00:45:13 +02: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
|
|
|
QueryParameterVisitor.h
|
|
|
QueryPriorities.h
|
|
|
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
|
|
|
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
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
|
|
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
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
|
|
|
RequiredSourceColumnsVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
RequiredSourceColumnsVisitor.h
|
|
|
RewriteAnyFunctionVisitor.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
RewriteAnyFunctionVisitor.h
|
|
|
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
|
|
|
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
|
|
|
RewriteSumIfFunctionVisitor.cpp
|
Fix sumIf rewrite
|
2022-01-16 06:25:11 +00:00 |
RewriteSumIfFunctionVisitor.h
|
|
|
RowRefs.cpp
|
Use proper type for RadixSortTraits in RowRefs.cpp
|
2022-03-27 11:32:51 +03:00 |
RowRefs.h
|
Improve performance of ASOF join
|
2022-03-23 12:19:38 +01:00 |
SelectIntersectExceptQueryVisitor.cpp
|
|
|
SelectIntersectExceptQueryVisitor.h
|
|
|
SelectQueryOptions.h
|
Don't materialize external tables if it's explain statement
|
2022-04-08 09:00:55 +08:00 |
Session.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
Session.h
|
Polish TCP is_secure flag
|
2022-03-30 06:39:40 +00:00 |
SessionLog.cpp
|
Fixed missing enum values for ClientInfo::Interface
|
2022-04-21 12:16:12 +03:00 |
SessionLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
Set.cpp
|
Make SortDescription::column_name always non-empty (#35805)
|
2022-04-04 14:17:15 +02:00 |
Set.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
SetVariants.cpp
|
|
|
SetVariants.h
|
|
|
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
|
Fix tests naming, remove code duplication
|
2022-02-07 14:12:19 +03:00 |
SortedBlocksWriter.h
|
|
|
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
|
|
|
StorageID.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +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
|
|
|
SubstituteColumnOptimizer.h
|
|
|
SynonymsExtensions.cpp
|
|
|
SynonymsExtensions.h
|
|
|
SystemLog.cpp
|
fix
|
2022-05-01 19:45:16 +08:00 |
SystemLog.h
|
fix
|
2022-05-01 19:45:16 +08:00 |
TableJoin.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TableJoin.h
|
base should not depend on Common
|
2022-04-29 10:26:35 +08: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
|
|
|
TablesStatus.h
|
|
|
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
|
Remove outdated comment from ThreadStatusExt
|
2022-04-29 17:04:56 +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
|
|
|
TraceLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |
TransactionLog.cpp
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TransactionLog.h
|
try fix build with gcc
|
2022-03-30 17:42:47 +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
|
base should not depend on Common
|
2022-04-29 10:26:35 +08:00 |
TransactionVersionMetadata.h
|
more comments, minor fixes
|
2022-03-18 12:01:26 +01:00 |
TranslateQualifiedNamesVisitor.cpp
|
Update TranslateQualifiedNamesVisitor.cpp
|
2022-04-24 05:04:13 +03:00 |
TranslateQualifiedNamesVisitor.h
|
Fix clang-tidy warnings in Interpreters, IO folders
|
2022-03-14 18:17:35 +00: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
|
Merge pull request #36486 from kitaisreal/executable-user-defined-functions-fix-group-by
|
2022-04-24 06:11:57 +03:00 |
TreeOptimizer.h
|
|
|
TreeRewriter.cpp
|
Merge pull request #36444 from rschu1ze/clang-tidy-fixes
|
2022-04-21 16:11:27 +02:00 |
TreeRewriter.h
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2022-02-25 13:41:30 +03:00 |
UserDefinedExecutableFunction.cpp
|
|
|
UserDefinedExecutableFunction.h
|
Added tests
|
2022-02-18 15:21:11 +00:00 |
UserDefinedExecutableFunctionFactory.cpp
|
Throw exception when file cant be executed instead of displaying success
|
2022-04-12 17:52:44 +02:00 |
UserDefinedExecutableFunctionFactory.h
|
|
|
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
|
|
|
UserDefinedSQLObjectsLoader.cpp
|
Merge pull request #36715 from amosbird/refactorbase
|
2022-04-30 09:40:58 +03:00 |
UserDefinedSQLObjectsLoader.h
|
SQLUserDefinedFunctions support CREATE OR REPLACE, CREATE IF NOT EXISTS
|
2021-10-20 17:56:46 +03:00 |
WhereConstraintsOptimizer.cpp
|
|
|
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
|
|
WindowDescription.h
|
|
|
ZooKeeperLog.cpp
|
add thread_id and query_id to zookeeper_log
|
2022-04-08 17:10:08 +02:00 |
ZooKeeperLog.h
|
Custom column list for system.asynchronous_metric_log
|
2022-04-17 23:49:39 +02:00 |