ClickHouse/src/Storages
2023-11-23 10:29:48 +00:00
..
Cache used assert_cast instead of dynamic_cast 2023-09-05 22:57:40 +00:00
DataLakes Support Iceberg metadata files for metastore tables 2023-11-15 17:45:07 +00:00
Distributed Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
examples
FileLog Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
fuzzers
HDFS Update after review 2023-11-15 16:37:24 +01:00
Hive Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
Kafka Fix build 2023-11-13 10:09:23 +01:00
LiveView Better shutdown 2023-11-06 15:47:57 +01:00
MergeTree Merge pull request #56668 from ClickHouse/vdimir/analyzer_s3_partition_pruning 2023-11-22 16:44:44 +01:00
MySQL
NATS Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
PostgreSQL Better shutdown 2023-11-06 15:47:57 +01:00
RabbitMQ Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
RocksDB Fix tests. 2023-11-07 11:43:16 +00:00
S3Queue Merge pull request #56990 from ClickHouse/s3queue-fix-incorrect-ref-count-from-exception-in-ctor 2023-11-21 21:37:23 +01:00
System Merge branch 'master' into dashboards-table 2023-11-23 10:29:48 +00:00
tests Fix 2023-11-09 06:23:23 +00:00
WindowView Better shutdown 2023-11-06 15:47:57 +01:00
AlterCommands.cpp Fix a bug 2023-11-18 15:44:45 +00:00
AlterCommands.h Initial implementation 2023-10-10 19:59:48 +02: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
buildQueryTreeForShard.h
checkAndGetLiteralArgument.cpp
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
ColumnsDescription.cpp Merge branch 'master' into revert-53782-revert-52762-planner-prepare-filters-for-analysis 2023-10-09 14:44:00 +02:00
ColumnsDescription.h Merge branch 'master' into revert-53782-revert-52762-planner-prepare-filters-for-analysis 2023-10-09 14:44:00 +02: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
ExternalDataSourceConfiguration.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +00:00
ExternalDataSourceConfiguration.h
extractKeyExpressionList.cpp ANTLR4 Grammar for ClickHouse and new parser (#11298) 2020-12-04 05:15:44 +03:00
extractKeyExpressionList.h
extractTableFunctionArgumentsFromSelectQuery.cpp
extractTableFunctionArgumentsFromSelectQuery.h
Freeze.cpp
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
IndicesDescription.h Refactor IHints 2023-09-10 03:48:12 +00:00
IStorage_fwd.h
IStorage.cpp wip CHECK query for all tables 2023-10-27 15:22:10 +00:00
IStorage.h Merge pull request #56367 from canhld94/ch_table_reinit_new_disk 2023-11-14 15:54:22 +01:00
IStorageCluster.cpp Better 2023-09-15 11:11:04 +00:00
IStorageCluster.h
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
MemorySettings.cpp
MemorySettings.h
MessageQueueSink.cpp
MessageQueueSink.h
MutationCommands.cpp
MutationCommands.h
NamedCollectionsHelpers.cpp Fix format 2023-11-09 17:25:20 +01:00
NamedCollectionsHelpers.h
PartitionCommands.cpp
PartitionCommands.h
PartitionedSink.cpp Remove C++ templates 2023-11-10 05:25:02 +01:00
PartitionedSink.h
prepareReadingFromFormat.cpp
prepareReadingFromFormat.h Fix tests 2023-07-05 17:56:03 +00:00
ProjectionsDescription.cpp
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 Remove Meilisearch 2023-09-30 06:02:38 +02:00
registerStorages.h
removeGroupingFunctionSpecializations.cpp
removeGroupingFunctionSpecializations.h
RenamingRestrictions.h
SelectQueryDescription.cpp
SelectQueryDescription.h
SelectQueryInfo.cpp
SelectQueryInfo.h
SetSettings.cpp
SetSettings.h Move obsolete format settings to separate section 2023-09-20 16:00:28 +00:00
StorageAzureBlob.cpp Implement system table blob_storage_log 2023-11-21 09:18:25 +00:00
StorageAzureBlob.h Merge pull request #54642 from rschu1ze/broken-re2st 2023-09-17 15:30:57 +02:00
StorageAzureBlobCluster.cpp
StorageAzureBlobCluster.h
StorageBuffer.cpp Re-fix 'Block structure mismatch' on concurrent ALTER and INSERTs in Buffer table (#56140) 2023-10-31 13:41:54 -07:00
StorageBuffer.h Re-fix 'Block structure mismatch' on concurrent ALTER and INSERTs in Buffer table (#56140) 2023-10-31 13:41:54 -07: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 Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
StorageDistributed.h Merge pull request #56367 from canhld94/ch_table_reinit_new_disk 2023-11-14 15:54:22 +01:00
StorageDummy.cpp
StorageDummy.h
StorageExecutable.cpp
StorageExecutable.h
StorageExternalDistributed.cpp
StorageExternalDistributed.h
StorageFactory.cpp
StorageFactory.h Refactor IHints 2023-09-10 03:48:12 +00:00
StorageFile.cpp small fixes after review 2023-11-16 00:01:36 +01:00
StorageFile.h Fix parsing error in WithNames formats while reading subset of columns with disabled input_format_with_names_use_header 2023-09-11 14:55:37 +00:00
StorageGenerateRandom.cpp Fix UInt256 and IPv4 random data generation on s390x 2023-09-13 04:55:02 -07:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp
StorageInMemoryMetadata.h
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
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 Small fixes and add test 2023-11-09 15:56:57 +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
StorageMaterializedView.cpp Merge pull request #56377 from ClickHouse/minor-improvements-for-s3-queue 2023-11-10 11:28:09 +01:00
StorageMaterializedView.h Better shutdown 2023-11-06 15:47:57 +01:00
StorageMemory.cpp
StorageMemory.h
StorageMerge.cpp Merge pull request #54905 from nickitat/fix_key_analysis_merge_engine 2023-11-09 14:52:54 +01:00
StorageMerge.h better 2023-09-26 11:51:34 +02:00
StorageMergeTree.cpp Merge pull request #56502 from amosbird/fix-56481 2023-11-11 02:29:04 +01:00
StorageMergeTree.h Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
StorageMongoDB.cpp
StorageMongoDB.h
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp
StorageMySQL.h update comment 2023-09-19 08:18:37 +00:00
StorageNull.cpp
StorageNull.h fix: StorageNull supports subcolumns 2023-10-22 16:24:01 +08:00
StoragePostgreSQL.cpp
StoragePostgreSQL.h
StorageProxy.h Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
StorageRedis.cpp
StorageRedis.h
StorageReplicatedMergeTree.cpp Merge pull request #56102 from ClickHouse/coverage 2023-11-16 23:23:40 +01:00
StorageReplicatedMergeTree.h Fix unexpected parts handling (#56693) 2023-11-15 16:54:47 +01:00
StorageS3.cpp Merge pull request #56668 from ClickHouse/vdimir/analyzer_s3_partition_pruning 2023-11-22 16:44:44 +01:00
StorageS3.h Merge pull request #56668 from ClickHouse/vdimir/analyzer_s3_partition_pruning 2023-11-22 16:44:44 +01:00
StorageS3Cluster.cpp Fxi 2023-09-28 16:25:04 +02:00
StorageS3Cluster.h
StorageS3Settings.cpp
StorageS3Settings.h Revert "Revert "s3 adaptive timeouts"" 2023-11-20 14:53:22 +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 Merge branch 'master' into revert-53782-revert-52762-planner-prepare-filters-for-analysis 2023-10-09 14:44:00 +02:00
StorageSnapshot.h
StorageSQLite.cpp
StorageSQLite.h
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 Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
StorageURL.h Support orc filter push down (file + stripe + rowgroup level) (#55330) 2023-10-24 12:08:17 -07:00
StorageURLCluster.cpp
StorageURLCluster.h
StorageValues.cpp
StorageValues.h
StorageView.cpp Revert "Support SAMPLE BY for VIEW" 2023-10-09 00:08:46 +03:00
StorageView.h
StorageXDBC.cpp Fix parsing error in WithNames formats while reading subset of columns with disabled input_format_with_names_use_header 2023-09-11 14:55:37 +00:00
StorageXDBC.h Fix parsing error in WithNames formats while reading subset of columns with disabled input_format_with_names_use_header 2023-09-11 14:55:37 +00:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp Update src/Storages/transformQueryForExternalDatabase.cpp 2023-11-08 23:20:12 +08:00
transformQueryForExternalDatabase.h
transformQueryForExternalDatabaseAnalyzer.cpp
transformQueryForExternalDatabaseAnalyzer.h
TTLDescription.cpp enable_qpl_deflate_codec --> enable_deflate_qpl_codec 2023-06-09 12:43:33 +00:00
TTLDescription.h
TTLMode.h
UVLoop.h
VirtualColumnUtils.cpp Analyzer: partition pruning for S3 2023-11-20 17:59:53 +00:00
VirtualColumnUtils.h Style changes around filterKeysForPartitionPruning 2023-11-20 18:08:45 +00:00