.. |
Access
|
Move parsing into a separate function
|
2024-07-15 00:52:31 +00:00 |
Cache
|
Merge pull request #67801 from ClickHouse/kssenii-patch-12
|
2024-08-05 15:57:50 +00:00 |
ClusterProxy
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
examples
|
Fix build
|
2024-07-24 19:51:22 +02:00 |
fuzzers
|
fix rest
|
2024-07-29 17:13:05 +01:00 |
HashJoin
|
Merge pull request #64281 from bigo-sg/extend_inequal_join
|
2024-08-09 21:36:31 +00:00 |
JIT
|
Delete unneeded changes
|
2024-07-09 20:17:01 +00:00 |
MySQL
|
Merge pull request #66506 from ClickHouse/ast-data-type
|
2024-07-29 16:08:11 +00:00 |
tests
|
Move unit tests to gtest_convertFieldToType.cpp
|
2024-07-23 15:07:18 +08:00 |
ActionLocksManager.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
ActionLocksManager.h
|
|
|
ActionsDAG.cpp
|
Avoid converting type to string and back in _CAST
|
2024-08-09 11:51:23 +00:00 |
ActionsDAG.h
|
Fix anotehr one case of non-deterministic PK
|
2024-07-29 16:21:55 +00:00 |
ActionsVisitor.cpp
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
ActionsVisitor.h
|
Better.
|
2024-07-18 17:06:03 +00:00 |
AddDefaultDatabaseVisitor.h
|
fix for multiple WITH
|
2024-08-07 18:50:19 +00:00 |
AddIndexConstraintsOptimizer.cpp
|
Fix most tests
|
2024-02-26 02:31:58 +08:00 |
AddIndexConstraintsOptimizer.h
|
|
|
addMissingDefaults.cpp
|
Change ActionsDAGPtr to ActionsDAG where possible.
|
2024-07-05 17:49:50 +00:00 |
addMissingDefaults.h
|
Better.
|
2024-07-18 17:06:03 +00:00 |
addTypeConversionToAST.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
addTypeConversionToAST.h
|
|
|
AggregatedData.h
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregatedDataVariants.cpp
|
Reapply "Remove some unnecessary UNREACHABLE s"
|
2024-05-29 13:37:47 +00:00 |
AggregatedDataVariants.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
AggregateDescription.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregateDescription.h
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregateFunctionOfGroupByKeysVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
AggregationCommon.h
|
Fix broken multi-column aggregation on s390x
|
2024-06-10 10:52:35 -07:00 |
AggregationMethod.cpp
|
Fix broken multi-column aggregation on s390x
|
2024-06-10 10:52:35 -07:00 |
AggregationMethod.h
|
too big translation unit in Aggregator
|
2024-03-12 16:17:33 +08:00 |
AggregationUtils.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
AggregationUtils.h
|
|
|
Aggregator.cpp
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into fix-memory-leak-nullkey-distinct
|
2024-08-05 10:24:39 +00:00 |
Aggregator.h
|
cache hash table sizes in ConcurrentHJ
|
2024-05-30 17:38:58 +01:00 |
Aliases.h
|
|
|
applyTableOverride.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
applyTableOverride.h
|
|
|
ApplyWithAliasVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ApplyWithAliasVisitor.h
|
|
|
ApplyWithGlobalVisitor.cpp
|
Make clang-tidy happy
|
2022-10-18 11:40:12 +02:00 |
ApplyWithGlobalVisitor.h
|
|
|
ApplyWithSubqueryVisitor.cpp
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ApplyWithSubqueryVisitor.h
|
Add more checkStackSize calls
|
2022-10-01 17:48:56 +02:00 |
ArithmeticOperationsInAgrFuncOptimize.cpp
|
fix logic + better test
|
2023-02-22 13:30:57 +08:00 |
ArithmeticOperationsInAgrFuncOptimize.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ArrayJoinAction.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
ArrayJoinAction.h
|
Respect max_block_size for array join to avoid possible OOM
|
2023-09-18 11:04:38 +08:00 |
ArrayJoinedColumnsVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
AsynchronousInsertLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
AsynchronousInsertLog.h
|
Update to clang-19
|
2024-02-27 14:37:21 +01:00 |
AsynchronousInsertQueue.cpp
|
Merge branch 'master' into revert-66134-revert-61601-chesema-dedup-matview
|
2024-07-11 18:01:12 +02:00 |
AsynchronousInsertQueue.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
AsynchronousMetricLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
AsynchronousMetricLog.h
|
Remove unused headers
|
2024-06-18 08:37:40 +00:00 |
BackupLog.cpp
|
add event_time to backup_log system table
|
2024-04-11 10:22:02 +01:00 |
BackupLog.h
|
Done
|
2024-04-15 16:19:54 +00:00 |
BlobStorageLog.cpp
|
fix race in BlobStorageLog::shouldIgnorePath
|
2024-06-04 11:14:03 +00:00 |
BlobStorageLog.h
|
fix race in BlobStorageLog::shouldIgnorePath
|
2024-06-04 11:14:03 +00:00 |
BloomFilter.cpp
|
Reuse granule during skip index reading
|
2023-10-18 14:40:34 +08:00 |
BloomFilter.h
|
Reuse granule during skip index reading
|
2023-10-18 14:40:34 +08:00 |
BloomFilterHash.h
|
Avoid crashing on column type mismatch in a few dozen places
|
2024-05-06 22:09:02 +00:00 |
CancellationCode.h
|
Useless changes
|
2024-05-09 02:07:04 +02:00 |
castColumn.cpp
|
Avoid converting type to string and back in _CAST
|
2024-08-09 11:51:23 +00:00 |
castColumn.h
|
Remove C++ templates
|
2023-11-10 05:25:02 +01:00 |
ClientInfo.cpp
|
Support prometheus remote write protocol.
|
2024-08-03 16:20:23 +02:00 |
ClientInfo.h
|
Support prometheus remote write protocol.
|
2024-08-03 16:20:23 +02:00 |
Cluster.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
Cluster.h
|
Fix addShard()
|
2023-12-05 18:07:51 +00:00 |
ClusterDiscovery.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
ClusterDiscovery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
CMakeLists.txt
|
|
|
CollectJoinOnKeysVisitor.cpp
|
Support 'is not distinct from' in join on section
|
2023-08-28 11:41:36 +00:00 |
CollectJoinOnKeysVisitor.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
ColumnAliasesVisitor.cpp
|
|
|
ColumnAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ComparisonGraph.cpp
|
Reapply "Remove some unnecessary UNREACHABLE s"
|
2024-05-29 13:37:47 +00:00 |
ComparisonGraph.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
ComparisonTupleEliminationVisitor.cpp
|
Better ComparisonTupleEliminationVisitor
|
2023-03-21 16:23:09 +00:00 |
ComparisonTupleEliminationVisitor.h
|
Add ComparisonTupleEliminationVisitor
|
2023-03-21 16:11:06 +00:00 |
ConcurrentHashJoin.cpp
|
Replace updateWeakHash to getWeakHash
|
2024-07-17 13:23:44 +00:00 |
ConcurrentHashJoin.h
|
Merge branch 'master' into concurrent_hash_join_cache_ht_sizes
|
2024-07-03 19:35:48 +01:00 |
Context_fwd.h
|
Useless changes
|
2024-05-09 02:07:04 +02:00 |
Context.cpp
|
Merge pull request #66843 from ClickHouse/fix_getddlworker_deadlock
|
2024-08-01 17:35:43 +00:00 |
Context.h
|
Merge pull request #66528 from Algunenano/getSettingsCopy
|
2024-07-31 09:55:21 +00:00 |
convertFieldToType.cpp
|
Merge branch 'master' into vdimir/analyzer_external_query_fix
|
2024-08-06 12:25:39 +02:00 |
convertFieldToType.h
|
fix failed code style check
|
2024-06-17 04:25:57 +08:00 |
ConvertFunctionOrLikeVisitor.cpp
|
Move likePatternToRegexp from Functions/ to Common/
|
2023-02-27 16:41:15 +00:00 |
ConvertFunctionOrLikeVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
ConvertStringsToEnumVisitor.cpp
|
Fix some typos
|
2023-10-15 15:43:02 +02:00 |
ConvertStringsToEnumVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
CrashLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
CrashLog.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01: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
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
CrossToInnerJoinVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
DatabaseAndTableWithAlias.cpp
|
Revert "Revert "Check stack size in Parser""
|
2024-02-27 01:34:50 +03:00 |
DatabaseAndTableWithAlias.h
|
Improve Asterisk and ColumnMatcher parser
|
2022-11-02 06:21:02 +00:00 |
DatabaseCatalog.cpp
|
Better
|
2024-07-31 17:58:41 +02:00 |
DatabaseCatalog.h
|
Moved settings to ServerSettings and made the table drop even faster
|
2024-07-30 00:39:29 +02:00 |
DDLTask.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
DDLTask.h
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
DDLWorker.cpp
|
Less indirect dependencies on Settings.h
|
2024-07-11 17:33:14 +02:00 |
DDLWorker.h
|
automatically recover Replicated database if the queue got stuck
|
2024-05-09 00:00:51 +02:00 |
DirectJoin.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DirectJoin.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
DNSCacheUpdater.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DNSCacheUpdater.h
|
|
|
DuplicateOrderByVisitor.cpp
|
Move handling of RESPECT NULLS outside of the parser
|
2023-11-27 11:00:27 +01:00 |
DuplicateOrderByVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
EmbeddedDictionaries.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
EmbeddedDictionaries.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ErrorLog.cpp
|
Consolidate code into PeriodicLog
|
2024-06-20 16:22:18 +00:00 |
ErrorLog.h
|
Consolidate code into PeriodicLog
|
2024-06-20 16:22:18 +00:00 |
evaluateConstantExpression.cpp
|
Remove ActionsDAGPtr completely.
|
2024-07-25 15:37:13 +00:00 |
evaluateConstantExpression.h
|
Merge branch 'master' into planner-prepare-filters-for-analysis-2
|
2023-09-11 16:14:03 +02:00 |
executeDDLQueryOnCluster.cpp
|
impl
|
2024-07-17 16:59:31 +01:00 |
executeDDLQueryOnCluster.h
|
Move ZooKeeperRetries.h to Common
|
2024-01-30 19:02:17 +01:00 |
executeQuery.cpp
|
Validate also alias
|
2024-08-05 15:29:15 +00:00 |
executeQuery.h
|
Fix writing exception message in output format in HTTP when http_wait_end_of_query is used
|
2024-03-22 16:03:28 +00:00 |
ExecuteScalarSubqueriesVisitor.cpp
|
Rename Context::getSettings()
|
2024-07-15 14:28:12 +02:00 |
ExecuteScalarSubqueriesVisitor.h
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
ExpressionActions.cpp
|
Merge pull request #67520 from Avogar/fix-short-circuit
|
2024-07-31 22:06:38 +00:00 |
ExpressionActions.h
|
Conflicts
|
2024-08-05 21:57:23 +00:00 |
ExpressionActionsSettings.cpp
|
|
|
ExpressionActionsSettings.h
|
Less deps for SettingsEnums.h
|
2024-07-10 19:43:50 +02:00 |
ExpressionAnalyzer.cpp
|
support percent_rank in old analyzer
|
2024-08-07 08:57:56 +08:00 |
ExpressionAnalyzer.h
|
support percent_rank in old analyzer
|
2024-08-07 08:57:56 +08:00 |
ExpressionJIT.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
ExternalDictionariesLoader.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
ExternalDictionariesLoader.h
|
Better code: remove unnecessary usage of const_cast and std::function.
|
2024-03-19 02:56:38 +01:00 |
ExternalLoader.cpp
|
Fix dictionary hang in case of CANNOT_SCHEDULE_TASK while loading
|
2024-08-04 15:48:59 +02:00 |
ExternalLoader.h
|
Modify the code for build with new libcxx
|
2024-07-09 20:16:43 +00:00 |
ExternalLoaderDictionaryStorageConfigRepository.cpp
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderDictionaryStorageConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderTempConfigRepository.cpp
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderTempConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExternalLoaderXMLConfigRepository.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
ExternalLoaderXMLConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
ExtractExpressionInfoVisitor.cpp
|
|
|
ExtractExpressionInfoVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
FilesystemCacheLog.cpp
|
Sync code back from private to public repo
|
2024-05-28 10:31:29 +00:00 |
FilesystemCacheLog.h
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
FilesystemReadPrefetchesLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
FilesystemReadPrefetchesLog.h
|
Useless changes
|
2024-05-09 01:08:33 +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
|
Introduce ASTDataType
|
2024-07-19 00:20:03 +02:00 |
FullSortingMergeJoin.h
|
QueryPlan convert OUTER JOIN to INNER JOIN optimization
|
2024-04-28 12:52:04 +03:00 |
FunctionMaskingArgumentCheckVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
FunctionNameNormalizer.cpp
|
Function name normalization fix functions header
|
2022-10-04 17:29:33 +02:00 |
FunctionNameNormalizer.h
|
Add comments to FunctionNameNormalizer.
|
2022-09-19 22:07:04 +08:00 |
GatherFunctionQuantileVisitor.cpp
|
fix bug of quantileGK
|
2024-01-31 12:14:04 +08:00 |
GatherFunctionQuantileVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
GetAggregatesVisitor.cpp
|
Fix ORDER BY tuple of WINDOW functions
|
2023-07-16 02:52:06 +02:00 |
GetAggregatesVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
getClusterName.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
getClusterName.h
|
Implement referential dependencies for table engine "Distributed"
|
2022-12-13 11:09:42 +01:00 |
getColumnFromBlock.cpp
|
Fix tests
|
2024-07-06 15:03:13 +00:00 |
getColumnFromBlock.h
|
Fix reading dynamic subcolumns from altered Memory table
|
2024-07-03 19:21:12 +00:00 |
getCustomKeyFilterForParallelReplicas.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
getCustomKeyFilterForParallelReplicas.h
|
fix style
|
2024-06-06 05:26:57 -07:00 |
getHeaderForProcessingStage.cpp
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
getHeaderForProcessingStage.h
|
Analyzer support storage Merge
|
2023-02-16 12:17:03 +01:00 |
getTableExpressions.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
getTableExpressions.h
|
Addressed review comments
|
2023-03-21 18:29:26 +01:00 |
getTableOverride.cpp
|
|
|
getTableOverride.h
|
|
|
GinFilter.cpp
|
Useless changes
|
2024-05-10 04:53:29 +02:00 |
GinFilter.h
|
Be more graceful to existing inverted indexes
|
2024-05-31 15:50:16 +00:00 |
GlobalSubqueriesVisitor.h
|
Merge branch 'master' into use-uniq-ptr-for-actions-dag
|
2024-07-15 13:25:53 +02:00 |
GraceHashJoin.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
GraceHashJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
GroupByFunctionKeysVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
GroupingSetsRewriterVisitor.cpp
|
|
|
GroupingSetsRewriterVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
HashTablesStatistics.cpp
|
move max_entries_for_hash_table_stats to server settings
|
2024-06-03 22:54:10 +01:00 |
HashTablesStatistics.h
|
remove todo
|
2024-07-03 19:41:05 +01:00 |
IdentifierSemantic.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
IdentifierSemantic.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
IExternalLoadable.cpp
|
Useless changes
|
2024-05-10 04:53:29 +02:00 |
IExternalLoadable.h
|
Merge pull request #61356 from vitlibar/fix-replace-dictionary
|
2024-03-21 16:45:06 +01:00 |
IExternalLoaderConfigRepository.h
|
Get rid of checking the "last modification time" when the configuration is generated
|
2024-03-17 12:10:57 +01:00 |
IInterpreter.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
IInterpreter.h
|
More interesting settings for Stress Tests (#41534)
|
2023-02-21 15:36:23 +03:00 |
IInterpreterUnionOrSelectQuery.cpp
|
Merge branch 'master' into use-uniq-ptr-for-actions-dag
|
2024-07-25 15:22:45 +02:00 |
IInterpreterUnionOrSelectQuery.h
|
Less indirect dependencies on Settings.h
|
2024-07-11 17:33:14 +02:00 |
IJoin.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
IKeyValueEntity.h
|
Revert "Revert "Introduce bulk loading to StorageEmbeddedRocksDB""
|
2024-05-03 18:29:36 +08:00 |
InDepthNodeVisitor.h
|
Modifiy visitor
|
2022-11-23 13:32:36 +00:00 |
InJoinSubqueriesPreprocessor.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InJoinSubqueriesPreprocessor.h
|
|
|
inplaceBlockConversions.cpp
|
add some comments
|
2024-08-05 11:19:27 +00:00 |
inplaceBlockConversions.h
|
Change ActionsDAGPtr to ActionsDAG where possible.
|
2024-07-05 17:49:50 +00:00 |
InternalTextLogsQueue.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InternalTextLogsQueue.h
|
Some fixups
|
2024-01-07 22:28:08 +00:00 |
InterpreterAlterNamedCollectionQuery.cpp
|
Ignore ON CLUSTER clause in queries for management of replicated named collections
|
2024-07-09 17:36:09 +00:00 |
InterpreterAlterNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterAlterQuery.cpp
|
fix compile error
|
2024-07-19 10:29:13 +08:00 |
InterpreterAlterQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterBackupQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterBackupQuery.h
|
|
|
InterpreterCheckQuery.cpp
|
Merge branch 'master' into revert-66134-revert-61601-chesema-dedup-matview
|
2024-07-15 14:35:44 +02:00 |
InterpreterCheckQuery.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
InterpreterCreateFunctionQuery.cpp
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
InterpreterCreateFunctionQuery.h
|
Split UserDefinedSQLObjectsLoader to interface and implementation.
|
2022-10-13 10:32:32 +02:00 |
InterpreterCreateIndexQuery.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InterpreterCreateIndexQuery.h
|
|
|
InterpreterCreateNamedCollectionQuery.cpp
|
Ignore ON CLUSTER clause in queries for management of replicated named collections
|
2024-07-09 17:36:09 +00:00 |
InterpreterCreateNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterCreateQuery.cpp
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into ts-engine
|
2024-08-07 21:01:13 +00:00 |
InterpreterCreateQuery.h
|
Merge remote-tracking branch 'blessed/master' into mergetree_private
|
2024-07-11 19:58:54 +02:00 |
InterpreterDeleteQuery.cpp
|
fix compile error
|
2024-07-19 10:29:13 +08:00 |
InterpreterDeleteQuery.h
|
|
|
InterpreterDescribeCacheQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterDescribeCacheQuery.h
|
|
|
InterpreterDescribeQuery.cpp
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
InterpreterDescribeQuery.h
|
fix test
|
2024-02-29 21:09:12 +00:00 |
InterpreterDropFunctionQuery.cpp
|
Don't access static members through instance
|
2024-04-03 18:50:33 +00:00 |
InterpreterDropFunctionQuery.h
|
|
|
InterpreterDropIndexQuery.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InterpreterDropIndexQuery.h
|
|
|
InterpreterDropNamedCollectionQuery.cpp
|
Ignore ON CLUSTER clause in queries for management of replicated named collections
|
2024-07-09 17:36:09 +00:00 |
InterpreterDropNamedCollectionQuery.h
|
Add commands CREATE/ALTER/DROP NAMED COLLECTION
|
2022-11-15 15:51:56 +01:00 |
InterpreterDropQuery.cpp
|
Fixed style
|
2024-07-30 00:39:29 +02:00 |
InterpreterDropQuery.h
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into better-stress-upgrade-checks
|
2024-04-03 12:07:22 +00:00 |
InterpreterExistsQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterExistsQuery.h
|
|
|
InterpreterExplainQuery.cpp
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
InterpreterExplainQuery.h
|
|
|
InterpreterExternalDDLQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterExternalDDLQuery.h
|
|
|
InterpreterFactory.cpp
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
InterpreterFactory.h
|
Update to clang-19
|
2024-02-27 14:37:21 +01:00 |
InterpreterInsertQuery.cpp
|
Fixed build and made setting an alias
|
2024-08-05 15:29:14 +00:00 |
InterpreterInsertQuery.h
|
Revert "Revert "insertion deduplication on retries for materialised views""
|
2024-07-05 16:52:51 +02:00 |
InterpreterKillQueryQuery.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InterpreterKillQueryQuery.h
|
|
|
InterpreterOptimizeQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterOptimizeQuery.h
|
|
|
InterpreterRenameQuery.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InterpreterRenameQuery.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
InterpreterSelectIntersectExceptQuery.cpp
|
Less indirect dependencies on Settings.h
|
2024-07-11 17:33:14 +02:00 |
InterpreterSelectIntersectExceptQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSelectQuery.cpp
|
Merge pull request #66528 from Algunenano/getSettingsCopy
|
2024-07-31 09:55:21 +00:00 |
InterpreterSelectQuery.h
|
Merge branch 'master' into use-uniq-ptr-for-actions-dag
|
2024-07-25 15:22:45 +02:00 |
InterpreterSelectQueryAnalyzer.cpp
|
Update src/Interpreters/InterpreterSelectQueryAnalyzer.cpp
|
2024-05-13 14:48:33 +02:00 |
InterpreterSelectQueryAnalyzer.h
|
Analyzer view read only necessary columns
|
2024-05-13 13:41:47 +03:00 |
InterpreterSelectWithUnionQuery.cpp
|
Less indirect dependencies on Settings.h
|
2024-07-11 17:33:14 +02:00 |
InterpreterSelectWithUnionQuery.h
|
Fix trash around query kind, part 2
|
2023-02-01 03:31:31 +01:00 |
InterpreterSetQuery.cpp
|
Fix inconsistent formatting of SET param_...
|
2024-02-26 02:11:51 +01:00 |
InterpreterSetQuery.h
|
Ignore setting constraints for projection ASTs
|
2023-07-12 10:34:36 +08:00 |
InterpreterShowColumnsQuery.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InterpreterShowColumnsQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterShowCreateQuery.cpp
|
Merge branch 'master' into ast-data-type
|
2024-07-23 02:26:35 +02:00 |
InterpreterShowCreateQuery.h
|
|
|
InterpreterShowEngineQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowEngineQuery.h
|
Update InterpreterShowEngineQuery.h
|
2023-02-01 04:57:58 +03:00 |
InterpreterShowFunctionsQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterShowFunctionsQuery.h
|
Add SHOW FUNCTIONS support to client
|
2023-09-07 14:08:50 -07:00 |
InterpreterShowIndexesQuery.cpp
|
Better (perhaps, if the stars align)
|
2024-07-17 10:30:56 +00:00 |
InterpreterShowIndexesQuery.h
|
Initial version of SHOW INDEXES
|
2023-04-25 20:48:11 +00:00 |
InterpreterShowProcesslistQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowProcesslistQuery.h
|
|
|
InterpreterShowSettingQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterShowSettingQuery.h
|
Add SHOW SETTING query
|
2023-10-25 18:49:00 +03:00 |
InterpreterShowTablesQuery.cpp
|
Fix SHOW MERGES
|
2024-07-18 22:56:15 +02:00 |
InterpreterShowTablesQuery.h
|
Implement SHOW COLUMNS
|
2023-03-28 18:04:22 +00:00 |
InterpreterSystemQuery.cpp
|
Reduce dependencies on ServerSettings.h
|
2024-07-10 18:10:19 +02:00 |
InterpreterSystemQuery.h
|
Add SYSTEM UNLOAD PRIMARY KEY
|
2024-04-17 21:24:59 +02:00 |
InterpreterTransactionControlQuery.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
InterpreterTransactionControlQuery.h
|
|
|
InterpreterUndropQuery.cpp
|
init
|
2024-07-04 15:44:06 +02:00 |
InterpreterUndropQuery.h
|
support undrop table
|
2023-03-27 22:16:36 +08:00 |
InterpreterUseQuery.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
InterpreterUseQuery.h
|
|
|
InterpreterWatchQuery.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
InterpreterWatchQuery.h
|
|
|
interpretSubquery.cpp
|
Rename Context::getSettings()
|
2024-07-15 14:28:12 +02:00 |
interpretSubquery.h
|
Revert "Trying to fix a test."
|
2023-06-15 16:42:38 +00:00 |
InterserverCredentials.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
InterserverCredentials.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
InterserverIOHandler.h
|
Merge pull request #45007 from ClickHouse/cancellable-mutex-integration
|
2023-01-25 11:15:46 +01:00 |
ITokenExtractor.cpp
|
fix: function filters with token-based text indexes
|
2024-06-04 09:25:00 +03:00 |
ITokenExtractor.h
|
fix: function filters with token-based text indexes
|
2024-06-04 09:25:00 +03:00 |
joinDispatch.h
|
fixed
|
2024-08-09 09:51:11 +08:00 |
JoinedTables.cpp
|
Rename Context::getSettings()
|
2024-07-15 14:28:12 +02:00 |
JoinedTables.h
|
Addressed review comments
|
2023-03-21 18:29:26 +01:00 |
JoinSwitcher.cpp
|
refactor hash join to reduce target size
|
2024-06-20 09:10:23 +08:00 |
JoinSwitcher.h
|
Remove redundant descriptionForPlan
|
2023-11-28 11:01:38 +00:00 |
JoinToSubqueryTransformVisitor.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
JoinToSubqueryTransformVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
JoinUtils.cpp
|
Replace updateWeakHash to getWeakHash
|
2024-07-17 13:23:44 +00:00 |
JoinUtils.h
|
Fix clang-tidy "-readability-redundant-inline-specifier"
|
2024-05-19 10:23:58 +00:00 |
Lemmatizers.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
Lemmatizers.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
loadMetadata.cpp
|
Merge pull request #65400 from k-morozov/add_system_detach_tables
|
2024-07-17 14:05:31 +00:00 |
loadMetadata.h
|
fix
|
2023-05-12 20:27:41 +00:00 |
LogicalExpressionsOptimizer.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
LogicalExpressionsOptimizer.h
|
LogicalExpressionsOptimizer: optimze for LowCardinality
|
2022-11-02 16:56:58 +08:00 |
MarkTableIdentifiersVisitor.cpp
|
|
|
MarkTableIdentifiersVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
MergeJoin.cpp
|
Merge pull request #63755 from ClickHouse/vdimir/pmj_join_non_procssed_clash
|
2024-05-15 12:46:30 +00:00 |
MergeJoin.h
|
Useless changes
|
2024-05-09 01:08:33 +02:00 |
MergeTreeTransaction.cpp
|
Block cannot allocate thread fault in noexcept functions in MergeTreeTransaction
|
2024-04-18 10:30:36 +00:00 |
MergeTreeTransaction.h
|
Fix MergeTreeTransaction::isReadOnly
|
2023-03-07 16:16:51 +00:00 |
MergeTreeTransactionHolder.cpp
|
|
|
MergeTreeTransactionHolder.h
|
|
|
MetricLog.cpp
|
Fix coding style
|
2024-06-20 16:29:37 +00:00 |
MetricLog.h
|
Consolidate code into PeriodicLog
|
2024-06-20 16:22:18 +00:00 |
misc.h
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
MutationsInterpreter.cpp
|
fix skip of parts in mutation with analyzer
|
2024-08-08 16:22:06 +00:00 |
MutationsInterpreter.h
|
fix skip of parts in mutation with analyzer
|
2024-08-08 16:22:06 +00:00 |
MutationsNonDeterministicHelpers.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
MutationsNonDeterministicHelpers.h
|
allow to execute constant non-deterministic functions in mutations on initiator
|
2023-08-07 17:16:15 +00:00 |
NormalizeSelectWithUnionQueryVisitor.cpp
|
Fix incomplete query result for UNION in view() function.
|
2023-11-02 18:33:57 +00:00 |
NormalizeSelectWithUnionQueryVisitor.h
|
Fix reloading SQL UDFs with UNION
|
2024-08-02 11:13:41 +02:00 |
NullableUtils.cpp
|
Avoid crashing on column type mismatch in a few dozen places
|
2024-05-06 22:09:02 +00:00 |
NullableUtils.h
|
|
|
ObjectStorageQueueLog.cpp
|
Fix
|
2024-06-28 17:51:08 +02:00 |
ObjectStorageQueueLog.h
|
One more
|
2024-06-28 17:56:51 +02:00 |
OpenTelemetrySpanLog.cpp
|
Useless changes
|
2024-05-09 02:07:04 +02:00 |
OpenTelemetrySpanLog.h
|
Fixing more headers
|
2024-02-29 15:40:30 +00:00 |
OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
|
Update OptimizeDateOrDateTimeConverterWithPreimageVisitor.cpp
|
2023-08-15 09:46:40 +03:00 |
OptimizeDateOrDateTimeConverterWithPreimageVisitor.h
|
Revert "Revert "Merge pull request #50951 from ZhiguoZh/20230607-toyear-fix""
|
2023-07-04 17:38:53 +02:00 |
OptimizeIfChains.cpp
|
add checks
|
2023-03-09 12:37:57 +01:00 |
OptimizeIfChains.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
OptimizeIfWithConstantConditionVisitor.cpp
|
Refactor OptimizeIfWithConstantConditionVisitor using InDepthNodeVisitor
|
2024-07-07 18:29:22 +08:00 |
OptimizeIfWithConstantConditionVisitor.h
|
Refactor OptimizeIfWithConstantConditionVisitor using InDepthNodeVisitor
|
2024-07-07 18:29:22 +08:00 |
OptimizeShardingKeyRewriteInVisitor.cpp
|
Fix incorrect sharding key types for optimize_skip_unused_shards_rewrite_in
|
2024-04-15 11:53:56 +02:00 |
OptimizeShardingKeyRewriteInVisitor.h
|
Fix incorrect sharding key types for optimize_skip_unused_shards_rewrite_in
|
2024-04-15 11:53:56 +02:00 |
parseColumnsListForTableFunction.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
parseColumnsListForTableFunction.h
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
PartLog.cpp
|
fix typo for part log
|
2024-04-23 11:37:55 +08:00 |
PartLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
PasteJoin.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
PeriodicLog.cpp
|
Fix coding style
|
2024-06-20 16:29:37 +00:00 |
PeriodicLog.h
|
Fix coding style
|
2024-06-20 16:29:37 +00:00 |
PredicateExpressionsOptimizer.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
PredicateExpressionsOptimizer.h
|
|
|
PredicateRewriteVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
PredicateRewriteVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
PreparedSets.cpp
|
Less indirect dependencies on Settings.h
|
2024-07-11 17:33:14 +02:00 |
PreparedSets.h
|
Fix 'Not-ready Set is passed' in system tables
|
2024-07-03 02:56:33 +00:00 |
processColumnTransformers.cpp
|
better interfaces for virtual columns
|
2024-03-01 22:29:56 +00:00 |
processColumnTransformers.h
|
|
|
ProcessList.cpp
|
Fix race condition in system.processes and Settings
|
2024-08-02 00:48:25 +02:00 |
ProcessList.h
|
Useless changes
|
2024-05-09 02:07:04 +02:00 |
ProcessorsProfileLog.cpp
|
Remove nested dependency on DateLutImpl
|
2024-04-02 14:45:48 +02:00 |
ProcessorsProfileLog.h
|
Fix type of input_wait_elapsed_us/input_wait_elapsed_us/elapsed_us (was UInt32)
|
2024-07-08 19:08:14 +02:00 |
ProfileEventsExt.cpp
|
Use FQDN as host name by default for TCP
|
2024-01-30 20:27:30 +00:00 |
ProfileEventsExt.h
|
Use FQDN as host name by default for TCP
|
2024-01-30 20:27:30 +00:00 |
QueryAliasesVisitor.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
QueryAliasesVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
QueryLog.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
QueryLog.h
|
Merge remote-tracking branch 'blessed/master' into mergetree_private
|
2024-07-11 19:58:54 +02:00 |
QueryNormalizer.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
QueryNormalizer.h
|
Updated to support query parameters in different parts of query (SELECT, ORDERBY, GROUP BY), updated the approach in WHERE & HAVING, added tests for the same - 40907 Parameterized views as table functions
|
2022-11-28 19:05:01 +01:00 |
QueryPriorities.h
|
|
|
QueryThreadLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
QueryThreadLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
QueryViewsLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
QueryViewsLog.h
|
Merge remote-tracking branch 'blessed/master' into mergetree_private
|
2024-07-11 19:58:54 +02:00 |
RedundantFunctionsInOrderByVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
registerInterpreters.cpp
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
registerInterpreters.h
|
independent registration of interpreters (#58443)
|
2024-01-08 22:33:48 -08:00 |
RemoveInjectiveFunctionsVisitor.cpp
|
|
|
RemoveInjectiveFunctionsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
removeOnClusterClauseIfNeeded.cpp
|
Merge remote-tracking branch 'blessed/master' into mergetree_private
|
2024-07-11 19:58:54 +02:00 |
removeOnClusterClauseIfNeeded.h
|
Add settings and processing code
|
2023-08-03 12:44:44 +03:00 |
RenameColumnVisitor.cpp
|
|
|
RenameColumnVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
replaceAliasColumnsInQuery.cpp
|
|
|
replaceAliasColumnsInQuery.h
|
|
|
replaceForPositionalArguments.cpp
|
Fix UBSan error in negative positional arguments
|
2024-05-20 09:45:23 +02:00 |
replaceForPositionalArguments.h
|
|
|
replaceMissedSubcolumnsInQuery.cpp
|
Replace missed Object(Nullable(json)) subcolumns
|
2023-09-19 09:55:45 +08:00 |
replaceMissedSubcolumnsInQuery.h
|
Replace missed Object(Nullable(json)) subcolumns
|
2023-09-19 09:55:45 +08:00 |
ReplaceQueryParameterVisitor.cpp
|
fix
|
2023-08-16 22:35:45 +02:00 |
ReplaceQueryParameterVisitor.h
|
fix
|
2023-08-16 22:35:45 +02:00 |
RequiredSourceColumnsData.cpp
|
|
|
RequiredSourceColumnsData.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
RequiredSourceColumnsVisitor.cpp
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
RequiredSourceColumnsVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteArrayExistsFunctionVisitor.cpp
|
Fix build
|
2023-09-08 05:22:21 +02:00 |
RewriteArrayExistsFunctionVisitor.h
|
Better
|
2023-09-07 02:35:21 +00:00 |
RewriteCountDistinctVisitor.cpp
|
Useless changes
|
2024-05-10 04:53:29 +02:00 |
RewriteCountDistinctVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteCountVariantsVisitor.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
RewriteCountVariantsVisitor.h
|
fix some bad logics in ast level optimization
|
2022-12-02 17:56:23 +08:00 |
RewriteOrderByVisitor.cpp
|
Fix crash
|
2024-04-03 12:18:54 +00:00 |
RewriteOrderByVisitor.hpp
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
RewriteSumFunctionWithSumAndCountVisitor.cpp
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
RewriteSumFunctionWithSumAndCountVisitor.h
|
Rewrite the AST of sum(column + literal) function
|
2023-12-15 01:28:47 +08:00 |
RewriteUniqToCountVisitor.cpp
|
Fix optimize_uniq_to_count removing the column alias
|
2024-02-15 14:10:55 +01:00 |
RewriteUniqToCountVisitor.h
|
Add optimization uniq to count
|
2023-09-13 16:16:11 +08:00 |
RowRefs.cpp
|
Fixed code review issues
|
2024-02-13 15:41:17 +03:00 |
RowRefs.h
|
fixed bugs
|
2024-04-28 09:26:11 +08:00 |
SelectIntersectExceptQueryVisitor.cpp
|
forbid old ctor of Exception
|
2023-01-23 22:18:05 +01:00 |
SelectIntersectExceptQueryVisitor.h
|
Move InDepthNodeVisitor.h back to src/Interpreters.
|
2022-11-17 18:16:32 +01:00 |
SelectQueryOptions.h
|
Fixed tests
|
2024-04-28 12:52:17 +03:00 |
ServerAsynchronousMetrics.cpp
|
Remove unnecessary try catch
|
2024-06-18 20:04:36 +02:00 |
ServerAsynchronousMetrics.h
|
Apply review comments
|
2024-04-12 03:47:29 +02:00 |
Session.cpp
|
Merge remote-tracking branch 'blessed/master' into mergetree_private
|
2024-07-11 19:58:54 +02:00 |
Session.h
|
Fix bad code, but not error in system.session_log
|
2024-06-17 07:51:58 +02:00 |
SessionLog.cpp
|
Support prometheus remote write protocol.
|
2024-08-03 16:20:23 +02:00 |
SessionLog.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +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
|
Improve PartitionPruner and trivial count opt
|
2024-06-03 21:25:21 +08:00 |
Set.h
|
Merge branch 'master' into non-ready-set-ttl
|
2024-02-07 11:29:04 +00:00 |
SetKeys.h
|
Cleanup.
|
2023-06-22 14:23:04 +00:00 |
SetVariants.cpp
|
Reapply "Remove some unnecessary UNREACHABLE s"
|
2024-05-29 13:37:47 +00:00 |
SetVariants.h
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into clang-18-ci
|
2024-05-10 07:17:39 +02:00 |
sortBlock.cpp
|
Refactor EqualRange
|
2024-05-22 15:38:50 +00: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
|
|
|
Squashing.cpp
|
some corner case optimize
|
2024-08-02 15:11:31 +02:00 |
Squashing.h
|
add test when chunk with 0 columns has to be produced in squashing
|
2024-07-06 15:34:30 +02:00 |
StorageID.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
StorageID.h
|
Revert "Use Atomic database by default in clickhouse-local "
|
2024-08-08 10:07:14 +02:00 |
SubstituteColumnOptimizer.cpp
|
Update SubstituteColumnOptimizer.cpp
|
2024-07-27 03:47:29 +02:00 |
SubstituteColumnOptimizer.h
|
Fix English
|
2024-07-27 02:58:00 +02:00 |
SynonymsExtensions.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
SynonymsExtensions.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
SystemLog.cpp
|
Merge branch 'master' into revert-66134-revert-61601-chesema-dedup-matview
|
2024-07-08 18:56:36 +02:00 |
SystemLog.h
|
Merge branch 'master' into pufit/startup-scripts
|
2024-07-05 13:52:58 -04:00 |
TableJoin.cpp
|
Change ActionsDAGPtr to ActionsDAG where possible.
|
2024-07-05 17:49:50 +00:00 |
TableJoin.h
|
Merge branch 'master' into use-uniq-ptr-for-actions-dag
|
2024-07-15 13:25:53 +02:00 |
TableNameHints.h
|
Reduce header dependencies
|
2024-03-19 17:04:29 +01:00 |
TableOverrideUtils.cpp
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
TableOverrideUtils.h
|
|
|
TablesStatus.cpp
|
Do not try to INSERT into readonly replicas for Distributed engine
|
2024-03-26 11:21:38 +01:00 |
TablesStatus.h
|
Do not try to INSERT into readonly replicas for Distributed engine
|
2024-03-26 11:21:38 +01:00 |
TemporaryDataOnDisk.cpp
|
Fix conflicts
|
2024-06-19 13:34:15 +02:00 |
TemporaryDataOnDisk.h
|
Fix conflicts
|
2024-06-19 13:34:15 +02:00 |
TextLog.cpp
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +01:00 |
TextLog.h
|
Add columns for values used in the formatting message into system.text_log
|
2024-04-23 17:26:56 +01:00 |
ThreadStatusExt.cpp
|
Hide Settings object from Context.h
|
2024-07-11 14:00:05 +02:00 |
TraceCollector.cpp
|
Fix global trace collector
|
2024-06-06 11:18:31 +02:00 |
TraceCollector.h
|
Update src/Interpreters/TraceCollector.h
|
2024-06-06 11:22:48 +02:00 |
TraceLog.cpp
|
Add a build_id ALIAS column to trace_log to facilitate auto renaming upon detecting binary changes.
|
2024-05-10 23:27:42 -07:00 |
TraceLog.h
|
Add a build_id ALIAS column to trace_log to facilitate auto renaming upon detecting binary changes.
|
2024-05-10 23:27:42 -07:00 |
TransactionLog.cpp
|
Update TransactionLog.cpp
|
2024-04-15 17:32:28 +02:00 |
TransactionLog.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionsInfoLog.cpp
|
More comments for column for system tables (#59016)
|
2024-03-08 18:05:56 +01:00 |
TransactionsInfoLog.h
|
Remove unused method
|
2024-02-25 22:40:03 +01:00 |
TransactionVersionMetadata.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TransactionVersionMetadata.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
TranslateQualifiedNamesVisitor.cpp
|
Move StringUtils.h/cpp back to Common/
|
2024-05-19 09:39:36 +00:00 |
TranslateQualifiedNamesVisitor.h
|
Enable clang-tidy in headers
|
2024-03-18 08:00:09 +00:00 |
TreeCNFConverter.cpp
|
Fix most tests
|
2024-02-26 02:31:58 +08:00 |
TreeCNFConverter.h
|
Update src/Interpreters/TreeCNFConverter.h
|
2024-05-23 19:04:09 +03:00 |
TreeOptimizer.cpp
|
Refactor OptimizeIfWithConstantConditionVisitor using InDepthNodeVisitor
|
2024-07-07 18:29:22 +08:00 |
TreeOptimizer.h
|
fix crash with multiif and constant condition and nullable arguments
|
2023-05-22 23:31:50 +00:00 |
TreeRewriter.cpp
|
Clean up projection inside storage snapshot
|
2024-07-29 22:35:47 +08:00 |
TreeRewriter.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
WhereConstraintsOptimizer.cpp
|
CNF with mutually exclusive atoms reduction fix
|
2024-05-23 19:03:56 +03:00 |
WhereConstraintsOptimizer.h
|
|
|
WindowDescription.cpp
|
Introduce IAggregateFunction_fwd to reduce header dependencies
|
2024-04-04 12:29:54 +02:00 |
WindowDescription.h
|
Better.
|
2024-07-18 17:06:03 +00:00 |
ZooKeeperLog.cpp
|
Fix error
|
2024-03-25 03:41:52 +01:00 |
ZooKeeperLog.h
|
Merge with master
|
2024-03-25 03:38:47 +01:00 |