ClickHouse/src/Interpreters
2023-08-09 05:02:50 +02:00
..
Access Implemented max sessions for user 2023-07-30 22:09:03 +00:00
Cache Merge pull request #53055 from kssenii/fix-rare-race-on-key-prefix-directory-cleanup 2023-08-07 15:38:46 +02:00
ClusterProxy Change signature of the updateSettingsForCluster() to avoid cluster requirement 2023-07-24 05:50:44 +02:00
examples Do not use PackedHashMap for non-POD for the purposes of layout 2023-05-19 06:07:21 +02:00
fuzzers
JIT Fixed tests 2023-06-20 11:42:22 +03:00
MySQL
tests Update gtest_lru_file_cache.cpp 2023-07-22 12:03:20 +02:00
ActionLocksManager.cpp Add system stop pulling replication log (#52881) 2023-08-03 13:34:43 +03:00
ActionLocksManager.h
ActionsDAG.cpp Merge remote-tracking branch 'origin/master' into fix_remove_redundant_distinct_with_view 2023-07-22 18:10:24 +00:00
ActionsDAG.h
ActionsVisitor.cpp style convertFieldToTypeStrict 2023-08-04 09:45:13 +00:00
ActionsVisitor.h
AddDefaultDatabaseVisitor.h
AddIndexConstraintsOptimizer.cpp
AddIndexConstraintsOptimizer.h
addMissingDefaults.cpp
addMissingDefaults.h
addTypeConversionToAST.cpp
addTypeConversionToAST.h
AggregateDescription.cpp
AggregateDescription.h
AggregateFunctionOfGroupByKeysVisitor.h
AggregationCommon.h
AggregationUtils.cpp
AggregationUtils.h
Aggregator.cpp Fix memory consumption when max_block_size is huge in Aggregator + more memory checks (#51566) 2023-08-02 15:11:52 +02:00
Aggregator.h Fix memory consumption when max_block_size is huge in Aggregator + more memory checks (#51566) 2023-08-02 15:11:52 +02:00
Aliases.h
applyTableOverride.cpp
applyTableOverride.h
ApplyWithAliasVisitor.cpp
ApplyWithAliasVisitor.h Global WITH and WITH propagation. 2020-10-08 15:03:34 +08:00
ApplyWithGlobalVisitor.cpp
ApplyWithGlobalVisitor.h
ApplyWithSubqueryVisitor.cpp
ApplyWithSubqueryVisitor.h
ArithmeticOperationsInAgrFuncOptimize.cpp
ArithmeticOperationsInAgrFuncOptimize.h
ArrayJoinAction.cpp
ArrayJoinAction.h
ArrayJoinedColumnsVisitor.h
AsynchronousInsertLog.cpp Log async query flushes to query_log 2023-06-20 11:38:19 +02:00
AsynchronousInsertLog.h Log async query flushes to query_log 2023-06-20 11:38:19 +02:00
AsynchronousInsertQueue.cpp System logs improvements 2023-07-28 07:23:34 +00:00
AsynchronousInsertQueue.h Merge remote-tracking branch 'upstream/master' into HEAD 2023-07-24 10:55:31 +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 Better usage of ccache 2023-08-09 05:02:50 +02:00
ClientInfo.h
Cluster.cpp Initialize weight/slot_to_shards for cluster not from xml correcty 2023-06-28 19:07:14 +02:00
Cluster.h Remove non existing ctor of Cluster::Address 2023-07-24 05:50:44 +02:00
ClusterDiscovery.cpp Unify priorities for connections 2023-06-07 16:25:52 +00: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 addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
ConcurrentHashJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
Context_fwd.h
Context.cpp Merge pull request #52954 from ClickHouse/fix-error-code 2023-08-04 16:26:33 +03:00
Context.h Merge branch 'master' into disable-fs-cache-for-backups 2023-08-04 01:15:23 +02:00
convertFieldToType.cpp style convertFieldToTypeStrict 2023-08-04 09:45:13 +00:00
convertFieldToType.h style convertFieldToTypeStrict 2023-08-04 09:45:13 +00:00
ConvertFunctionOrLikeVisitor.cpp
ConvertFunctionOrLikeVisitor.h
ConvertStringsToEnumVisitor.cpp
ConvertStringsToEnumVisitor.h
CrashLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
CrashLog.h System logs improvements 2023-07-28 07:23:34 +00:00
createBlockSelector.cpp Convert assert to LOGICAL_ERROR in createBlockSelector() for zero weight 2023-06-28 19:06:31 +02:00
createBlockSelector.h
CrossToInnerJoinVisitor.cpp
CrossToInnerJoinVisitor.h
DatabaseAndTableWithAlias.cpp
DatabaseAndTableWithAlias.h
DatabaseCatalog.cpp Revert "Merge pull request #53044 from ClickHouse/revert-52155-database-filesystem-remove-catch" 2023-08-04 12:41:55 +02:00
DatabaseCatalog.h more fair queue for drop table sync (#52276) 2023-07-20 14:51:01 +03:00
DDLTask.cpp Remove non-const function Context::getClientInfo(). 2023-07-17 15:02:07 +02:00
DDLTask.h Preserve initial_query_id for ON CLUSTER queries 2023-05-21 23:04:54 +02:00
DDLWorker.cpp Check for punctuation 2023-07-25 06:10:04 +02:00
DDLWorker.h
DirectJoin.cpp addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
DirectJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
DNSCacheUpdater.cpp
DNSCacheUpdater.h
DuplicateOrderByVisitor.cpp
DuplicateOrderByVisitor.h
EmbeddedDictionaries.cpp
EmbeddedDictionaries.h
evaluateConstantExpression.cpp Better version 2023-07-17 04:49:04 +02:00
evaluateConstantExpression.h
executeDDLQueryOnCluster.cpp Do not replicate ALTER TABLE t FREEZE on Replicated engine (#52064) 2023-08-02 14:39:54 +03:00
executeDDLQueryOnCluster.h Do not replicate ALTER TABLE t FREEZE on Replicated engine (#52064) 2023-08-02 14:39:54 +03:00
executeQuery.cpp Include query cache usage in SYSTEM.QUERY_LOG 2023-07-24 16:24:36 +00:00
executeQuery.h Include query cache usage in SYSTEM.QUERY_LOG 2023-07-24 16:24:36 +00:00
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 Remove isReady from FutureSet iface. 2023-06-19 12:56:24 +00:00
ExpressionActions.h
ExpressionActionsSettings.cpp
ExpressionActionsSettings.h
ExpressionAnalyzer.cpp select required columns when getting join 2023-08-07 03:15:20 +00:00
ExpressionAnalyzer.h Slightly more changes 2023-07-16 03:14:44 +02:00
ExpressionJIT.cpp JIT infrastructure refactoring 2023-06-20 11:42:22 +03:00
ExternalDictionariesLoader.cpp
ExternalDictionariesLoader.h
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 Revert "Merge pull request #51917 from ClickHouse/revert-system-drop-filesystem-cache-by-key" 2023-07-30 13:39:54 +02:00
FilesystemCacheLog.h Revert "Merge pull request #51917 from ClickHouse/revert-system-drop-filesystem-cache-by-key" 2023-07-30 13:39:54 +02:00
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 addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
FunctionMaskingArgumentCheckVisitor.h
FunctionNameNormalizer.cpp
FunctionNameNormalizer.h
GatherFunctionQuantileVisitor.cpp
GatherFunctionQuantileVisitor.h
GetAggregatesVisitor.cpp Fix ORDER BY tuple of WINDOW functions 2023-07-16 02:52:06 +02:00
GetAggregatesVisitor.h Slightly more changes 2023-07-16 03:14:44 +02:00
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 Cleanup. 2023-06-22 14:23:04 +00:00
GraceHashJoin.cpp update 2023-07-20 18:22:01 +08:00
GraceHashJoin.h wip: grace hash join support full & right join 2023-07-20 18:22:01 +08:00
GroupByFunctionKeysVisitor.h
GroupingSetsRewriterVisitor.cpp
GroupingSetsRewriterVisitor.h
HashJoin.cpp wip: reserve hash table size (#50875) 2023-07-10 10:44:01 +02:00
HashJoin.h wip: reserve hash table size (#50875) 2023-07-10 10:44:01 +02:00
IdentifierSemantic.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
IdentifierSemantic.h
IExternalLoadable.cpp
IExternalLoadable.h
IExternalLoaderConfigRepository.h
IInterpreter.cpp
IInterpreter.h
IInterpreterUnionOrSelectQuery.cpp
IInterpreterUnionOrSelectQuery.h
IJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
IKeyValueEntity.h
InDepthNodeVisitor.h
InJoinSubqueriesPreprocessor.cpp
InJoinSubqueriesPreprocessor.h
inplaceBlockConversions.cpp fix reading of empty Nested(Array(LowCardinality(...))) 2023-08-02 16:48:08 +00:00
inplaceBlockConversions.h
InternalTextLogsQueue.cpp
InternalTextLogsQueue.h
InterpreterAlterNamedCollectionQuery.cpp
InterpreterAlterNamedCollectionQuery.h
InterpreterAlterQuery.cpp Remove ALTER of LIVE VIEW 2023-06-22 20:32:29 +02:00
InterpreterAlterQuery.h
InterpreterBackupQuery.cpp
InterpreterBackupQuery.h
InterpreterCheckQuery.cpp
InterpreterCheckQuery.h
InterpreterCreateFunctionQuery.cpp
InterpreterCreateFunctionQuery.h
InterpreterCreateIndexQuery.cpp style 2023-07-19 15:03:48 +00:00
InterpreterCreateIndexQuery.h
InterpreterCreateNamedCollectionQuery.cpp Fix named collections related statements #51609 2023-07-27 09:41:47 +03:00
InterpreterCreateNamedCollectionQuery.h
InterpreterCreateQuery.cpp Merge branch 'master' into azure_blob_storage_sas_token 2023-07-17 17:23:29 +02:00
InterpreterCreateQuery.h bugfix 2023-07-03 19:10:39 +03:00
InterpreterDeleteQuery.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
InterpreterDeleteQuery.h
InterpreterDescribeCacheQuery.cpp Merge remote-tracking branch 'upstream/master' into min-file-segment-size 2023-06-29 19:36:13 +02:00
InterpreterDescribeCacheQuery.h
InterpreterDescribeQuery.cpp Added option to check if container exists before attempting to read/create it, added this flag for all table functions, only used in azureBlobStorage 2023-07-06 10:56:07 +02:00
InterpreterDescribeQuery.h
InterpreterDropFunctionQuery.cpp Split UserDefinedSQLObjectsLoader to interface and implementation. 2022-10-13 10:32:32 +02:00
InterpreterDropFunctionQuery.h
InterpreterDropIndexQuery.cpp
InterpreterDropIndexQuery.h
InterpreterDropNamedCollectionQuery.cpp Fix named collections related statements #51609 2023-07-27 09:41:47 +03:00
InterpreterDropNamedCollectionQuery.h
InterpreterDropQuery.cpp Merge branch 'master' into add_delay_for_replicated 2023-07-22 12:11:39 +02:00
InterpreterDropQuery.h Fix race between DROP MatView and RESTART REPLICAS (#47863) 2023-04-01 15:26:00 +03:00
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
InterpreterKillQueryQuery.cpp
InterpreterKillQueryQuery.h
InterpreterOptimizeQuery.cpp Support OPTIMIZE for temporary tables (#50710) 2023-06-09 14:31:49 +03:00
InterpreterOptimizeQuery.h
InterpreterRenameQuery.cpp Check for punctuation 2023-07-25 06:10:04 +02:00
InterpreterRenameQuery.h
InterpreterSelectIntersectExceptQuery.cpp
InterpreterSelectIntersectExceptQuery.h
InterpreterSelectQuery.cpp Merge pull request #52569 from ClickHouse/Realize_parameterized_view_as_new_storage_view 2023-07-30 05:46:51 +03:00
InterpreterSelectQuery.h Disable pure parallel replicas if trivial count optimization is possible (#50594) 2023-06-06 18:38:32 +02:00
InterpreterSelectQueryAnalyzer.cpp Add a comment 2023-06-12 13:54:45 +00:00
InterpreterSelectQueryAnalyzer.h Trying to fix a test. 2023-06-14 18:10:30 +00:00
InterpreterSelectWithUnionQuery.cpp
InterpreterSelectWithUnionQuery.h
InterpreterSetQuery.cpp Implemented max sessions for user 2023-07-30 22:09:03 +00:00
InterpreterSetQuery.h Ignore setting constraints for projection ASTs 2023-07-12 10:34:36 +08:00
InterpreterShowColumnsQuery.cpp
InterpreterShowColumnsQuery.h
InterpreterShowCreateQuery.cpp
InterpreterShowCreateQuery.h
InterpreterShowEngineQuery.cpp
InterpreterShowEngineQuery.h
InterpreterShowIndexesQuery.cpp Incorporate review feedback 2023-07-06 15:03:15 +00:00
InterpreterShowIndexesQuery.h Initial version of SHOW INDEXES 2023-04-25 20:48:11 +00:00
InterpreterShowProcesslistQuery.cpp
InterpreterShowProcesslistQuery.h
InterpreterShowTablesQuery.cpp
InterpreterShowTablesQuery.h
InterpreterSystemQuery.cpp Add system stop pulling replication log (#52881) 2023-08-03 13:34:43 +03:00
InterpreterSystemQuery.h
InterpreterTransactionControlQuery.cpp
InterpreterTransactionControlQuery.h
InterpreterUndropQuery.cpp
InterpreterUndropQuery.h
InterpreterUseQuery.cpp
InterpreterUseQuery.h
InterpreterWatchQuery.cpp
InterpreterWatchQuery.h
interpretSubquery.cpp Revert "Trying to fix a test." 2023-06-15 16:42:38 +00:00
interpretSubquery.h Revert "Trying to fix a test." 2023-06-15 16:42:38 +00:00
InterserverCredentials.cpp
InterserverCredentials.h
InterserverIOHandler.h
ITokenExtractor.cpp
ITokenExtractor.h
joinDispatch.h
JoinedTables.cpp disable direct join for range dictionary 2023-07-17 08:16:58 +00:00
JoinedTables.h
JoinSwitcher.cpp addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
JoinSwitcher.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
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 Merge pull request #52956 from ClickHouse/fixes_for_databases 2023-08-03 19:13:41 +03:00
loadMetadata.h
LogicalExpressionsOptimizer.cpp
LogicalExpressionsOptimizer.h
MarkTableIdentifiersVisitor.cpp
MarkTableIdentifiersVisitor.h
MergeJoin.cpp Fix usage of temporary directories during RESTORE 2023-07-27 19:24:54 +02:00
MergeJoin.h addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
MergeTreeTransaction.cpp Update MergeTreeTransaction.cpp 2023-06-26 13:44:09 +03:00
MergeTreeTransaction.h
MergeTreeTransactionHolder.cpp
MergeTreeTransactionHolder.h
MetricLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
MetricLog.h
misc.h
MonotonicityCheckVisitor.h
MutationsInterpreter.cpp fix again 2023-06-05 01:48:13 +08:00
MutationsInterpreter.h Proper mutation of skip indices and projections 2023-06-04 18:32:08 +08: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
OpenTelemetrySpanLog.h
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp use UTC LUT 2023-07-05 11:57:18 +02:00
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h Revert "Revert "Merge pull request #50951 from ZhiguoZh/20230607-toyear-fix"" 2023-07-04 17:38:53 +02:00
OptimizeIfChains.cpp
OptimizeIfChains.h
OptimizeIfWithConstantConditionVisitor.cpp
OptimizeIfWithConstantConditionVisitor.h
OptimizeShardingKeyRewriteInVisitor.cpp Fix implicit cast for optimize_skip_unused_shards_rewrite_in 2022-05-12 16:17:30 +03:00
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 System logs improvements 2023-07-28 07:23:34 +00:00
PartLog.h
PredicateExpressionsOptimizer.cpp Do not apply PredicateExpressionsOptimizer for ASOF/ANTI join 2023-06-29 17:12:55 +00:00
PredicateExpressionsOptimizer.h
PredicateRewriteVisitor.cpp
PredicateRewriteVisitor.h
PreparedSets.cpp Fix stupid bug. 2023-06-22 18:15:16 +00:00
PreparedSets.h Cleanup. 2023-06-22 14:23:04 +00:00
processColumnTransformers.cpp
processColumnTransformers.h
ProcessList.cpp Revert "Revert "Add an ability to specify allocations size for sampling memory profiler"" 2023-07-30 14:01:34 +02:00
ProcessList.h Merge branch 'master' into async_to_query_log 2023-06-27 13:12:13 +02:00
ProcessorsProfileLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
ProcessorsProfileLog.h System logs improvements 2023-07-28 07:23:34 +00:00
ProfileEventsExt.cpp Add peak memory usage (prototype) 2023-06-28 09:31:44 +00:00
ProfileEventsExt.h Add peak memory usage (prototype) 2023-06-28 09:31:44 +00:00
QueryAliasesVisitor.cpp
QueryAliasesVisitor.h
QueryLog.cpp Incorporate review feedback 2023-07-27 08:55:19 +00:00
QueryLog.h Include query cache usage in SYSTEM.QUERY_LOG 2023-07-24 16:24:36 +00:00
QueryNormalizer.cpp
QueryNormalizer.h
QueryPriorities.h
QueryThreadLog.cpp
QueryThreadLog.h
QueryViewsLog.cpp
QueryViewsLog.h
RedundantFunctionsInOrderByVisitor.h
RemoveInjectiveFunctionsVisitor.cpp
RemoveInjectiveFunctionsVisitor.h
RenameColumnVisitor.cpp
RenameColumnVisitor.h
replaceAliasColumnsInQuery.cpp
replaceAliasColumnsInQuery.h
replaceForPositionalArguments.cpp
replaceForPositionalArguments.h
ReplaceQueryParameterVisitor.cpp
ReplaceQueryParameterVisitor.h
RequiredSourceColumnsData.cpp
RequiredSourceColumnsData.h
RequiredSourceColumnsVisitor.cpp
RequiredSourceColumnsVisitor.h
RewriteAnyFunctionVisitor.cpp
RewriteAnyFunctionVisitor.h
RewriteArrayExistsFunctionVisitor.cpp
RewriteArrayExistsFunctionVisitor.h add passes for rewriting arrayexists 2023-02-09 16:30:53 +08:00
RewriteCountDistinctVisitor.cpp
RewriteCountDistinctVisitor.h
RewriteCountVariantsVisitor.cpp
RewriteCountVariantsVisitor.h
RewriteFunctionToSubcolumnVisitor.cpp
RewriteFunctionToSubcolumnVisitor.h
RewriteOrderByVisitor.cpp
RewriteOrderByVisitor.hpp Fix: clear children in order by element during rewriting 2022-07-05 22:48:48 +00:00
RewriteSumIfFunctionVisitor.cpp
RewriteSumIfFunctionVisitor.h
RowRefs.cpp
RowRefs.h
SelectIntersectExceptQueryVisitor.cpp
SelectIntersectExceptQueryVisitor.h
SelectQueryOptions.h Ignore setting constraints for projection ASTs 2023-07-12 10:34:36 +08:00
ServerAsynchronousMetrics.cpp Add query cache metrics to system.asynchronous_metrics 2023-07-27 15:19:01 +00:00
ServerAsynchronousMetrics.h
Session.cpp Added new tests for session_log plus bugfix 2023-08-03 22:06:33 +00:00
Session.h Added new tests for session_log plus bugfix 2023-08-03 22:06:33 +00:00
SessionLog.cpp Added new tests for session_log plus bugfix 2023-08-03 22:06:33 +00:00
SessionLog.h Added new tests for session_log plus bugfix 2023-08-03 22:06:33 +00:00
SessionTracker.cpp Implemented max sessions for user 2023-07-30 22:09:03 +00:00
SessionTracker.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
Set.cpp Fix check. 2023-06-22 19:21:08 +00:00
Set.h Cleanup. 2023-06-22 14:23:04 +00:00
SetKeys.h Cleanup. 2023-06-22 14:23:04 +00:00
SetVariants.cpp
SetVariants.h
sortBlock.cpp Fixed build 2023-06-19 13:02:35 +03:00
sortBlock.h Sort block improvements 2023-06-18 12:52:08 +03:00
SortedBlocksWriter.cpp Fix usage of temporary directories during RESTORE 2023-07-27 19:24:54 +02:00
SortedBlocksWriter.h
SquashingTransform.cpp
SquashingTransform.h
StorageID.cpp
StorageID.h
SubstituteColumnOptimizer.cpp
SubstituteColumnOptimizer.h
SynonymsExtensions.cpp
SynonymsExtensions.h
SystemLog.cpp Update SystemLog.cpp (#52858) 2023-08-02 15:18:57 +03:00
SystemLog.h System logs improvements 2023-07-28 07:23:34 +00:00
TableJoin.cpp Fixing build. 2023-06-08 17:56:35 +00:00
TableJoin.h StorageJoin: do not create clone hash join with all columns 2023-08-04 11:07:33 +00:00
TableOverrideUtils.cpp
TableOverrideUtils.h
TablesStatus.cpp
TablesStatus.h
TemporaryDataOnDisk.cpp Fix usage of temporary directories during RESTORE 2023-07-27 19:24:54 +02:00
TemporaryDataOnDisk.h
TextLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TextLog.h System logs improvements 2023-07-28 07:23:34 +00:00
threadPoolCallbackRunner.h Rework loading and removing of data parts for MergeTree tables. (#49474) 2023-06-06 14:42:56 +02:00
ThreadStatusExt.cpp metrics_perf_events_enabled turn off in perf tests (#52072) 2023-08-07 23:25:16 +02:00
TraceCollector.cpp Merge branch 'master' into revert-44629-revert_flamegraph 2023-08-01 17:14:16 +00:00
TraceCollector.h
TraceLog.cpp
TraceLog.h
TransactionLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TransactionLog.h
TransactionsInfoLog.cpp System logs improvements 2023-07-28 07:23:34 +00:00
TransactionsInfoLog.h
TransactionVersionMetadata.cpp
TransactionVersionMetadata.h
TranslateQualifiedNamesVisitor.cpp Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02:00
TranslateQualifiedNamesVisitor.h Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02:00
TreeCNFConverter.cpp
TreeCNFConverter.h
TreeOptimizer.cpp Merge remote-tracking branch 'origin/master' into remove-perf-test-duplicate-order-by-and-distinct 2023-07-18 14:26:22 +00:00
TreeOptimizer.h fix crash with multiif and constant condition and nullable arguments 2023-05-22 23:31:50 +00:00
TreeRewriter.cpp Merge branch 'master' into count-distinct-if 2023-07-31 18:53:06 +08:00
TreeRewriter.h Merge pull request #52569 from ClickHouse/Realize_parameterized_view_as_new_storage_view 2023-07-30 05:46:51 +03:00
WhereConstraintsOptimizer.cpp
WhereConstraintsOptimizer.h
WindowDescription.cpp Allow Floats as boundaries for RANGE is nonsense 2023-07-30 23:19:54 +00:00
WindowDescription.h
ZooKeeperLog.cpp "reconfig" support for CH Keeper 2023-07-07 00:20:54 +03:00
ZooKeeperLog.h