ClickHouse/src/Interpreters
2020-07-02 23:39:31 +03:00
..
ClusterProxy Update executeQuery.cpp 2020-06-21 21:29:11 +03:00
tests Better way of implementation 2020-06-14 20:42:11 +03:00
ActionLocksManager.cpp Fix error with Lazy database 2020-06-02 05:06:16 +03:00
ActionLocksManager.h add context to DatabaseCatalog methods 2020-05-29 02:01:18 +03:00
ActionsVisitor.cpp Fix JOIN over LC and Nullable in key (#11414) 2020-06-04 13:07:22 +03:00
ActionsVisitor.h review fixes 2020-04-14 20:41:06 +03:00
AddDefaultDatabaseVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
addMissingDefaults.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
addMissingDefaults.h Add missing headers for libstdc++ from gcc10 2020-05-16 00:00:38 +03:00
addTypeConversionToAST.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
addTypeConversionToAST.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
AggregateDescription.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
AggregateFunctionOfGroupByKeysVisitor.h Preserve column alias with optimize_aggregators_of_group_by_keys 2020-06-19 23:04:19 +03:00
AggregationCommon.h Fix build 2020-05-10 02:54:04 +03:00
Aggregator.cpp Merge remote-tracking branch 'upstream/master' into HEAD 2020-06-25 14:59:15 +03:00
Aggregator.h Merge remote-tracking branch 'upstream/master' into HEAD 2020-06-25 14:59:15 +03:00
Aliases.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
AnyInputOptimize.cpp better code 2020-06-18 20:05:26 +03:00
AnyInputOptimize.h Any input optimize (#11529) 2020-06-18 19:34:29 +03:00
ArithmeticOperationsInAgrFuncOptimize.cpp Rewrite arithmetic in aggregate functions optimisation (#11899) 2020-06-24 21:49:55 +03:00
ArithmeticOperationsInAgrFuncOptimize.h Rewrite arithmetic in aggregate functions optimisation (#11899) 2020-06-24 21:49:55 +03:00
ArrayJoinAction.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
ArrayJoinAction.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
ArrayJoinedColumnsVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
asof.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
AsteriskSemantic.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
AsynchronousMetricLog.cpp Add files; flush more often 2020-06-11 00:16:58 +03:00
AsynchronousMetricLog.h Add files; flush more often 2020-06-11 00:16:58 +03:00
AsynchronousMetrics.cpp Limit /proc/cpuinfo metrics to linux only 2020-06-28 18:44:24 -05:00
AsynchronousMetrics.h Update AsynchronousMetrics.h 2020-06-26 05:18:57 +03:00
BloomFilter.cpp I'm able to build it 2020-05-28 15:37:05 +03:00
BloomFilter.h I'm able to build it 2020-05-28 15:37:05 +03:00
BloomFilterHash.h Fix bloom filters for String (data skipping indices) 2020-06-12 22:46:40 +03:00
CancellationCode.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
castColumn.cpp CAST keep nullable (#11733) 2020-06-18 13:18:28 +03:00
castColumn.h Remove useless code 2020-04-15 00:05:45 +03:00
CatBoostModel.cpp Checkpoint 2020-04-22 08:39:31 +03:00
CatBoostModel.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
ClientInfo.cpp Merge branch 'master' into quota-key-in-client 2020-04-20 02:15:37 +03:00
ClientInfo.h Remove "current_password" but keep it for Arcadians 2020-06-15 05:17:08 +03:00
Cluster.cpp Fix shard_num/replica_num for <node> (breaks use_compact_format_in_distributed_parts_names) 2020-06-08 22:30:13 +03:00
Cluster.h Fix prefer_localhost_replica=0 and load_balancing for Distributed INSERT 2020-05-14 03:29:03 +03:00
CMakeLists.txt dbms/ → src/ 2020-04-03 18:14:31 +03:00
CollectJoinOnKeysVisitor.cpp renames: AnalyzedJoin -> TableJoin, Join -> HashJoin (#10065) 2020-04-07 12:48:47 +03:00
CollectJoinOnKeysVisitor.h refactoring: remove TableWithColumnNames 2020-06-06 00:17:00 +03:00
Context.cpp Fix typos 2020-06-27 22:05:00 +03:00
Context.h Add system.asynchronous_metric_log 2020-06-10 22:17:54 +03:00
convertFieldToType.cpp fix some logical errors 2020-06-24 23:51:17 +03:00
convertFieldToType.h fix some logical errors 2020-06-24 23:51:17 +03:00
createBlockSelector.cpp Update libdivide to v3.0 (#10169) 2020-04-11 14:14:01 +03:00
createBlockSelector.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
CrossToInnerJoinVisitor.cpp Change push down logic in VIEW (#11513) 2020-06-15 15:36:10 +03:00
CrossToInnerJoinVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
DatabaseAndTableWithAlias.cpp Checkpoint 2020-04-22 09:01:33 +03:00
DatabaseAndTableWithAlias.h refactoring: remove TableWithColumnNames 2020-06-06 00:17:00 +03:00
DatabaseCatalog.cpp Put clickhouse-local data to /tmp by default 2020-06-24 22:03:28 +03:00
DatabaseCatalog.h Remove assorted synonyms of LOGICAL_ERROR. 2020-06-03 16:18:42 +03:00
DDLWorker.cpp Remove leader election, step 3 2020-06-19 17:18:58 +03:00
DDLWorker.h support distributed DDLs on cross replication clusters. 2020-06-16 11:53:27 +03:00
DictionaryReader.cpp Make IColumn::mutate() static. 2020-05-14 11:30:18 +03:00
DictionaryReader.h move DictionaryReader code out of header 2020-04-13 20:36:07 +03:00
DNSCacheUpdater.cpp Return old names of macros 2020-05-24 01:24:01 +03:00
DNSCacheUpdater.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
DuplicateDistinctVisitor.h Remove duplicate ORDER BY and DISTINCT from subqueries (#10067) 2020-06-15 15:03:01 +03:00
DuplicateOrderByVisitor.h Remove duplicate ORDER BY and DISTINCT from subqueries (#10067) 2020-06-15 15:03:01 +03:00
EmbeddedDictionaries.cpp Remove namespace pollution 2020-05-31 00:57:37 +03:00
EmbeddedDictionaries.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
evaluateConstantExpression.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
evaluateConstantExpression.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
executeQuery.cpp Merge branch 'master' into atomic_metadata5 2020-06-17 11:14:03 +03:00
executeQuery.h Try fix compatibility. 2020-05-19 17:06:33 +03:00
ExecuteScalarSubqueriesVisitor.cpp Try fix tests. 2020-05-28 17:11:36 +03:00
ExecuteScalarSubqueriesVisitor.h Do not calculate subqueries when only_analyze enabled. 2020-05-09 21:43:16 +03:00
ExpressionActions.cpp better ExpressionAction::execute() 2020-06-25 23:28:41 +03:00
ExpressionActions.h Update ExpressionActions.h 2020-06-26 15:24:13 +03:00
ExpressionAnalyzer.cpp place left join keys in before_join actions 2020-06-26 02:10:37 +03:00
ExpressionAnalyzer.h place left join keys in before_join actions 2020-06-26 02:10:37 +03:00
ExpressionJIT.cpp Checkpoint 2020-04-22 09:01:33 +03:00
ExpressionJIT.h Merge pull request #10342 from azat/optimizeGroupBy-isInjective 2020-04-18 14:28:59 +03:00
ExternalDictionariesLoader.cpp Remove namespace pollution 2020-05-31 00:57:37 +03:00
ExternalDictionariesLoader.h Show information about not loaded dictionaries in system.columns, system.tables 2020-04-18 12:50:54 +03:00
ExternalLoader.cpp Remove namespace pollution 2020-05-31 00:57:37 +03:00
ExternalLoader.h Remove namespace pollution 2020-05-31 00:57:37 +03:00
ExternalLoaderDatabaseConfigRepository.cpp Move initialization of DatabaseWithDictionaries to constructor. 2020-04-30 20:22:20 +03:00
ExternalLoaderDatabaseConfigRepository.h Move initialization of DatabaseWithDictionaries to constructor. 2020-04-30 20:22:20 +03:00
ExternalLoaderTempConfigRepository.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
ExternalLoaderTempConfigRepository.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
ExternalLoaderXMLConfigRepository.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
ExternalLoaderXMLConfigRepository.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
ExternalModelsLoader.cpp Remove namespace pollution 2020-05-31 00:57:37 +03:00
ExternalModelsLoader.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
ExtractExpressionInfoVisitor.cpp refactoring: remove TableWithColumnNames 2020-06-06 00:17:00 +03:00
ExtractExpressionInfoVisitor.h refactoring: remove TableWithColumnNames 2020-06-06 00:17:00 +03:00
FillingRow.cpp Split file for better build times 2020-06-14 21:42:10 +03:00
FillingRow.h Split file for better build times 2020-06-14 21:42:10 +03:00
GetAggregatesVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
getClusterName.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
getClusterName.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
getTableExpressions.cpp getColumns in StorageInMemoryMetadta (only compilable) 2020-06-17 19:39:58 +03:00
getTableExpressions.h refactoring: remove TableWithColumnNames 2020-06-06 00:17:00 +03:00
GlobalSubqueriesVisitor.h Merge pull request #11243 from ClickHouse/remove-experimental-use-processors-flag-4 2020-05-30 21:05:14 +03:00
GroupByFunctionKeysVisitor.h Remove functions of other keys in GROUP BY section (#10051) 2020-06-16 12:14:25 +03:00
HashJoin.cpp Fix JOIN over LC and Nullable in key (#11414) 2020-06-04 13:07:22 +03:00
HashJoin.h more types in ASOF JOIN (#11301) 2020-06-01 12:38:46 +03:00
IdentifierSemantic.cpp Change push down logic in VIEW (#11513) 2020-06-15 15:36:10 +03:00
IdentifierSemantic.h Change push down logic in VIEW (#11513) 2020-06-15 15:36:10 +03:00
IExternalLoadable.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
IExternalLoadable.h code review fixes & added exception in case lifetime parameter presence in config 2020-05-06 02:43:06 +03:00
IExternalLoaderConfigRepository.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
IInterpreter.h Fix style. 2020-05-28 12:07:40 +03:00
IJoin.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InDepthNodeVisitor.h Fix and improve OneTypeMatcher (#10253) 2020-04-14 21:50:00 +03:00
InJoinSubqueriesPreprocessor.cpp add context to DatabaseCatalog methods 2020-05-29 02:01:18 +03:00
InJoinSubqueriesPreprocessor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
inplaceBlockConversions.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
inplaceBlockConversions.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InternalTextLogsQueue.cpp Return old names of macros 2020-05-24 01:24:01 +03:00
InternalTextLogsQueue.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterAlterQuery.cpp fix: can not drop local table and replace ALTER with SYSTEM 2020-06-23 12:12:30 +08:00
InterpreterAlterQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterCheckQuery.cpp add context to DatabaseCatalog methods 2020-05-29 02:01:18 +03:00
InterpreterCheckQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterCreateQuery.cpp add uuid to atomic databases 2020-07-02 23:39:31 +03:00
InterpreterCreateQuery.h I'm able to build it 2020-05-28 15:37:05 +03:00
InterpreterCreateQuotaQuery.cpp Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
InterpreterCreateQuotaQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterCreateRoleQuery.cpp Support for multiple names in one CREATE/ALTER command. 2020-06-15 20:10:28 +03:00
InterpreterCreateRoleQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterCreateRowPolicyQuery.cpp Slightly improve syntax of CREATE POLICY. 2020-06-15 22:07:42 +03:00
InterpreterCreateRowPolicyQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterCreateSettingsProfileQuery.cpp Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
InterpreterCreateSettingsProfileQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterCreateUserQuery.cpp Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
InterpreterCreateUserQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterDescribeQuery.cpp Better locks in Storages 2020-06-18 19:10:47 +03:00
InterpreterDescribeQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterDropAccessEntityQuery.cpp Support for multiple names in one CREATE/ALTER command. 2020-06-15 20:10:28 +03:00
InterpreterDropAccessEntityQuery.h Use enum Type instead of std::type_index to represent the type of IAccessEntity. 2020-05-13 19:40:48 +03:00
InterpreterDropQuery.cpp Better locks in Storages 2020-06-18 19:10:47 +03:00
InterpreterDropQuery.h better code 2020-04-07 02:22:44 +03:00
InterpreterExistsQuery.cpp add context to DatabaseCatalog methods 2020-05-29 02:01:18 +03:00
InterpreterExistsQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterExplainQuery.cpp Change push down logic in VIEW (#11513) 2020-06-15 15:36:10 +03:00
InterpreterExplainQuery.h Forward declaration for Context as much as possible. 2020-05-21 01:53:18 +03:00
InterpreterFactory.cpp Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterFactory.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterGrantQuery.cpp Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
InterpreterGrantQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterInsertQuery.cpp Merge branch 'master' into atomic_metadata5 2020-06-22 12:03:53 +03:00
InterpreterInsertQuery.h Move getSampleBlockNonMaterialized to StorageInMemoryMetadata 2020-06-16 15:48:10 +03:00
InterpreterKillQueryQuery.cpp add context to DatabaseCatalog methods 2020-05-29 02:01:18 +03:00
InterpreterKillQueryQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterOptimizeQuery.cpp TTL in storage in memory metadata 2020-06-17 16:39:26 +03:00
InterpreterOptimizeQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterRenameQuery.cpp add context to DatabaseCatalog methods 2020-05-29 02:01:18 +03:00
InterpreterRenameQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterSelectQuery.cpp Merge branch 'master' into better-distinct-for-query-plan 2020-06-29 11:14:05 +03:00
InterpreterSelectQuery.h Better comments 2020-06-22 12:49:21 +03:00
InterpreterSelectWithUnionQuery.cpp Use QueryPlan in InterpreterSelectQuery [part 2]. 2020-06-18 20:45:00 +03:00
InterpreterSelectWithUnionQuery.h Use QueryPlan in InterpreterSelectQuery [part 2]. 2020-06-18 20:45:00 +03:00
InterpreterSetQuery.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterSetQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterSetRoleQuery.cpp Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
InterpreterSetRoleQuery.h Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
InterpreterShowAccessEntitiesQuery.cpp Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowAccessEntitiesQuery.h Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowAccessQuery.cpp Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowAccessQuery.h Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowCreateAccessEntityQuery.cpp Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowCreateAccessEntityQuery.h Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowCreateQuery.cpp fix segfault in show create table 2020-06-10 15:53:12 +03:00
InterpreterShowCreateQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterShowGrantsQuery.cpp Support multiple users/roles in SHOW CREATE USER(ROLE, etc.) and SHOW GRANTS FOR commands. 2020-06-15 22:07:47 +03:00
InterpreterShowGrantsQuery.h Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
InterpreterShowPrivilegesQuery.cpp Add system table for access types. 2020-05-14 14:12:20 +03:00
InterpreterShowPrivilegesQuery.h Add system table for access types. 2020-05-14 14:12:20 +03:00
InterpreterShowProcesslistQuery.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterShowProcesslistQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterShowTablesQuery.cpp Add DISTINCT keyword when show clusters 2020-06-09 10:39:37 +08:00
InterpreterShowTablesQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterSystemQuery.cpp minor improvements 2020-06-23 22:15:01 +03:00
InterpreterSystemQuery.h minor improvements 2020-06-23 22:15:01 +03:00
InterpreterUseQuery.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterUseQuery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterpreterWatchQuery.cpp getColumns in StorageInMemoryMetadta (only compilable) 2020-06-17 19:39:58 +03:00
InterpreterWatchQuery.h Forward declaration for Context as much as possible. 2020-05-21 01:53:18 +03:00
interpretSubquery.cpp getColumns in StorageInMemoryMetadta (only compilable) 2020-06-17 19:39:58 +03:00
interpretSubquery.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
InterserverIOHandler.h better 2020-04-13 18:21:05 +03:00
join_common.cpp fix low card types in merge join (#12035) 2020-06-30 14:13:43 +03:00
join_common.h fix low card types in merge join (#12035) 2020-06-30 14:13:43 +03:00
joinDispatch.h renames: AnalyzedJoin -> TableJoin, Join -> HashJoin (#10065) 2020-04-07 12:48:47 +03:00
JoinedTables.cpp getColumns in StorageInMemoryMetadta (only compilable) 2020-06-17 19:39:58 +03:00
JoinedTables.h Fix typos 2020-06-27 22:05:00 +03:00
JoinSwitcher.cpp renames: AnalyzedJoin -> TableJoin, Join -> HashJoin (#10065) 2020-04-07 12:48:47 +03:00
JoinSwitcher.h renames: AnalyzedJoin -> TableJoin, Join -> HashJoin (#10065) 2020-04-07 12:48:47 +03:00
JoinToSubqueryTransformVisitor.cpp Fix typos 2020-06-27 22:05:00 +03:00
JoinToSubqueryTransformVisitor.h Fix typos 2020-06-27 22:05:00 +03:00
loadMetadata.cpp add uuid to atomic databases 2020-07-02 23:39:31 +03:00
loadMetadata.h Merge branch 'master' into database_atomic 2020-04-06 16:18:07 +03:00
LogicalExpressionsOptimizer.cpp Checkpoint 2020-04-22 09:01:33 +03:00
LogicalExpressionsOptimizer.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
MarkTableIdentifiersVisitor.cpp Fix passing dictionary's name to dictGet() with alias. 2020-05-19 21:17:29 +03:00
MarkTableIdentifiersVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
MergeJoin.cpp fix low card types in merge join (#12035) 2020-06-30 14:13:43 +03:00
MergeJoin.h Buffer left blocks optimisation for MergeJoin (#10601) 2020-06-16 23:13:18 +03:00
MetricLog.cpp A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
MetricLog.h A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
misc.h Fix passing dictionary's name to dictGet() with alias. 2020-05-19 21:17:29 +03:00
MutationsInterpreter.cpp Better locks in Storages 2020-06-18 19:10:47 +03:00
MutationsInterpreter.h Better locks in Storages 2020-06-18 19:10:47 +03:00
NullableUtils.cpp Make IColumn::mutate() static. 2020-05-14 11:30:18 +03:00
NullableUtils.h Implement transform_null_in 2020-04-07 20:08:13 +09:00
OptimizeIfChains.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
OptimizeIfChains.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
OptimizeIfWithConstantConditionVisitor.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
OptimizeIfWithConstantConditionVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
PartLog.cpp Remove namespace pollution 2020-05-31 00:57:37 +03:00
PartLog.h A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
PredicateExpressionsOptimizer.cpp hotfix: save tmp container 2020-06-06 00:28:44 +03:00
PredicateExpressionsOptimizer.h hotfix: save tmp container 2020-06-06 00:28:44 +03:00
PredicateRewriteVisitor.cpp hotfix: save tmp container 2020-06-06 00:28:44 +03:00
PredicateRewriteVisitor.h hotfix: save tmp container 2020-06-06 00:28:44 +03:00
PreparedSets.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
ProcessList.cpp Remove namespace pollution 2020-05-31 00:57:37 +03:00
ProcessList.h Remove useless code 2020-05-01 22:01:02 +03:00
ProfileEventsExt.cpp Checkpoint 2020-04-22 09:01:33 +03:00
ProfileEventsExt.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
QueryAliasesVisitor.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
QueryAliasesVisitor.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
QueryLog.cpp A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
QueryLog.h Merge pull request #11118 from ClickHouse/aku/trace-log-overflow-followup 2020-05-22 14:29:11 +03:00
QueryNormalizer.cpp Checkpoint 2020-04-22 09:01:33 +03:00
QueryNormalizer.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
QueryParameterVisitor.h ISSUES-5436 reworking predefine http 2020-04-20 03:18:36 +08:00
QueryPriorities.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
QueryThreadLog.cpp A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
QueryThreadLog.h Merge pull request #11118 from ClickHouse/aku/trace-log-overflow-followup 2020-05-22 14:29:11 +03:00
RenameColumnVisitor.cpp Checkpoint 2020-04-22 09:01:33 +03:00
RenameColumnVisitor.h Checkpoint 2020-04-22 09:01:33 +03:00
ReplaceQueryParameterVisitor.cpp Merge pull request #11936 from ClickHouse/fix_11918 2020-06-26 00:54:37 +03:00
ReplaceQueryParameterVisitor.h fix query parameter visitor 2020-06-25 00:36:18 +03:00
RequiredSourceColumnsData.cpp Checkpoint 2020-04-22 09:01:33 +03:00
RequiredSourceColumnsData.h tech debt 2020-04-14 17:43:09 +03:00
RequiredSourceColumnsVisitor.cpp Fix lambdas with multiple_joins_rewriter v2 (#11587) 2020-06-16 19:32:32 +03:00
RequiredSourceColumnsVisitor.h Fix lambdas with multiple_joins_rewriter v2 (#11587) 2020-06-16 19:32:32 +03:00
RowRefs.cpp IColumn::getDataType() (#11438) 2020-06-05 01:02:59 +03:00
RowRefs.h more types in ASOF JOIN (#11301) 2020-06-01 12:38:46 +03:00
SelectQueryOptions.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
Set.cpp Forward declaration for Context as much as possible. 2020-05-21 01:53:18 +03:00
Set.h Remove namespace pollution 2020-05-31 00:57:37 +03:00
SetVariants.cpp Checkpoint 2020-04-22 09:01:33 +03:00
SetVariants.h Whitespaces 2020-04-15 01:25:31 +03:00
sortBlock.cpp Fix ORDER BY tuple with COLLATE on const column 2020-06-28 23:55:45 +03:00
sortBlock.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
SortedBlocksWriter.cpp Buffer left blocks optimisation for MergeJoin (#10601) 2020-06-16 23:13:18 +03:00
SortedBlocksWriter.h Buffer left blocks optimisation for MergeJoin (#10601) 2020-06-16 23:13:18 +03:00
StorageID.cpp Checkpoint 2020-04-22 09:01:33 +03:00
StorageID.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
SubqueryForSet.cpp Try fix tests. 2020-05-28 17:11:36 +03:00
SubqueryForSet.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
SyntaxAnalyzer.cpp Merge pull request #11950 from 4ertus2/joins 2020-06-26 15:52:58 +03:00
SyntaxAnalyzer.h keep ArrayJoin optimisation 2020-06-25 23:59:10 +03:00
SystemLog.cpp Whitespace 2020-06-13 04:35:49 +03:00
SystemLog.h Merge branch 'master' into atomic_metadata5 2020-06-17 11:14:03 +03:00
TableJoin.cpp Buffer left blocks optimisation for MergeJoin (#10601) 2020-06-16 23:13:18 +03:00
TableJoin.h Buffer left blocks optimisation for MergeJoin (#10601) 2020-06-16 23:13:18 +03:00
TablesStatus.cpp dbms/ → src/ 2020-04-03 18:14:31 +03:00
TablesStatus.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
TextLog.cpp A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
TextLog.h A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
ThreadStatusExt.cpp Add TLB misses perf counters. 2020-06-29 15:48:18 +03:00
TraceLog.cpp A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
TraceLog.h A follow-up for trace log overflow in perftests 2020-05-21 23:40:23 +03:00
TranslateQualifiedNamesVisitor.cpp fix bug for query "select *, abc.*" should failed. (#11753) 2020-06-23 12:16:42 +03:00
TranslateQualifiedNamesVisitor.h refactoring: remove TableWithColumnNames 2020-06-06 00:17:00 +03:00
ya.make Any input optimize (#11529) 2020-06-18 19:34:29 +03:00