.. |
ClusterProxy
|
Fix limit/offset settings for distributed queries (ignore on the remote nodes)
|
2021-06-03 21:14:24 +03:00 |
examples
|
Fix clang-tidy
|
2021-06-10 22:14:24 +03:00 |
JIT
|
Merge pull request #25265 from ClickHouse/minor-changes-3
|
2021-06-16 08:33:12 +03:00 |
MySQL
|
Update InterpretersMySQLDDLQuery.cpp
|
2021-06-16 14:22:07 +08:00 |
tests
|
Ban loop aliases in table definitions
|
2021-06-07 23:59:38 +03:00 |
ActionLocksManager.cpp
|
|
|
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Add comment.
|
2021-06-17 23:05:39 +03:00 |
ActionsDAG.h
|
Function constant result with nonconstant arguments
|
2021-05-24 10:16:12 +03:00 |
ActionsVisitor.cpp
|
Merge remote-tracking branch 'upstream/master' into ast-table-identifier-2
|
2021-05-27 15:57:59 +03:00 |
ActionsVisitor.h
|
|
|
AddDefaultDatabaseVisitor.h
|
|
|
addMissingDefaults.cpp
|
|
|
addMissingDefaults.h
|
|
|
addTypeConversionToAST.cpp
|
Rewrite more alias columns
|
2021-06-15 17:54:28 +08:00 |
addTypeConversionToAST.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
AggregateDescription.cpp
|
Minor changes
|
2021-06-14 07:13:35 +03:00 |
AggregateDescription.h
|
|
|
AggregateFunctionOfGroupByKeysVisitor.h
|
|
|
AggregationCommon.h
|
|
|
Aggregator.cpp
|
Merge pull request #25015 from ClickHouse/fix-wrong-code-in-aggregate-functions
|
2021-06-11 00:36:35 +03:00 |
Aggregator.h
|
Making fundamentals correct
|
2021-06-07 00:49:55 +03:00 |
Aliases.h
|
|
|
ApplyWithAliasVisitor.cpp
|
|
|
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
|
|
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
Fix false-positive issue from clang-tidy
|
2021-06-11 21:05:45 +03:00 |
ApplyWithSubqueryVisitor.h
|
|
|
ArithmeticOperationsInAgrFuncOptimize.cpp
|
Add 256 bit integers in some places
|
2021-05-06 03:31:09 +03:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
|
|
ArrayJoinAction.cpp
|
|
|
ArrayJoinAction.h
|
|
|
ArrayJoinedColumnsVisitor.h
|
|
|
asof.h
|
|
|
AsynchronousMetricLog.cpp
|
use LowCardinality for AsynchronousMetricLog name column
|
2021-05-09 16:25:28 +00:00 |
AsynchronousMetricLog.h
|
|
|
AsynchronousMetrics.cpp
|
Fixed code review issues
|
2021-05-10 11:09:32 +03:00 |
AsynchronousMetrics.h
|
|
|
BloomFilter.cpp
|
|
|
BloomFilter.h
|
|
|
BloomFilterHash.h
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
CancellationCode.h
|
|
|
castColumn.cpp
|
IFunction refactoring
|
2021-05-15 20:33:15 +03:00 |
castColumn.h
|
|
|
CatBoostModel.cpp
|
Minor changes
|
2021-06-14 07:13:35 +03:00 |
CatBoostModel.h
|
|
|
ClientInfo.cpp
|
Update comment
|
2021-06-11 23:24:38 +08:00 |
ClientInfo.h
|
Add initial_query_start_time to query log
|
2021-06-11 22:24:53 +08:00 |
Cluster.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
Cluster.h
|
|
|
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
|
|
CollectJoinOnKeysVisitor.h
|
|
|
ColumnAliasesVisitor.cpp
|
Fix RBAC test again
|
2021-06-17 23:00:03 +08:00 |
ColumnAliasesVisitor.h
|
Fix RBAC test again
|
2021-06-17 23:00:03 +08:00 |
Context_fwd.h
|
Update Context_fwd.h
|
2021-06-01 16:38:47 +03:00 |
Context.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
Context.h
|
Merge branch 'master' into rename-const-context-ptr
|
2021-06-04 14:41:41 +00:00 |
convertFieldToType.cpp
|
replace all isDateOrDateTime invocations to explicit calls to isDate and isDateTime and isDateTime64
|
2021-05-28 15:34:49 +03:00 |
convertFieldToType.h
|
|
|
ConvertStringsToEnumVisitor.cpp
|
Fix clang-tidy
|
2021-05-09 20:02:37 +03:00 |
ConvertStringsToEnumVisitor.h
|
Fix a bunch of warnings from PVS-Studio
|
2021-05-08 19:13:10 +03:00 |
CrashLog.cpp
|
|
|
CrashLog.h
|
|
|
createBlockSelector.cpp
|
|
|
createBlockSelector.h
|
|
|
CrossToInnerJoinVisitor.cpp
|
|
|
CrossToInnerJoinVisitor.h
|
|
|
DatabaseAndTableWithAlias.cpp
|
|
|
DatabaseAndTableWithAlias.h
|
|
|
DatabaseCatalog.cpp
|
Try reusing built sets during multi-pass analysis
|
2021-06-03 22:06:05 +08:00 |
DatabaseCatalog.h
|
Add missed #include <condition_variable>
|
2021-06-13 22:14:05 +03:00 |
DDLTask.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
DDLTask.h
|
Merge pull request #23657 from kssenii/poco-file-to-std-fs
|
2021-05-31 23:17:02 +03:00 |
DDLWorker.cpp
|
Merge pull request #25373 from ClickHouse/improve_replicated_database_tests2
|
2021-06-17 08:34:06 +03:00 |
DDLWorker.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
DictionaryReader.cpp
|
|
|
DictionaryReader.h
|
|
|
DNSCacheUpdater.cpp
|
|
|
DNSCacheUpdater.h
|
|
|
DuplicateOrderByVisitor.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
EmbeddedDictionaries.cpp
|
|
|
EmbeddedDictionaries.h
|
|
|
evaluateConstantExpression.cpp
|
Allow shard pruning with IN literal
|
2021-06-04 21:16:15 +08:00 |
evaluateConstantExpression.h
|
|
|
executeDDLQueryOnCluster.cpp
|
improve replicated database tests
|
2021-06-15 23:52:29 +03:00 |
executeDDLQueryOnCluster.h
|
|
|
executeQuery.cpp
|
Update comment
|
2021-06-11 23:24:38 +08:00 |
executeQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
Remove a chunk of wrong code and look what will happen
|
2021-06-06 19:28:54 +03:00 |
ExecuteScalarSubqueriesVisitor.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
ExpressionActions.cpp
|
Fixed tests
|
2021-05-24 10:16:12 +03:00 |
ExpressionActions.h
|
Updated ExpressionActionSettings
|
2021-05-19 17:32:07 +03:00 |
ExpressionActionsSettings.cpp
|
Updated ExpressionActionSettings
|
2021-05-19 17:32:07 +03:00 |
ExpressionActionsSettings.h
|
Updated ExpressionActionSettings
|
2021-05-19 17:32:07 +03:00 |
ExpressionAnalyzer.cpp
|
Merge branch 'master' into ast-table-identifier-2
|
2021-06-10 16:43:22 +03:00 |
ExpressionAnalyzer.h
|
Try reusing built sets during multi-pass analysis
|
2021-06-03 22:06:05 +08:00 |
ExpressionJIT.cpp
|
ExpressionJIT remove unnecessary logging
|
2021-05-31 23:17:40 +03:00 |
ExpressionJIT.h
|
CompileExpression cached functions with context fix
|
2021-05-25 21:46:40 +03:00 |
ExternalDictionariesLoader.cpp
|
Merge branch 'master' into rename-const-context-ptr
|
2021-06-07 09:46:24 +00:00 |
ExternalDictionariesLoader.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
ExternalLoader.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
ExternalLoader.h
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
ExternalLoaderDatabaseConfigRepository.h
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
|
|
ExternalLoaderDictionaryStorageConfigRepository.h
|
|
|
ExternalLoaderTempConfigRepository.cpp
|
|
|
ExternalLoaderTempConfigRepository.h
|
|
|
ExternalLoaderXMLConfigRepository.cpp
|
File movement
|
2021-05-29 00:57:53 +03:00 |
ExternalLoaderXMLConfigRepository.h
|
|
|
ExternalModelsLoader.cpp
|
|
|
ExternalModelsLoader.h
|
|
|
ExtractExpressionInfoVisitor.cpp
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
ExtractExpressionInfoVisitor.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
FillingRow.cpp
|
Minor changes
|
2021-06-14 07:13:35 +03:00 |
FillingRow.h
|
Improve implementation
|
2021-05-21 04:17:18 +03:00 |
FunctionNameNormalizer.cpp
|
|
|
FunctionNameNormalizer.h
|
|
|
GetAggregatesVisitor.h
|
|
|
getClusterName.cpp
|
|
|
getClusterName.h
|
|
|
getHeaderForProcessingStage.cpp
|
|
|
getHeaderForProcessingStage.h
|
|
|
getTableExpressions.cpp
|
|
|
getTableExpressions.h
|
|
|
GlobalSubqueriesVisitor.h
|
Add prefer_global_in_and_join setting
|
2021-06-17 14:27:29 +08:00 |
GroupByFunctionKeysVisitor.h
|
A bunch of changes for PVS-Studio
|
2021-05-08 19:11:50 +03:00 |
HashJoin.cpp
|
Merge pull request #24061 from vdimir/issue-23351
|
2021-06-18 11:07:28 +03:00 |
HashJoin.h
|
Fix joinGetOrNull with not-nullable columns
|
2021-06-15 16:34:53 +08:00 |
IdentifierSemantic.cpp
|
|
|
IdentifierSemantic.h
|
|
|
IExternalLoadable.cpp
|
|
|
IExternalLoadable.h
|
|
|
IExternalLoaderConfigRepository.h
|
|
|
IInterpreter.cpp
|
|
|
IInterpreter.h
|
|
|
IInterpreterUnionOrSelectQuery.cpp
|
|
|
IInterpreterUnionOrSelectQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
IJoin.h
|
|
|
InDepthNodeVisitor.h
|
|
|
InJoinSubqueriesPreprocessor.cpp
|
Add prefer_global_in_and_join setting
|
2021-06-17 14:27:29 +08:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
|
|
inplaceBlockConversions.h
|
|
|
InternalTextLogsQueue.cpp
|
|
|
InternalTextLogsQueue.h
|
|
|
InterpreterAlterQuery.cpp
|
Merge pull request #24979 from nvartolomei/nv/parts-uuid-move-shard-acl
|
2021-06-15 17:19:10 +03:00 |
InterpreterAlterQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
|
|
InterpreterCheckQuery.h
|
|
|
InterpreterCreateQuery.cpp
|
Merge branch 'master' into issue-16775
|
2021-06-06 02:18:28 +03:00 |
InterpreterCreateQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterCreateQuotaQuery.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
InterpreterCreateQuotaQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterCreateRoleQuery.cpp
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterpreterCreateRoleQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterCreateRowPolicyQuery.cpp
|
|
|
InterpreterCreateRowPolicyQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterCreateSettingsProfileQuery.cpp
|
|
|
InterpreterCreateSettingsProfileQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterCreateUserQuery.cpp
|
|
|
InterpreterCreateUserQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterDescribeQuery.cpp
|
|
|
InterpreterDescribeQuery.h
|
|
|
InterpreterDropAccessEntityQuery.cpp
|
|
|
InterpreterDropAccessEntityQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterDropQuery.cpp
|
Merge pull request #23657 from kssenii/poco-file-to-std-fs
|
2021-05-31 23:17:02 +03:00 |
InterpreterDropQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterExistsQuery.cpp
|
Mark StorageID::operator bool() as explicit
|
2021-06-08 10:51:22 +03:00 |
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
|
|
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterExternalDDLQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterFactory.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterFactory.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterGrantQuery.cpp
|
|
|
InterpreterGrantQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterInsertQuery.cpp
|
Updated ExpressionActionSettings
|
2021-05-19 17:32:07 +03:00 |
InterpreterInsertQuery.h
|
|
|
InterpreterKillQueryQuery.cpp
|
fix unexpected behavior in mutation finalization
|
2021-05-25 14:10:45 +03:00 |
InterpreterKillQueryQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterOptimizeQuery.cpp
|
|
|
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
|
|
InterpreterRenameQuery.h
|
|
|
InterpreterSelectQuery.cpp
|
Merge pull request #24405 from amosbird/replacemorealias
|
2021-06-18 09:10:31 +03:00 |
InterpreterSelectQuery.h
|
Try reusing built sets during multi-pass analysis
|
2021-06-03 22:06:05 +08:00 |
InterpreterSelectWithUnionQuery.cpp
|
|
|
InterpreterSelectWithUnionQuery.h
|
|
|
InterpreterSetQuery.cpp
|
|
|
InterpreterSetQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterSetRoleQuery.cpp
|
|
|
InterpreterSetRoleQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowAccessEntitiesQuery.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowAccessEntitiesQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowAccessQuery.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
InterpreterShowAccessQuery.h
|
|
|
InterpreterShowCreateAccessEntityQuery.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
InterpreterShowCreateAccessEntityQuery.h
|
|
|
InterpreterShowCreateQuery.cpp
|
|
|
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowGrantsQuery.cpp
|
|
|
InterpreterShowGrantsQuery.h
|
|
|
InterpreterShowPrivilegesQuery.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowPrivilegesQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowProcesslistQuery.cpp
|
|
|
InterpreterShowProcesslistQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowTablesQuery.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterShowTablesQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterSystemQuery.cpp
|
Merge pull request #23657 from kssenii/poco-file-to-std-fs
|
2021-05-31 23:17:02 +03:00 |
InterpreterSystemQuery.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
InterpreterUseQuery.cpp
|
Replace all Context references with std::weak_ptr (#22297)
|
2021-04-11 02:33:54 +03:00 |
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Fix a bunch of warnings from PVS-Studio
|
2021-05-08 19:13:10 +03:00 |
InterpreterWatchQuery.h
|
|
|
interpretSubquery.cpp
|
|
|
interpretSubquery.h
|
|
|
InterserverCredentials.cpp
|
|
|
InterserverCredentials.h
|
|
|
InterserverIOHandler.h
|
|
|
join_common.cpp
|
Check column in removeColumnNullability
|
2021-06-18 14:06:55 +03:00 |
join_common.h
|
Restore correct cardinality in HashJoin
|
2021-05-15 14:39:13 +03:00 |
joinDispatch.h
|
|
|
JoinedTables.cpp
|
|
|
JoinedTables.h
|
|
|
JoinSwitcher.cpp
|
|
|
JoinSwitcher.h
|
|
|
JoinToSubqueryTransformVisitor.cpp
|
Merge branch 'master' into ast-table-identifier-2
|
2021-06-10 16:43:22 +03:00 |
JoinToSubqueryTransformVisitor.h
|
|
|
loadMetadata.cpp
|
Merge pull request #23657 from kssenii/poco-file-to-std-fs
|
2021-05-31 23:17:02 +03:00 |
loadMetadata.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
LogicalExpressionsOptimizer.cpp
|
|
|
LogicalExpressionsOptimizer.h
|
|
|
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
|
|
MergeJoin.cpp
|
Correct cardinality in MergeJoin (same as in input)
|
2021-05-17 14:18:03 +03:00 |
MergeJoin.h
|
Correct cardinality in MergeJoin (same as in input)
|
2021-05-17 14:18:03 +03:00 |
MetricLog.cpp
|
|
|
MetricLog.h
|
|
|
misc.h
|
|
|
MonotonicityCheckVisitor.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
MutationsInterpreter.cpp
|
Merge pull request #25197 from ClickHouse/disable-paln-optimizations-for-mutations
|
2021-06-15 17:15:36 +03:00 |
MutationsInterpreter.h
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
NormalizeSelectWithUnionQueryVisitor.cpp
|
fix tiny code style
|
2021-05-16 14:14:59 +00:00 |
NormalizeSelectWithUnionQueryVisitor.h
|
|
|
NullableUtils.cpp
|
|
|
NullableUtils.h
|
|
|
OpenTelemetrySpanLog.cpp
|
Fix OpenTelemetry
|
2021-05-05 01:42:14 +03:00 |
OpenTelemetrySpanLog.h
|
Fix OpenTelemetry
|
2021-05-05 01:42:14 +03:00 |
OptimizeIfChains.cpp
|
|
|
OptimizeIfChains.h
|
|
|
OptimizeIfWithConstantConditionVisitor.cpp
|
|
|
OptimizeIfWithConstantConditionVisitor.h
|
|
|
OptimizeShardingKeyRewriteInVisitor.cpp
|
|
|
OptimizeShardingKeyRewriteInVisitor.h
|
|
|
PartLog.cpp
|
Fix a bunch of warnings from PVS-Studio
|
2021-05-08 19:13:10 +03:00 |
PartLog.h
|
|
|
PredicateExpressionsOptimizer.cpp
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
PredicateExpressionsOptimizer.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
PredicateRewriteVisitor.cpp
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
PredicateRewriteVisitor.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03:00 |
PreparedSets.h
|
|
|
processColumnTransformers.cpp
|
|
|
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
|
|
ProcessList.h
|
Fix some PVS-Studio warnings
|
2021-05-09 01:10:10 +03:00 |
ProfileEventsExt.cpp
|
|
|
ProfileEventsExt.h
|
|
|
QueryAliasesVisitor.cpp
|
|
|
QueryAliasesVisitor.h
|
|
|
QueryLog.cpp
|
Add initial_query_start_time to query log
|
2021-06-11 22:24:53 +08:00 |
QueryLog.h
|
Projections
|
2021-05-11 18:12:23 +08:00 |
QueryNormalizer.cpp
|
Ban loop aliases in table definitions
|
2021-06-07 23:59:38 +03:00 |
QueryNormalizer.h
|
Ban loop aliases in table definitions
|
2021-06-07 23:59:38 +03:00 |
QueryParameterVisitor.cpp
|
|
|
QueryParameterVisitor.h
|
|
|
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
Add initial_query_start_time to query log
|
2021-06-11 22:24:53 +08:00 |
QueryThreadLog.h
|
|
|
RedundantFunctionsInOrderByVisitor.h
|
Rename ContextConstPtr to ContextPtr.
|
2021-06-01 15:20:52 +03: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
|
|
|
RenameColumnVisitor.h
|
|
|
replaceAliasColumnsInQuery.cpp
|
Fix RBAC test again
|
2021-06-17 23:00:03 +08:00 |
replaceAliasColumnsInQuery.h
|
Fix RBAC test again
|
2021-06-17 23:00:03 +08:00 |
ReplaceQueryParameterVisitor.cpp
|
|
|
ReplaceQueryParameterVisitor.h
|
|
|
RequiredSourceColumnsData.cpp
|
ASTTableIdentifier Part #1: improve internal representation of ASTIdentifier name (#16149)
|
2020-10-24 21:46:10 +03:00 |
RequiredSourceColumnsData.h
|
|
|
RequiredSourceColumnsVisitor.cpp
|
|
|
RequiredSourceColumnsVisitor.h
|
|
|
RewriteAnyFunctionVisitor.cpp
|
|
|
RewriteAnyFunctionVisitor.h
|
|
|
RewriteCountVariantsVisitor.cpp
|
|
|
RewriteCountVariantsVisitor.h
|
|
|
RewriteFunctionToSubcolumnVisitor.cpp
|
fix build
|
2021-05-24 15:57:03 +03:00 |
RewriteFunctionToSubcolumnVisitor.h
|
fix build
|
2021-05-24 15:57:03 +03:00 |
RewriteSumIfFunctionVisitor.cpp
|
Untangle UUID
|
2021-05-04 01:46:51 +03:00 |
RewriteSumIfFunctionVisitor.h
|
|
|
RowRefs.cpp
|
|
|
RowRefs.h
|
|
|
SelectQueryOptions.h
|
Cleanup code.
|
2021-05-11 18:12:26 +08:00 |
Set.cpp
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
Set.h
|
|
|
SetVariants.cpp
|
|
|
SetVariants.h
|
|
|
sortBlock.cpp
|
|
|
sortBlock.h
|
More fixes for PVS-Studio
|
2021-05-08 19:12:31 +03:00 |
SortedBlocksWriter.cpp
|
|
|
SortedBlocksWriter.h
|
|
|
StorageID.cpp
|
Merge branch 'master' into ast-table-identifier-2
|
2021-06-10 16:43:22 +03:00 |
StorageID.h
|
Merge branch 'master' into ast-table-identifier-2
|
2021-06-10 16:43:22 +03:00 |
SubqueryForSet.cpp
|
|
|
SubqueryForSet.h
|
|
|
SystemLog.cpp
|
|
|
SystemLog.h
|
Merge ext into common
|
2021-06-16 23:28:41 +03:00 |
TableJoin.cpp
|
StorageJoin clashing column name with JOIN ON
|
2021-05-10 17:56:12 +03:00 |
TableJoin.h
|
Update TableJoin.h
|
2021-06-11 17:47:30 +03:00 |
TablesStatus.cpp
|
|
|
TablesStatus.h
|
|
|
TextLog.cpp
|
|
|
TextLog.h
|
More fixes for PVS-Studio
|
2021-05-08 19:12:31 +03:00 |
ThreadStatusExt.cpp
|
Make ContextPtr const by default.
|
2021-05-31 17:49:02 +03:00 |
TraceLog.cpp
|
|
|
TraceLog.h
|
|
|
TranslateQualifiedNamesVisitor.cpp
|
|
|
TranslateQualifiedNamesVisitor.h
|
|
|
TreeOptimizer.cpp
|
Merge branch 'master' into rename-const-context-ptr
|
2021-06-12 03:25:09 +03:00 |
TreeOptimizer.h
|
Merge branch 'master' into rename-const-context-ptr
|
2021-06-12 03:25:09 +03:00 |
TreeRewriter.cpp
|
Fix RBAC test again
|
2021-06-17 23:00:03 +08:00 |
TreeRewriter.h
|
Fix RBAC test again
|
2021-06-17 23:00:03 +08:00 |
WindowDescription.cpp
|
Minor changes
|
2021-06-14 07:13:35 +03:00 |
WindowDescription.h
|
Untangle UUID
|
2021-05-04 01:46:51 +03:00 |
ya.make
|
RewriteFunctionToSubcolumnVisitor add into ya.make
|
2021-06-10 11:41:16 +03:00 |
ya.make.in
|
|
|