ClickHouse/src/Interpreters
2023-06-09 16:23:22 +00:00
..
Access Merge branch 'master' into feature/show-secrets-option 2023-04-28 20:19:35 +03:00
Cache Merge branch 'master' into fix-cache-slow-with-insert 2023-06-08 10:49:46 +02:00
ClusterProxy
examples Do not use PackedHashMap for non-POD for the purposes of layout 2023-05-19 06:07:21 +02:00
fuzzers
JIT
MySQL
tests Update src/Interpreters/tests/gtest_convertFieldToType.cpp 2023-06-06 18:28:34 +02:00
ActionLocksManager.cpp
ActionLocksManager.h
ActionsDAG.cpp Merge branch 'master' into aiven-sal/having_pr 2023-05-08 05:53:38 +03:00
ActionsDAG.h Merge pull request #48427 from ClickHouse/update_sort_desc_follow_up 2023-04-12 13:59:37 +02:00
ActionsVisitor.cpp Fix parameterized views when query parameter used multiple times in the query 2023-05-16 15:13:21 +02:00
ActionsVisitor.h Do not skip building set even when reading from remote 2023-05-02 21:31:56 +02:00
AddDefaultDatabaseVisitor.h
AddIndexConstraintsOptimizer.cpp
AddIndexConstraintsOptimizer.h
addMissingDefaults.cpp
addMissingDefaults.h
addTypeConversionToAST.cpp
addTypeConversionToAST.h
AggregateDescription.cpp
AggregateDescription.h
AggregateFunctionOfGroupByKeysVisitor.h
AggregationCommon.h Reduce inter-header dependencies 2023-05-02 21:15:18 +02:00
AggregationUtils.cpp
AggregationUtils.h
Aggregator.cpp JIT aggregation nullable key fix 2023-05-28 21:05:17 +03:00
Aggregator.h Merge remote-tracking branch 'blessed/master' into arenita 2023-04-24 10:42:56 +02:00
Aliases.h
applyTableOverride.cpp
applyTableOverride.h
ApplyWithAliasVisitor.cpp
ApplyWithAliasVisitor.h
ApplyWithGlobalVisitor.cpp
ApplyWithGlobalVisitor.h
ApplyWithSubqueryVisitor.cpp
ApplyWithSubqueryVisitor.h
ArithmeticOperationsInAgrFuncOptimize.cpp
ArithmeticOperationsInAgrFuncOptimize.h
ArrayJoinAction.cpp
ArrayJoinAction.h
ArrayJoinedColumnsVisitor.h
AsynchronousInsertLog.cpp add field with number of rows to async insert log 2023-04-25 00:31:55 +00:00
AsynchronousInsertLog.h Remove the duplicate pair of parentheses 2023-05-28 12:59:34 +08:00
AsynchronousInsertQueue.cpp Fixes for clang-17 2023-05-13 02:57:31 +02:00
AsynchronousInsertQueue.h Another atempt to fix test 2023-05-02 18:51:36 +00:00
AsynchronousMetricLog.cpp
AsynchronousMetricLog.h Remove the duplicate pair of parentheses 2023-05-28 12:59:34 +08:00
BloomFilter.cpp
BloomFilter.h
BloomFilterHash.h
CancellationCode.h
castColumn.cpp
castColumn.h
ClientInfo.cpp
ClientInfo.h
Cluster.cpp fix comment 2023-05-19 17:53:22 +00:00
Cluster.h
ClusterDiscovery.cpp Update src/Interpreters/ClusterDiscovery.cpp 2023-05-25 13:06:40 +02:00
ClusterDiscovery.h support passing fqdn to register cluster node in keeper 2023-05-20 12:41:48 +08:00
CMakeLists.txt
CollectJoinOnKeysVisitor.cpp
CollectJoinOnKeysVisitor.h
ColumnAliasesVisitor.cpp
ColumnAliasesVisitor.h
ComparisonGraph.cpp
ComparisonGraph.h
ComparisonTupleEliminationVisitor.cpp
ComparisonTupleEliminationVisitor.h
ConcurrentHashJoin.cpp
ConcurrentHashJoin.h
Context_fwd.h
Context.cpp Desctructing --> Destructing 2023-06-09 16:23:22 +00:00
Context.h Merge pull request #46661 from ClickHouse/42192_Lower_parallel_parsing_threads_with_globs 2023-05-30 08:53:08 +02:00
convertFieldToType.cpp Merge pull request #50280 from lucas-tubi/fix-datetime64-index-scaning 2023-06-08 07:10:55 +02:00
convertFieldToType.h
ConvertFunctionOrLikeVisitor.cpp
ConvertFunctionOrLikeVisitor.h
ConvertStringsToEnumVisitor.cpp
ConvertStringsToEnumVisitor.h
CrashLog.cpp
CrashLog.h
createBlockSelector.cpp
createBlockSelector.h
CrossToInnerJoinVisitor.cpp
CrossToInnerJoinVisitor.h
DatabaseAndTableWithAlias.cpp
DatabaseAndTableWithAlias.h
DatabaseCatalog.cpp
DatabaseCatalog.h
DDLTask.cpp Preserve initial_query_id for ON CLUSTER queries 2023-05-21 23:04:54 +02:00
DDLTask.h Preserve initial_query_id for ON CLUSTER queries 2023-05-21 23:04:54 +02:00
DDLWorker.cpp Preserve initial_query_id for ON CLUSTER queries 2023-05-21 23:04:54 +02:00
DDLWorker.h
DirectJoin.cpp
DirectJoin.h
DNSCacheUpdater.cpp
DNSCacheUpdater.h
DuplicateOrderByVisitor.cpp
DuplicateOrderByVisitor.h
EmbeddedDictionaries.cpp
EmbeddedDictionaries.h
evaluateConstantExpression.cpp
evaluateConstantExpression.h
executeDDLQueryOnCluster.cpp Preserve initial_query_id for ON CLUSTER queries 2023-05-21 23:04:54 +02:00
executeDDLQueryOnCluster.h
executeQuery.cpp Merge branch 'master' into optimize_reading2 2023-05-29 15:26:18 +02:00
executeQuery.h
ExecuteScalarSubqueriesVisitor.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
ExecuteScalarSubqueriesVisitor.h refactoring near alter conversions 2023-05-25 22:54:54 +00:00
ExpressionActions.cpp Check getData() result in other places 2023-04-18 17:11:19 +02:00
ExpressionActions.h
ExpressionActionsSettings.cpp
ExpressionActionsSettings.h Fix performance, make only one setting 2021-08-16 14:30:56 +03:00
ExpressionAnalyzer.cpp Pure parallel replicas: JOIN support (#49544) 2023-05-26 01:04:24 +02:00
ExpressionAnalyzer.h Pure parallel replicas: JOIN support (#49544) 2023-05-26 01:04:24 +02:00
ExpressionJIT.cpp
ExternalDictionariesLoader.cpp trivial change 2023-05-11 13:49:02 +02:00
ExternalDictionariesLoader.h address comments 2023-05-10 17:42:08 +02:00
ExternalLoader.cpp Charge only server memory for dictionaries 2023-05-21 22:53:52 +02:00
ExternalLoader.h
ExternalLoaderDatabaseConfigRepository.h
ExternalLoaderDictionaryStorageConfigRepository.cpp
ExternalLoaderDictionaryStorageConfigRepository.h
ExternalLoaderTempConfigRepository.cpp
ExternalLoaderTempConfigRepository.h
ExternalLoaderXMLConfigRepository.cpp
ExternalLoaderXMLConfigRepository.h
ExtractExpressionInfoVisitor.cpp
ExtractExpressionInfoVisitor.h
FilesystemCacheLog.cpp
FilesystemCacheLog.h
FilesystemReadPrefetchesLog.cpp Merge branch 'master' into optimize_reading2 2023-05-28 18:04:44 +02:00
FilesystemReadPrefetchesLog.h Merge branch 'master' into optimize_reading2 2023-05-28 18:04:44 +02:00
FillingRow.cpp Fix suffix generation (see added test in commit 3355894) 2023-05-14 15:52:49 +00:00
FillingRow.h Fix suffix generation (see added test in commit 3355894) 2023-05-14 15:52:49 +00:00
formatWithPossiblyHidingSecrets.h separate name for format setting 2023-04-28 13:39:38 +00:00
FullSortingMergeJoin.h
FunctionMaskingArgumentCheckVisitor.h
FunctionNameNormalizer.cpp
FunctionNameNormalizer.h
GatherFunctionQuantileVisitor.cpp
GatherFunctionQuantileVisitor.h
GetAggregatesVisitor.cpp
GetAggregatesVisitor.h
getClusterName.cpp
getClusterName.h
getColumnFromBlock.cpp
getColumnFromBlock.h
getCustomKeyFilterForParallelReplicas.cpp
getCustomKeyFilterForParallelReplicas.h
getHeaderForProcessingStage.cpp
getHeaderForProcessingStage.h
getTableExpressions.cpp
getTableExpressions.h
getTableOverride.cpp
getTableOverride.h
GinFilter.cpp
GinFilter.h
GlobalSubqueriesVisitor.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
GraceHashJoin.cpp fixed. without apply prepareRightBlock will cause mismatch block structure 2023-06-01 08:10:28 +08:00
GraceHashJoin.h try to reserve hash table size 2023-05-22 17:42:38 +08:00
GroupByFunctionKeysVisitor.h
GroupingSetsRewriterVisitor.cpp
GroupingSetsRewriterVisitor.h
HashJoin.cpp Fixes for LowCardinality Nullable in HashJoin 2023-06-07 20:16:36 +02:00
HashJoin.h update 2023-05-22 17:45:18 +08:00
IdentifierSemantic.cpp
IdentifierSemantic.h
IExternalLoadable.cpp
IExternalLoadable.h
IExternalLoaderConfigRepository.h
IInterpreter.cpp
IInterpreter.h
IInterpreterUnionOrSelectQuery.cpp
IInterpreterUnionOrSelectQuery.h
IJoin.h
IKeyValueEntity.h
InDepthNodeVisitor.h
InJoinSubqueriesPreprocessor.cpp
InJoinSubqueriesPreprocessor.h Fix clang-tidy warnings in Interpreters, IO folders 2022-03-14 18:17:35 +00:00
inplaceBlockConversions.cpp
inplaceBlockConversions.h
InternalTextLogsQueue.cpp Modernize InternalTextLogsQueue::getPriorityName() 2023-01-20 11:09:35 +01:00
InternalTextLogsQueue.h
InterpreterAlterNamedCollectionQuery.cpp
InterpreterAlterNamedCollectionQuery.h
InterpreterAlterQuery.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
InterpreterAlterQuery.h
InterpreterBackupQuery.cpp
InterpreterBackupQuery.h
InterpreterCheckQuery.cpp
InterpreterCheckQuery.h
InterpreterCreateFunctionQuery.cpp
InterpreterCreateFunctionQuery.h
InterpreterCreateIndexQuery.cpp
InterpreterCreateIndexQuery.h
InterpreterCreateNamedCollectionQuery.cpp
InterpreterCreateNamedCollectionQuery.h
InterpreterCreateQuery.cpp Fix crashing in case of Replicated database without arguments 2023-05-21 23:12:39 +02:00
InterpreterCreateQuery.h
InterpreterDeleteQuery.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
InterpreterDeleteQuery.h
InterpreterDescribeCacheQuery.cpp
InterpreterDescribeCacheQuery.h
InterpreterDescribeQuery.cpp
InterpreterDescribeQuery.h
InterpreterDropFunctionQuery.cpp
InterpreterDropFunctionQuery.h
InterpreterDropIndexQuery.cpp
InterpreterDropIndexQuery.h
InterpreterDropNamedCollectionQuery.cpp
InterpreterDropNamedCollectionQuery.h
InterpreterDropQuery.cpp
InterpreterDropQuery.h
InterpreterExistsQuery.cpp
InterpreterExistsQuery.h
InterpreterExplainQuery.cpp
InterpreterExplainQuery.h
InterpreterExternalDDLQuery.cpp
InterpreterExternalDDLQuery.h
InterpreterFactory.cpp Add new profile events for queries with subqueries 2023-05-26 18:28:40 +02:00
InterpreterFactory.h
InterpreterInsertQuery.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
InterpreterInsertQuery.h Make INSERT do more things in parallel to avoid getting bottlenecked on one thread 2023-05-05 00:49:27 +00:00
InterpreterKillQueryQuery.cpp
InterpreterKillQueryQuery.h
InterpreterOptimizeQuery.cpp
InterpreterOptimizeQuery.h
InterpreterRenameQuery.cpp
InterpreterRenameQuery.h
InterpreterSelectIntersectExceptQuery.cpp
InterpreterSelectIntersectExceptQuery.h
InterpreterSelectQuery.cpp Disable pure parallel replicas if trivial count optimization is possible (#50594) 2023-06-06 18:38:32 +02:00
InterpreterSelectQuery.h Disable pure parallel replicas if trivial count optimization is possible (#50594) 2023-06-06 18:38:32 +02:00
InterpreterSelectQueryAnalyzer.cpp
InterpreterSelectQueryAnalyzer.h
InterpreterSelectWithUnionQuery.cpp
InterpreterSelectWithUnionQuery.h
InterpreterSetQuery.cpp
InterpreterSetQuery.h
InterpreterShowColumnsQuery.cpp More protection against SQL injection 2023-05-05 13:58:08 +00:00
InterpreterShowColumnsQuery.h
InterpreterShowCreateQuery.cpp
InterpreterShowCreateQuery.h
InterpreterShowEngineQuery.cpp
InterpreterShowEngineQuery.h
InterpreterShowIndexesQuery.cpp More protection against SQL injection 2023-05-05 13:58:08 +00:00
InterpreterShowIndexesQuery.h Initial version of SHOW INDEXES 2023-04-25 20:48:11 +00:00
InterpreterShowProcesslistQuery.cpp
InterpreterShowProcesslistQuery.h
InterpreterShowTablesQuery.cpp Simplify FileCacheFactory 2023-04-15 16:15:20 +02:00
InterpreterShowTablesQuery.h
InterpreterSystemQuery.cpp Merge branch 'master' into hanfei/fiu 2023-05-09 01:14:30 +02:00
InterpreterSystemQuery.h
InterpreterTransactionControlQuery.cpp
InterpreterTransactionControlQuery.h
InterpreterUndropQuery.cpp
InterpreterUndropQuery.h
InterpreterUseQuery.cpp Move access-rights' source files needed for parser to a separate target. 2021-11-01 19:13:49 +03:00
InterpreterUseQuery.h
InterpreterWatchQuery.cpp
InterpreterWatchQuery.h
interpretSubquery.cpp Pure parallel replicas: JOIN support (#49544) 2023-05-26 01:04:24 +02:00
interpretSubquery.h
InterserverCredentials.cpp
InterserverCredentials.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
InterserverIOHandler.h
ITokenExtractor.cpp
ITokenExtractor.h
joinDispatch.h
JoinedTables.cpp
JoinedTables.h
JoinSwitcher.cpp
JoinSwitcher.h
JoinToSubqueryTransformVisitor.cpp
JoinToSubqueryTransformVisitor.h
JoinUtils.cpp Fixes for LowCardinality Nullable in HashJoin 2023-06-07 20:16:36 +02:00
JoinUtils.h
Lemmatizers.cpp
Lemmatizers.h
loadMetadata.cpp
loadMetadata.h
LogicalExpressionsOptimizer.cpp
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp
MarkTableIdentifiersVisitor.h
MergeJoin.cpp
MergeJoin.h
MergeTreeTransaction.cpp fix some tests 2023-04-14 19:42:17 +02:00
MergeTreeTransaction.h
MergeTreeTransactionHolder.cpp
MergeTreeTransactionHolder.h
MetricLog.cpp
MetricLog.h
misc.h
MonotonicityCheckVisitor.h
MutationsInterpreter.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
MutationsInterpreter.h refactoring near alter conversions 2023-05-25 22:54:54 +00:00
MutationsNonDeterministicHelpers.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
MutationsNonDeterministicHelpers.h refactoring near alter conversions 2023-05-25 22:54:54 +00:00
NormalizeSelectWithUnionQueryVisitor.cpp
NormalizeSelectWithUnionQueryVisitor.h
NullableUtils.cpp
NullableUtils.h
OpenTelemetrySpanLog.cpp Optimize opentelemetry_span_log 2023-05-08 05:15:28 +02:00
OpenTelemetrySpanLog.h
OptimizeIfChains.cpp
OptimizeIfChains.h
OptimizeIfWithConstantConditionVisitor.cpp
OptimizeIfWithConstantConditionVisitor.h
OptimizeShardingKeyRewriteInVisitor.cpp
OptimizeShardingKeyRewriteInVisitor.h
parseColumnsListForTableFunction.cpp Geo types are production ready 2023-05-19 12:43:55 +02:00
parseColumnsListForTableFunction.h Geo types are production ready 2023-05-19 12:43:55 +02:00
PartLog.cpp add aliases for parts name and names 2023-04-17 13:18:40 +00:00
PartLog.h
PredicateExpressionsOptimizer.cpp
PredicateExpressionsOptimizer.h
PredicateRewriteVisitor.cpp
PredicateRewriteVisitor.h
PreparedSets.cpp Cleanups 2023-04-14 20:07:37 +02:00
PreparedSets.h Cleanups 2023-04-14 20:07:37 +02:00
processColumnTransformers.cpp
processColumnTransformers.h
ProcessList.cpp
ProcessList.h
ProcessorsProfileLog.cpp Add 'initial_query_id' field for system.processors_profile_log 2023-05-25 09:37:02 +08:00
ProcessorsProfileLog.h Add 'initial_query_id' field for system.processors_profile_log 2023-05-25 09:37:02 +08:00
ProfileEventsExt.cpp
ProfileEventsExt.h
QueryAliasesVisitor.cpp
QueryAliasesVisitor.h
QueryLog.cpp Add 'partitions' field for system.query_log 2023-05-24 20:42:31 +08:00
QueryLog.h Add 'partitions' field for system.query_log 2023-05-24 20:42:31 +08:00
QueryNormalizer.cpp
QueryNormalizer.h
QueryPriorities.h
QueryThreadLog.cpp Optimize the system.query_log and system.query_thread_log tables by applying LowCardinality when appropriate 2023-05-05 01:36:01 +02:00
QueryThreadLog.h
QueryViewsLog.cpp
QueryViewsLog.h Switch Block::NameMap to google::dense_hash_map over HashMap 2023-05-12 05:52:57 +02:00
RedundantFunctionsInOrderByVisitor.h
RemoveInjectiveFunctionsVisitor.cpp
RemoveInjectiveFunctionsVisitor.h
RenameColumnVisitor.cpp
RenameColumnVisitor.h
replaceAliasColumnsInQuery.cpp
replaceAliasColumnsInQuery.h
replaceForPositionalArguments.cpp
replaceForPositionalArguments.h
ReplaceQueryParameterVisitor.cpp Add the context to the exception message about query paramters 2023-04-23 09:34:12 +02:00
ReplaceQueryParameterVisitor.h
RequiredSourceColumnsData.cpp
RequiredSourceColumnsData.h
RequiredSourceColumnsVisitor.cpp
RequiredSourceColumnsVisitor.h
RewriteAnyFunctionVisitor.cpp
RewriteAnyFunctionVisitor.h
RewriteArrayExistsFunctionVisitor.cpp
RewriteArrayExistsFunctionVisitor.h
RewriteCountDistinctVisitor.cpp
RewriteCountDistinctVisitor.h
RewriteCountVariantsVisitor.cpp
RewriteCountVariantsVisitor.h
RewriteFunctionToSubcolumnVisitor.cpp
RewriteFunctionToSubcolumnVisitor.h
RewriteOrderByVisitor.cpp Fix: rewrite only outer braces 2022-07-06 10:23:05 +00:00
RewriteOrderByVisitor.hpp
RewriteSumIfFunctionVisitor.cpp
RewriteSumIfFunctionVisitor.h
RowRefs.cpp
RowRefs.h
SelectIntersectExceptQueryVisitor.cpp
SelectIntersectExceptQueryVisitor.h
SelectQueryOptions.h
ServerAsynchronousMetrics.cpp
ServerAsynchronousMetrics.h
Session.cpp
Session.h Separate AuthenticationData and AuthenticationType, small fixes 2023-04-24 15:12:45 +00:00
SessionLog.cpp Fix bcrypt enum value 2023-05-02 14:36:48 +00:00
SessionLog.h Separate AuthenticationData and AuthenticationType, small fixes 2023-04-24 15:12:45 +00:00
Set.cpp Cleanups 2023-04-14 16:12:18 +02:00
Set.h Cleanups 2023-04-14 16:12:18 +02:00
SetVariants.cpp
SetVariants.h
sortBlock.cpp
sortBlock.h
SortedBlocksWriter.cpp Enhancements for background merges (#49313) 2023-05-02 13:43:59 +02:00
SortedBlocksWriter.h
SquashingTransform.cpp
SquashingTransform.h
StorageID.cpp
StorageID.h
SubstituteColumnOptimizer.cpp
SubstituteColumnOptimizer.h
SynonymsExtensions.cpp
SynonymsExtensions.h
SystemLog.cpp Add 'settings' expression for system log tables 2023-05-28 12:59:34 +08:00
SystemLog.h
TableJoin.cpp Allow ASOF JOIN over nullable right column 2023-05-16 16:23:53 +02:00
TableJoin.h Fixes for LowCardinality Nullable in HashJoin 2023-06-07 20:16:36 +02:00
TableOverrideUtils.cpp
TableOverrideUtils.h
TablesStatus.cpp
TablesStatus.h
TemporaryDataOnDisk.cpp Fix incorrectly resolved conflicts after merge with master 2023-04-23 12:37:04 +02:00
TemporaryDataOnDisk.h Merge remote-tracking branch 'upstream/master' into cache-better-locks 2023-04-22 17:14:50 +02:00
TextLog.cpp
TextLog.h
threadPoolCallbackRunner.h Rework loading and removing of data parts for MergeTree tables. (#49474) 2023-06-06 14:42:56 +02:00
ThreadStatusExt.cpp Merge pull request #48787 from ClickHouse/background-memory-tracker 2023-05-09 07:58:36 +03:00
TraceCollector.cpp removed unnecessary check for thread's joinability 2023-05-09 19:43:39 +00:00
TraceCollector.h close pipe in run() if exception happens 2023-05-08 23:00:20 +00:00
TraceLog.cpp
TraceLog.h
TransactionLog.cpp
TransactionLog.h
TransactionsInfoLog.cpp
TransactionsInfoLog.h
TransactionVersionMetadata.cpp
TransactionVersionMetadata.h
TranslateQualifiedNamesVisitor.cpp
TranslateQualifiedNamesVisitor.h
TreeCNFConverter.cpp
TreeCNFConverter.h
TreeOptimizer.cpp Revert "Merge pull request #50062 from ZhiguoZh/20230511-toyear" 2023-06-06 16:10:22 +02:00
TreeOptimizer.h fix crash with multiif and constant condition and nullable arguments 2023-05-22 23:31:50 +00:00
TreeRewriter.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
TreeRewriter.h
WhereConstraintsOptimizer.cpp
WhereConstraintsOptimizer.h
WindowDescription.cpp
WindowDescription.h
ZooKeeperLog.cpp Update enum for ZooKeeperLog 2023-04-19 14:07:38 +02:00
ZooKeeperLog.h