ClickHouse/dbms/src/Interpreters
2020-02-17 22:28:25 +03:00
..
ClusterProxy Try fix test 2019-11-08 20:30:56 +03:00
tests move databases from Context to DatabaseCatalog 2020-02-10 17:49:44 +03:00
ActionLocksManager.cpp move databases from Context to DatabaseCatalog 2020-02-10 17:49:44 +03:00
ActionLocksManager.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
ActionsVisitor.cpp Merge remote-tracking branch 'upstream/master' into memory-profiler 2020-02-03 16:21:21 +03:00
ActionsVisitor.h Some InterpreterSelectQuery refactoring (#9035) 2020-02-10 18:50:12 +03:00
AddDefaultDatabaseVisitor.h Fix some spelling mistakes 2020-01-11 17:51:33 +08:00
addMissingDefaults.cpp
addMissingDefaults.h
addTypeConversionToAST.cpp
addTypeConversionToAST.h
AggregateDescription.h
AggregationCommon.h
Aggregator.cpp Add ability to use multiple disks/volumes for temporary data 2020-01-23 20:31:01 +03:00
Aggregator.h Add ability to use multiple disks/volumes for temporary data 2020-01-23 20:31:01 +03:00
Aliases.h
AnalyzedJoin.cpp better compatibility in EngineJoin 2020-02-02 19:12:48 +03:00
AnalyzedJoin.h better compatibility in EngineJoin 2020-02-02 19:12:48 +03:00
ArrayJoinAction.cpp ExpressionActions refactoring: extract ArrayJoinAction class (#8998) 2020-02-05 13:12:19 +03:00
ArrayJoinAction.h ExpressionActions refactoring: extract ArrayJoinAction class (#8998) 2020-02-05 13:12:19 +03:00
ArrayJoinedColumnsVisitor.h
asof.h
AsteriskSemantic.h
AsynchronousMetrics.cpp move databases from Context to DatabaseCatalog 2020-02-10 17:49:44 +03:00
AsynchronousMetrics.h
BloomFilter.cpp fixup 2020-01-10 14:16:14 +03:00
BloomFilter.h
BloomFilterHash.h Merge branch 'master' into fix/ISSUES-8317 2020-01-11 23:16:52 +08:00
CancellationCode.h
castColumn.cpp Remove context from formats (#8388) 2019-12-25 22:17:41 +03:00
castColumn.h Remove context from formats (#8388) 2019-12-25 22:17:41 +03:00
CatBoostModel.cpp
CatBoostModel.h Use separate variables for the database and name in dictionaries. 2019-12-29 23:48:10 +07:00
ClientInfo.cpp
ClientInfo.h
Cluster.cpp Update Cluster.cpp 2020-02-16 07:12:48 +03:00
Cluster.h Update Cluster.h 2020-02-16 07:13:54 +03:00
CMakeLists.txt
CollectJoinOnKeysVisitor.cpp relax ambiguous column check for multiple JOIN ON section 2019-12-24 21:51:37 +03:00
CollectJoinOnKeysVisitor.h relax ambiguous column check for multiple JOIN ON section 2019-12-24 21:51:37 +03:00
ColumnNamesContext.cpp
ColumnNamesContext.h
Context.cpp better get... methods 2020-02-17 16:52:59 +03:00
Context.h better get... methods 2020-02-17 16:52:59 +03:00
convertFieldToType.cpp Fix some spelling mistakes 2020-01-11 17:51:33 +08:00
convertFieldToType.h
createBlockSelector.cpp
createBlockSelector.h
CrossToInnerJoinVisitor.cpp Fix some spelling mistakes 2020-01-11 17:51:33 +08:00
CrossToInnerJoinVisitor.h
DatabaseAndTableWithAlias.cpp move one more function 2019-12-12 19:54:04 +03:00
DatabaseAndTableWithAlias.h try fix some predicate optimizer bug 2020-01-02 21:14:48 +08:00
DatabaseCatalog.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
DatabaseCatalog.h less Context::getTable() usages 2020-02-17 22:28:25 +03:00
DDLWorker.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
DDLWorker.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
DNSCacheUpdater.cpp
DNSCacheUpdater.h
EmbeddedDictionaries.cpp c++20! 2019-12-29 03:08:25 +08:00
EmbeddedDictionaries.h
evaluateConstantExpression.cpp
evaluateConstantExpression.h
evaluateMissingDefaults.cpp
evaluateMissingDefaults.h
executeQuery.cpp Using OS tid everywhere #7477 2020-02-02 05:28:14 +03:00
executeQuery.h Set X-ClickHouse-Format HTTP response header to the format name 2020-01-22 00:33:33 +05:30
ExecuteScalarSubqueriesVisitor.cpp Integration of log storages with IDisk interface 2019-12-23 16:11:56 +03:00
ExecuteScalarSubqueriesVisitor.h
ExpressionActions.cpp ExpressionActions refactoring: extract ArrayJoinAction class (#8998) 2020-02-05 13:12:19 +03:00
ExpressionActions.h ExpressionActions refactoring: extract ArrayJoinAction class (#8998) 2020-02-05 13:12:19 +03:00
ExpressionAnalyzer.cpp actualize ExpressionAnalyzer public interface 2020-02-10 22:55:13 +03:00
ExpressionAnalyzer.h actualize ExpressionAnalyzer public interface 2020-02-10 22:55:13 +03:00
ExpressionJIT.cpp cosmetic 2020-01-30 12:31:21 +01:00
ExpressionJIT.h Fix build. 2019-12-12 17:55:55 +03:00
ExternalDictionariesLoader.cpp Fix some spelling mistakes 2020-01-11 17:51:33 +08:00
ExternalDictionariesLoader.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalLoader.cpp Fix race when executing SYSTEM RELOAD ALL DICTIONARIES. 2020-01-23 16:35:12 +03:00
ExternalLoader.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalLoaderDatabaseConfigRepository.cpp Merge remote-tracking branch 'refs/remotes/upstream/master' into vfs_log 2020-01-02 18:01:41 +03:00
ExternalLoaderDatabaseConfigRepository.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalLoaderTempConfigRepository.cpp Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalLoaderTempConfigRepository.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalLoaderXMLConfigRepository.cpp Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalLoaderXMLConfigRepository.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalModelsLoader.cpp Fix typeo in ExternalModelsLoader. 2020-02-11 08:32:27 +03:00
ExternalModelsLoader.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
ExternalTablesVisitor.h better get... methods 2020-02-17 16:52:59 +03:00
ExtractExpressionInfoVisitor.cpp no skip lambda function 2020-01-07 11:31:03 +08:00
ExtractExpressionInfoVisitor.h fix lambda function in predicate 2020-01-06 18:38:48 +08:00
FillingRow.cpp
FillingRow.h
GetAggregatesVisitor.h
getClusterName.cpp
getClusterName.h
getTableExpressions.cpp More GCC warnings 2019-12-16 23:19:50 +02:00
getTableExpressions.h fix 'There's no column' error for materialized and alias columns 2019-12-13 21:46:55 +03:00
GlobalSubqueriesVisitor.h better constructors of storages 2019-12-26 20:04:08 +03:00
IdentifierSemantic.cpp relax ambiguous column check for multiple JOIN ON section 2019-12-24 21:51:37 +03:00
IdentifierSemantic.h relax ambiguous column check for multiple JOIN ON section 2019-12-24 21:51:37 +03:00
IExternalLoadable.cpp
IExternalLoadable.h Use separate variables for the database and name in dictionaries. 2019-12-29 23:48:10 +07:00
IExternalLoaderConfigRepository.h Automatic removing of config repositories to simplify the code. 2019-12-31 06:30:27 +07:00
IInterpreter.h Disable quota consumptions for the system queries and for selecting 2019-12-05 21:03:57 +03:00
IJoin.h rewrite with cursor position 2020-01-15 23:33:29 +03:00
InDepthNodeVisitor.h try fix some predicate optimizer bug 2020-01-02 21:14:48 +08:00
InJoinSubqueriesPreprocessor.cpp
InJoinSubqueriesPreprocessor.h Replace pointer with reference in SettingsCollection<T>::MemberInfos::findStrict(). 2019-11-17 03:51:51 +03:00
InternalTextLogsQueue.cpp Changed thread_id to UInt64 to support more OS 2020-02-02 23:01:13 +03:00
InternalTextLogsQueue.h
InterpreterAlterQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterAlterQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterCheckQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterCheckQuery.h
InterpreterCreateQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterCreateQuery.h Some InterpreterSelectQuery refactoring (#9035) 2020-02-10 18:50:12 +03:00
InterpreterCreateQuotaQuery.cpp Rewrite the User class to be controlled by AccessControlManager. 2020-01-31 20:27:32 +03:00
InterpreterCreateQuotaQuery.h Add DCL to manage quotas. 2019-12-05 21:03:57 +03:00
InterpreterCreateRowPolicyQuery.cpp Rewrite the User class to be controlled by AccessControlManager. 2020-01-31 20:27:32 +03:00
InterpreterCreateRowPolicyQuery.h Add DCL to manage row policies. 2019-12-19 18:40:21 +03:00
InterpreterCreateUserQuery.cpp Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterCreateUserQuery.h Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterDescribeQuery.cpp Rewrite the User class to be controlled by AccessControlManager. 2020-01-31 20:27:32 +03:00
InterpreterDescribeQuery.h
InterpreterDropAccessEntityQuery.cpp Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterDropAccessEntityQuery.h Add DCL to manage quotas. 2019-12-05 21:03:57 +03:00
InterpreterDropQuery.cpp better get... methods 2020-02-17 16:52:59 +03:00
InterpreterDropQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterExistsQuery.cpp better get... methods 2020-02-17 16:52:59 +03:00
InterpreterExistsQuery.h
InterpreterExplainQuery.cpp
InterpreterExplainQuery.h hold shared pointers to table function Storage and Context from InterpreterSelectQuery 2019-11-15 21:42:32 +03:00
InterpreterFactory.cpp Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterFactory.h
InterpreterGrantQuery.cpp Implement partial revokes. 2020-02-06 18:12:53 +03:00
InterpreterGrantQuery.h Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterInsertQuery.cpp Rewrite the User class to be controlled by AccessControlManager. 2020-01-31 20:27:32 +03:00
InterpreterInsertQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterKillQueryQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterKillQueryQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterOptimizeQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterOptimizeQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterRenameQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterRenameQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterSelectQuery.cpp Merge branch 'master' into split_databases_from_context 2020-02-12 21:18:32 +03:00
InterpreterSelectQuery.h actualize ExpressionAnalyzer public interface 2020-02-10 22:55:13 +03:00
InterpreterSelectWithUnionQuery.cpp Disable quota consumptions for the system queries and for selecting 2019-12-05 21:03:57 +03:00
InterpreterSelectWithUnionQuery.h Disable quota consumptions for the system queries and for selecting 2019-12-05 21:03:57 +03:00
InterpreterSetQuery.cpp
InterpreterSetQuery.h
InterpreterShowCreateAccessEntityQuery.cpp Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterShowCreateAccessEntityQuery.h Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterShowCreateQuery.cpp move databases from Context to DatabaseCatalog 2020-02-10 17:49:44 +03:00
InterpreterShowCreateQuery.h
InterpreterShowGrantsQuery.cpp Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterShowGrantsQuery.h Implement SQL queries to manipulate users and grants. 2020-02-06 18:12:53 +03:00
InterpreterShowProcesslistQuery.cpp
InterpreterShowProcesslistQuery.h
InterpreterShowQuotasQuery.cpp Add DCL to manage quotas. 2019-12-05 21:03:57 +03:00
InterpreterShowQuotasQuery.h Add DCL to manage quotas. 2019-12-05 21:03:57 +03:00
InterpreterShowRowPoliciesQuery.cpp Fixed merge issues 2019-12-27 12:49:23 +03:00
InterpreterShowRowPoliciesQuery.h Add DCL to manage row policies. 2019-12-19 18:40:21 +03:00
InterpreterShowTablesQuery.cpp Merge branch 'master' into split_databases_from_context 2020-02-17 13:04:36 +03:00
InterpreterShowTablesQuery.h
InterpreterSystemQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterSystemQuery.h Check access rights via new interface. 2020-01-31 20:27:28 +03:00
InterpreterUseQuery.cpp Rewrite the User class to be controlled by AccessControlManager. 2020-01-31 20:27:32 +03:00
InterpreterUseQuery.h
InterpreterWatchQuery.cpp less Context::getTable() usages 2020-02-17 22:28:25 +03:00
InterpreterWatchQuery.h
interpretSubquery.cpp Some InterpreterSelectQuery refactoring (#9035) 2020-02-10 18:50:12 +03:00
interpretSubquery.h
InterserverIOHandler.h get rid of StorageWeakPtr 2020-01-14 19:54:25 +03:00
join_common.cpp Fix crash in FULL JOIN with LowCard in key (attempt 2) 2019-12-17 18:02:42 +03:00
join_common.h Fix crash in FULL JOIN with LowCard in key (attempt 2) 2019-12-17 18:02:42 +03:00
Join.cpp rewrite with cursor position 2020-01-15 23:33:29 +03:00
Join.h rewrite with cursor position 2020-01-15 23:33:29 +03:00
joinDispatch.h better comment 2019-12-05 15:01:34 +03:00
JoinToSubqueryTransformVisitor.cpp relax ambiguous column check for multiple JOIN ON section 2019-12-24 21:51:37 +03:00
JoinToSubqueryTransformVisitor.h
loadMetadata.cpp move databases from Context to DatabaseCatalog 2020-02-10 17:49:44 +03:00
loadMetadata.h
LogicalExpressionsOptimizer.cpp
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp Allow table identifier as the first arg to joinGet (#7707) 2019-12-18 23:36:51 +03:00
MarkTableIdentifiersVisitor.h
MergeJoin.cpp rename ANY INNER to SEMI JOIN for partial merge join 2020-01-31 17:29:49 +03:00
MergeJoin.h rename ANY INNER to SEMI JOIN for partial merge join 2020-01-31 17:29:49 +03:00
MetricLog.cpp
MetricLog.h
misc.h
MutationsInterpreter.cpp Don't use ORDER BY for empty key 2020-02-07 20:10:24 +03:00
MutationsInterpreter.h Remove redundant alter_lock, because parts cannot be altered concurrently. 2019-12-25 15:34:04 +03:00
NullableUtils.cpp
NullableUtils.h
OptimizeIfChains.cpp Fix some spelling mistakes 2020-01-11 17:51:33 +08:00
OptimizeIfChains.h Improvements, part 1 2019-12-31 01:24:19 +03:00
OptimizeIfWithConstantConditionVisitor.cpp
OptimizeIfWithConstantConditionVisitor.h
PartLog.cpp remove separate getTableName() and getDatabaseName() 2019-12-26 21:11:49 +03:00
PartLog.h
PredicateExpressionsOptimizer.cpp try fix failure test & fix build failure 2020-01-04 16:47:03 +08:00
PredicateExpressionsOptimizer.h try fix failure test & fix build failure 2020-01-04 16:47:03 +08:00
PredicateRewriteVisitor.cpp no skip lambda function 2020-01-07 11:31:03 +08:00
PredicateRewriteVisitor.h try fix failure test & fix build failure 2020-01-04 16:47:03 +08:00
PreparedSets.h
ProcessList.cpp Merge remote-tracking branch 'upstream/master' into memory-profiler 2020-02-03 16:21:21 +03:00
ProcessList.h Changed thread_id to UInt64 to support more OS 2020-02-02 23:01:13 +03:00
ProfileEventsExt.cpp
ProfileEventsExt.h
QueryAliasesVisitor.cpp
QueryAliasesVisitor.h
QueryLog.cpp Changed thread_id to UInt64 to support more OS 2020-02-02 23:01:13 +03:00
QueryLog.h Changed thread_id to UInt64 to support more OS 2020-02-02 23:01:13 +03:00
QueryNormalizer.cpp Integration of log storages with IDisk interface 2019-12-23 16:11:56 +03:00
QueryNormalizer.h
QueryPriorities.h
QueryThreadLog.cpp Changed thread_id to UInt64 to support more OS 2020-02-02 23:01:13 +03:00
QueryThreadLog.h Changed thread_id to UInt64 to support more OS 2020-02-02 23:01:13 +03:00
ReplaceQueryParameterVisitor.cpp Changed serialization of query parameters 2020-01-03 17:10:56 +03:00
ReplaceQueryParameterVisitor.h
RequiredSourceColumnsVisitor.cpp
RequiredSourceColumnsVisitor.h
RowRefs.cpp Fixed using DecimalX and DateTime64 with ASOF JOIN 2019-11-20 12:00:10 +03:00
RowRefs.h Fixed using DecimalX and DateTime64 with ASOF JOIN 2019-11-20 12:00:10 +03:00
SelectQueryOptions.h Disable quota consumptions for the system queries and for selecting 2019-12-05 21:03:57 +03:00
Set.cpp Merge pull request #8813 from CurtizJ/merging-in-arrays 2020-02-02 04:33:54 +03:00
Set.h Merge pull request #8813 from CurtizJ/merging-in-arrays 2020-02-02 04:33:54 +03:00
SetVariants.cpp
SetVariants.h
sortBlock.cpp cosmetic 2020-01-29 11:09:27 +01:00
sortBlock.h Review fixes 2019-12-07 01:22:12 +03:00
SubqueryForSet.cpp Some InterpreterSelectQuery refactoring (#9035) 2020-02-10 18:50:12 +03:00
SubqueryForSet.h Some InterpreterSelectQuery refactoring (#9035) 2020-02-10 18:50:12 +03:00
SyntaxAnalyzer.cpp syntax ANY INNER to SEMI LEFT JOIN rewrite 2020-02-02 17:07:50 +03:00
SyntaxAnalyzer.h move one more function 2019-12-12 19:54:04 +03:00
SystemLog.cpp Update SystemLog.cpp 2020-01-23 22:21:57 +03:00
SystemLog.h less Context::getTable() usages 2020-02-17 22:28:25 +03:00
TablesStatus.cpp
TablesStatus.h
TextLog.cpp Improve flush performance in SystemLog 2020-02-07 22:32:49 +03:00
TextLog.h Improve flush performance in SystemLog 2020-02-07 22:32:49 +03:00
ThreadStatusExt.cpp Attempt to fix 2020-02-03 20:06:59 +03:00
TraceLog.cpp Fix Int64 → UInt64 for |size| 2020-02-10 18:24:26 +03:00
TraceLog.h Fix Int64 → UInt64 for |size| 2020-02-10 18:24:26 +03:00
TranslateQualifiedNamesVisitor.cpp fix 'There's no column' error for materialized and alias columns 2019-12-13 21:46:55 +03:00
TranslateQualifiedNamesVisitor.h support nested column names 2019-11-13 19:49:29 +03:00