.. |
Cache
|
Add union mode for schema inference to infer union schema of files with different schemas
|
2023-10-20 20:46:41 +00:00 |
DataLakes
|
Support Iceberg metadata files for metastore tables
|
2023-11-15 17:45:07 +00:00 |
Distributed
|
Merge pull request #57218 from tntnatbry/issue-43666
|
2023-12-18 04:48:57 +01:00 |
examples
|
|
|
FileLog
|
Better text_log with ErrnoException
|
2023-12-15 19:27:56 +01:00 |
fuzzers
|
fix fuzzers, cmake refactor, add target fuzzers
|
2023-09-01 14:20:50 +00:00 |
HDFS
|
Cleanup
|
2024-01-02 18:08:04 +00:00 |
Hive
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
Kafka
|
Clean cached messages on destroy kafka consumer
|
2023-12-29 14:30:21 +01:00 |
LiveView
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
MaterializedView
|
Fix WriteBuffer assert if refresh is cancelled at the wrong moment
|
2023-12-28 18:34:28 +00:00 |
MergeTree
|
Make alter with variant espansion as no-op, add tests for alters
|
2024-01-18 17:29:36 +00:00 |
MySQL
|
Intorduce *List definition for muli enum settings
|
2023-11-28 19:09:02 +00:00 |
NATS
|
Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue
|
2023-11-06 15:51:11 +01:00 |
PostgreSQL
|
Fxi
|
2023-12-14 16:05:40 +01:00 |
RabbitMQ
|
Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue
|
2023-11-06 15:51:11 +01:00 |
RocksDB
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01:00 |
S3Queue
|
Cleanup
|
2024-01-02 17:50:06 +00:00 |
Statistics
|
rename some code
|
2023-11-28 16:32:47 +01:00 |
System
|
Merge pull request #58029 from skyoct/feat/server_settings
|
2024-01-08 10:09:51 +01:00 |
tests
|
add test
|
2023-12-15 15:29:15 +00:00 |
WindowView
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01:00 |
AlterCommands.cpp
|
Things
|
2023-12-28 17:56:05 +00:00 |
AlterCommands.h
|
Things
|
2023-12-28 17:56:05 +00:00 |
BlockNumberColumn.cpp
|
Added a new column _block_number (#47532)
|
2023-09-20 11:31:12 +02:00 |
BlockNumberColumn.h
|
Added a new column _block_number (#47532)
|
2023-09-20 11:31:12 +02:00 |
buildQueryTreeForShard.cpp
|
Another try.
|
2023-12-16 15:41:02 +00:00 |
buildQueryTreeForShard.h
|
Use query tree to rewrite the query
|
2023-06-12 16:51:40 +00:00 |
checkAndGetLiteralArgument.cpp
|
add more check + line break
|
2023-07-05 15:04:38 +00:00 |
checkAndGetLiteralArgument.h
|
|
|
CheckResults.h
|
Improve CHECK TABLE system query
|
2023-10-23 09:35:26 +00:00 |
CMakeLists.txt
|
|
|
ColumnDefault.cpp
|
|
|
ColumnDefault.h
|
|
|
ColumnDependency.h
|
use statistic to order prewhere conditions better
|
2023-08-09 22:57:49 +02:00 |
ColumnsDescription.cpp
|
Flatten only true Nested type if flatten_nested=1, not all Array(Tuple)
|
2023-12-12 14:13:15 +00:00 |
ColumnsDescription.h
|
Merge pull request #57461 from ClickHouse/fix-ephemeral-matview
|
2023-12-06 16:46:54 -05:00 |
CompressionCodecSelector.h
|
|
|
ConstraintsDescription.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
ConstraintsDescription.h
|
|
|
DataDestinationType.h
|
|
|
ExecutableSettings.cpp
|
|
|
ExecutableSettings.h
|
StorageExecutable check_exit_code default to false
|
2023-08-18 15:38:47 +08:00 |
ExternalDataSourceConfiguration.cpp
|
Remove broken lockless variant of re2
|
2023-09-14 16:40:42 +00:00 |
ExternalDataSourceConfiguration.h
|
Support clang-18 (Wmissing-field-initializers)
|
2023-08-23 15:53:45 +02:00 |
extractKeyExpressionList.cpp
|
|
|
extractKeyExpressionList.h
|
|
|
extractTableFunctionArgumentsFromSelectQuery.cpp
|
|
|
extractTableFunctionArgumentsFromSelectQuery.h
|
|
|
Freeze.cpp
|
Support clang-18 (Wmissing-field-initializers)
|
2023-08-23 15:53:45 +02:00 |
Freeze.h
|
|
|
getStructureOfRemoteTable.cpp
|
Handle clusterAllReplicas/remote cases to avoid unnecessary logging
|
2023-09-12 12:52:29 +00:00 |
getStructureOfRemoteTable.h
|
|
|
IMessageProducer.cpp
|
|
|
IMessageProducer.h
|
|
|
IndicesDescription.cpp
|
Revert "Revert "Support use alias column in indices""
|
2023-12-05 18:22:32 +00:00 |
IndicesDescription.h
|
Refactor IHints
|
2023-09-10 03:48:12 +00:00 |
IStorage_fwd.h
|
|
|
IStorage.cpp
|
Show owner query ids in the message for the DEADLOCK_AVOIDED error.
|
2023-12-11 00:56:17 +01:00 |
IStorage.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
IStorageCluster.cpp
|
Cleanup
|
2024-01-02 17:50:06 +00:00 |
IStorageCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
KeyDescription.cpp
|
|
|
KeyDescription.h
|
|
|
KVStorageUtils.cpp
|
Remove default value for argument 'ignore_aliases' from IAST::getTreeHash()
|
2023-11-13 10:27:38 +00:00 |
KVStorageUtils.h
|
Fix rocksdb with analyzer.
|
2023-11-06 18:46:39 +00:00 |
LightweightDeleteDescription.cpp
|
|
|
LightweightDeleteDescription.h
|
|
|
MarkCache.h
|
Better parameter name
|
2023-08-22 15:43:13 +00:00 |
MemorySettings.cpp
|
|
|
MemorySettings.h
|
|
|
MessageQueueSink.cpp
|
|
|
MessageQueueSink.h
|
release buffers with exception context
|
2023-06-22 13:00:13 +02:00 |
MutationCommands.cpp
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
MutationCommands.h
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
NamedCollectionsHelpers.cpp
|
Update src/Storages/NamedCollectionsHelpers.cpp
|
2023-11-21 11:14:48 +01:00 |
NamedCollectionsHelpers.h
|
Merge remote-tracking branch 'upstream/master' into add-separate-access-for-use-named-collections
|
2023-06-14 13:33:56 +02:00 |
PartitionCommands.cpp
|
|
|
PartitionCommands.h
|
Support clang-18 (Wmissing-field-initializers)
|
2023-08-23 15:53:45 +02:00 |
PartitionedSink.cpp
|
Minor changes
|
2023-11-22 12:13:47 +01:00 |
PartitionedSink.h
|
release buffers with exception context
|
2023-06-22 13:00:13 +02:00 |
prepareReadingFromFormat.cpp
|
Fix tests
|
2023-07-06 17:47:01 +00:00 |
prepareReadingFromFormat.h
|
Fix tests
|
2023-07-05 17:56:03 +00:00 |
ProjectionsDescription.cpp
|
Disable transform_null_in as well just in case.
|
2023-11-29 17:30:22 +00:00 |
ProjectionsDescription.h
|
Refactor IHints
|
2023-09-10 03:48:12 +00:00 |
ReadFinalForExternalReplicaStorage.cpp
|
|
|
ReadFinalForExternalReplicaStorage.h
|
|
|
ReadInOrderOptimizer.cpp
|
|
|
ReadInOrderOptimizer.h
|
|
|
RedisCommon.cpp
|
|
|
RedisCommon.h
|
|
|
registerStorages.cpp
|
Follow-up to #56490: Fix build with -DENABLE_LIBRARIES=0
|
2023-11-28 19:59:43 +00:00 |
registerStorages.h
|
Make code slightly better
|
2020-11-11 09:08:53 +08:00 |
removeGroupingFunctionSpecializations.cpp
|
Resolve as FunctionGrouping
|
2023-03-14 03:33:31 +00:00 |
removeGroupingFunctionSpecializations.h
|
|
|
RenamingRestrictions.h
|
|
|
ReplaceAliasByExpressionVisitor.cpp
|
Revert "Revert "Support use alias column in indices""
|
2023-12-05 18:22:32 +00:00 |
ReplaceAliasByExpressionVisitor.h
|
Revert "Revert "Support use alias column in indices""
|
2023-12-05 18:22:32 +00:00 |
SelectQueryDescription.cpp
|
Things
|
2023-12-28 17:56:05 +00:00 |
SelectQueryDescription.h
|
Things
|
2023-12-28 17:56:05 +00:00 |
SelectQueryInfo.cpp
|
|
|
SelectQueryInfo.h
|
Merge remote-tracking branch 'blessed/master' into parallel_replicas_row_estimation
|
2023-08-29 11:17:34 +02:00 |
SetSettings.cpp
|
|
|
SetSettings.h
|
Move obsolete format settings to separate section
|
2023-09-20 16:00:28 +00:00 |
StatisticsDescription.cpp
|
refine exception messages
|
2023-09-27 17:59:53 +02:00 |
StatisticsDescription.h
|
address comments
|
2023-10-30 00:39:16 +01:00 |
StorageAzureBlob.cpp
|
Cleanup
|
2024-01-02 17:50:06 +00:00 |
StorageAzureBlob.h
|
Remove unneeded code
|
2024-01-02 17:27:33 +00:00 |
StorageAzureBlobCluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageAzureBlobCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageBuffer.cpp
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01:00 |
StorageBuffer.h
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01:00 |
StorageConfiguration.h
|
|
|
StorageDictionary.cpp
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
StorageDictionary.h
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
StorageDistributed.cpp
|
Cleanup
|
2024-01-02 17:50:06 +00:00 |
StorageDistributed.h
|
Make DirectoryMonitor handle cluster node list change (#42826)
|
2023-12-08 14:41:51 +01:00 |
StorageDummy.cpp
|
Refactor a bit.
|
2023-06-16 19:38:50 +00:00 |
StorageDummy.h
|
Revert "Revert "Planner prepare filters for analysis""
|
2023-08-24 12:32:56 +02:00 |
StorageExecutable.cpp
|
Add index to table system.numbers (#50909)
|
2023-12-01 19:59:25 +01:00 |
StorageExecutable.h
|
|
|
StorageExternalDistributed.cpp
|
|
|
StorageExternalDistributed.h
|
|
|
StorageFactory.cpp
|
|
|
StorageFactory.h
|
Refactor IHints
|
2023-09-10 03:48:12 +00:00 |
StorageFile.cpp
|
Merge pull request #58447 from canhld94/fix_symlink_in_user_files
|
2024-01-08 10:40:36 +01:00 |
StorageFile.h
|
Merge branch 'master' into try-to-remove-pk-analysis-on-ast
|
2024-01-05 10:54:46 +00:00 |
StorageFileCluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageFileCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageFuzzJSON.cpp
|
Update src/Storages/StorageFuzzJSON.cpp
|
2023-12-19 10:17:15 -08:00 |
StorageFuzzJSON.h
|
Add malformed output generation to JSON fuzzer (#57646)
|
2023-12-13 19:59:31 +01:00 |
StorageGenerateRandom.cpp
|
Fix tests
|
2023-12-12 14:13:15 +00:00 |
StorageGenerateRandom.h
|
|
|
StorageInMemoryMetadata.cpp
|
Things
|
2023-12-28 17:56:05 +00:00 |
StorageInMemoryMetadata.h
|
Slightly more things
|
2023-12-28 17:56:05 +00:00 |
StorageInput.cpp
|
Fixing style.
|
2023-11-14 14:55:21 +00:00 |
StorageInput.h
|
Fixing style.
|
2023-11-15 13:56:51 +00:00 |
StorageJoin.cpp
|
fix
|
2023-12-11 15:50:27 +00:00 |
StorageJoin.h
|
StorageJoin: supports trivial count()
|
2023-10-19 06:30:25 +00:00 |
StorageKeeperMap.cpp
|
Cleanup
|
2023-11-17 10:27:19 +00:00 |
StorageKeeperMap.h
|
Remove mayBenefitFromIndexForIn
|
2023-12-27 17:42:40 +00:00 |
StorageLog.cpp
|
wip CHECK query for all tables
|
2023-10-27 15:22:10 +00:00 |
StorageLog.h
|
wip CHECK query for all tables
|
2023-10-27 15:22:10 +00:00 |
StorageLogSettings.cpp
|
|
|
StorageLogSettings.h
|
|
|
StorageMaterializedMySQL.cpp
|
|
|
StorageMaterializedMySQL.h
|
Style fix
|
2023-08-14 12:30:29 +04:00 |
StorageMaterializedView.cpp
|
Merge branch 'master' into reintroduce_is_deleted
|
2023-12-29 15:46:24 +01:00 |
StorageMaterializedView.h
|
Merge pull request #57520 from Avogar/ignore-mv-with-dropped-target-table
|
2024-01-04 15:33:27 +01:00 |
StorageMemory.cpp
|
fix alter table tests
|
2023-11-30 21:42:13 +03:00 |
StorageMemory.h
|
allow ALTER for TEMPORARY table
|
2023-11-30 21:42:12 +03:00 |
StorageMerge.cpp
|
Update StorageMerge.cpp
|
2024-01-03 14:53:40 +01:00 |
StorageMerge.h
|
Review fixes.
|
2024-01-03 10:12:08 +00:00 |
StorageMergeTree.cpp
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
StorageMergeTree.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
StorageMongoDB.cpp
|
Fix build
|
2023-07-06 06:31:09 +00:00 |
StorageMongoDB.h
|
Correctly disable async insert with deduplication when it's not needed (#50663)
|
2023-06-07 20:33:08 +02:00 |
StorageMongoDBSocketFactory.cpp
|
|
|
StorageMongoDBSocketFactory.h
|
|
|
StorageMySQL.cpp
|
Better
|
2023-08-10 06:34:10 +00:00 |
StorageMySQL.h
|
update comment
|
2023-09-19 08:18:37 +00:00 |
StorageNull.cpp
|
Minor code cleanup: remove some redundant includes of InterpreterAlterQuery.h
|
2023-08-23 14:16:36 +00:00 |
StorageNull.h
|
fix: StorageNull supports subcolumns
|
2023-10-22 16:24:01 +08:00 |
StoragePostgreSQL.cpp
|
Move Allocator code into module part
|
2023-12-27 15:42:08 +01:00 |
StoragePostgreSQL.h
|
bugfix: addresses_expr ignored for psql named collections
|
2023-12-14 17:17:14 +01:00 |
StorageProxy.h
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01:00 |
StorageRedis.cpp
|
add notifications in docs
|
2023-06-13 09:33:38 +08:00 |
StorageRedis.h
|
fix build error
|
2023-06-12 10:15:32 +08:00 |
StorageReplicatedMergeTree.cpp
|
Merge pull request #58480 from ClickHouse/try-to-remove-pk-analysis-on-ast
|
2024-01-06 12:40:46 +01:00 |
StorageReplicatedMergeTree.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
StorageS3.cpp
|
Review fixes
|
2024-01-04 14:41:04 +00:00 |
StorageS3.h
|
Merge branch 'master' into try-to-remove-pk-analysis-on-ast
|
2024-01-05 10:54:46 +00:00 |
StorageS3Cluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageS3Cluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageS3Settings.cpp
|
Move Allocator code into module part
|
2023-12-27 15:42:08 +01:00 |
StorageS3Settings.h
|
Minor cache changes
|
2023-12-04 19:02:37 +01:00 |
StorageSet.cpp
|
Fix totalBytes()
|
2023-10-15 10:40:37 +02:00 |
StorageSet.h
|
Merging #52352
|
2023-10-14 02:52:53 +02:00 |
StorageSnapshot.cpp
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
StorageSnapshot.h
|
Revert "Revert "Planner prepare filters for analysis""
|
2023-08-24 12:32:56 +02:00 |
StorageSQLite.cpp
|
Better
|
2023-08-10 06:34:10 +00:00 |
StorageSQLite.h
|
Correctly disable async insert with deduplication when it's not needed (#50663)
|
2023-06-07 20:33:08 +02:00 |
StorageStripeLog.cpp
|
Split source and worker processors in InterpreterCheckQuery
|
2023-10-27 15:22:10 +00:00 |
StorageStripeLog.h
|
wip CHECK query for all tables
|
2023-10-27 15:22:10 +00:00 |
StorageTableFunction.h
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
StorageURL.cpp
|
Fix KeyCondition for file/url/s3
|
2024-01-03 17:44:28 +00:00 |
StorageURL.h
|
Merge branch 'master' into try-to-remove-pk-analysis-on-ast
|
2024-01-05 10:54:46 +00:00 |
StorageURLCluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageURLCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageValues.cpp
|
|
|
StorageValues.h
|
Disable parallelize_output_from_storages for storages with only one block
|
2023-06-14 19:11:23 +03:00 |
StorageView.cpp
|
Revert "Support SAMPLE BY for VIEW"
|
2023-10-09 00:08:46 +03:00 |
StorageView.h
|
Create new StorageView with substituted parameters for every SELECT query of a parameterized view
|
2023-07-25 14:04:55 +02:00 |
StorageXDBC.cpp
|
Add reading step to URL
|
2024-01-02 15:18:13 +00:00 |
StorageXDBC.h
|
Add reading step to URL
|
2024-01-02 15:18:13 +00:00 |
TableLockHolder.h
|
|
|
transformQueryForExternalDatabase.cpp
|
Fix transform query for external database
|
2023-12-15 08:34:58 +00:00 |
transformQueryForExternalDatabase.h
|
Better
|
2023-08-10 06:34:10 +00:00 |
transformQueryForExternalDatabaseAnalyzer.cpp
|
Fixing 01086_odbc_roundtrip with analyzer.
|
2023-08-31 15:23:27 +00:00 |
transformQueryForExternalDatabaseAnalyzer.h
|
|
|
TTLDescription.cpp
|
Fix build
|
2023-11-23 16:06:35 +01:00 |
TTLDescription.h
|
Fix tests
|
2023-11-23 16:02:33 +01:00 |
TTLMode.h
|
|
|
UVLoop.h
|
Better formatting for exception messages (#45449)
|
2023-01-24 00:13:58 +03:00 |
VirtualColumnUtils.cpp
|
Fixing index hint
|
2024-01-05 11:50:09 +00:00 |
VirtualColumnUtils.h
|
Fixing index hint
|
2024-01-05 11:50:09 +00:00 |