ClickHouse/src/Storages
2023-09-20 15:14:40 +02:00
..
Cache used assert_cast instead of dynamic_cast 2023-09-05 22:57:40 +00:00
DataLakes
Distributed rename new method 2023-08-28 16:01:00 +02:00
examples
FileLog
fuzzers fix fuzzers, cmake refactor, add target fuzzers 2023-09-01 14:20:50 +00:00
HDFS Merge pull request #54642 from rschu1ze/broken-re2st 2023-09-17 15:30:57 +02:00
Hive 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
Kafka Merge pull request #49618 from ClickHouse/concurrency-control-controllable 2023-08-29 19:44:51 +02:00
LiveView Merge pull request #54009 from ClickHouse/change-istorage-interface 2023-08-29 22:22:53 +02:00
MeiliSearch
MergeTree Merge pull request #54544 from kitaisreal/key-condition-in-function-different-types 2023-09-20 12:54:01 +02:00
MySQL
NATS Change interface 2023-08-29 16:26:48 +02:00
PostgreSQL
RabbitMQ Change interface 2023-08-29 16:26:48 +02:00
RocksDB
S3Queue 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
System Replace information_schema view columns aliases with uppercase 2023-09-19 23:42:40 +02:00
tests
WindowView Merge pull request #54009 from ClickHouse/change-istorage-interface 2023-08-29 22:22:53 +02:00
AlterCommands.cpp Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
AlterCommands.h Fix tests with database replicated 2023-09-06 14:17:46 +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
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
ColumnsDescription.cpp Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
ColumnsDescription.h Refactor IHints 2023-09-10 03:48:12 +00:00
CompressionCodecSelector.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ConstraintsDescription.cpp
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 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 Merge pull request #51141 from ClickHouse/azure_blob_storage_sas_token 2023-08-01 12:27:17 +02: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
IStorage.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
IStorageCluster.cpp Better 2023-09-15 11:11:04 +00:00
IStorageCluster.h
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp
KVStorageUtils.h
LightweightDeleteDescription.cpp
LightweightDeleteDescription.h
MarkCache.h Better parameter name 2023-08-22 15:43:13 +00:00
MemorySettings.cpp
MemorySettings.h Better alias definition 2023-02-01 13:54:03 +00:00
MessageQueueSink.cpp
MessageQueueSink.h
MutationCommands.cpp
MutationCommands.h Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02:00
NamedCollectionsHelpers.cpp
NamedCollectionsHelpers.h
PartitionCommands.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
PartitionCommands.h Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02:00
PartitionedSink.cpp
PartitionedSink.h
prepareReadingFromFormat.cpp
prepareReadingFromFormat.h
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
registerStorages.h
removeGroupingFunctionSpecializations.cpp
removeGroupingFunctionSpecializations.h
RenamingRestrictions.h
SelectQueryDescription.cpp
SelectQueryDescription.h
SelectQueryInfo.cpp
SelectQueryInfo.h Remove unused parallel replicas coordinator in query info 2023-08-27 22:12:39 +00:00
SetSettings.cpp
SetSettings.h
StorageAzureBlob.cpp Merge pull request #54642 from rschu1ze/broken-re2st 2023-09-17 15:30:57 +02:00
StorageAzureBlob.h Merge pull request #54642 from rschu1ze/broken-re2st 2023-09-17 15:30:57 +02:00
StorageAzureBlobCluster.cpp
StorageAzureBlobCluster.h Merge branch 'master' into fast-count-from-files 2023-08-23 15:13:20 +02:00
StorageBuffer.cpp Minor code cleanup: remove some redundant includes of InterpreterAlterQuery.h 2023-08-23 14:16:36 +00:00
StorageBuffer.h
StorageConfiguration.h
StorageDictionary.cpp Better 2023-09-15 11:11:04 +00:00
StorageDictionary.h Better 2023-09-15 11:11:04 +00:00
StorageDistributed.cpp Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
StorageDistributed.h Style check 2023-09-09 12:51:34 +00:00
StorageDummy.cpp
StorageDummy.h Revert "Planner prepare filters for analysis" 2023-08-24 12:52:03 +03:00
StorageExecutable.cpp
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 #54642 from rschu1ze/broken-re2st 2023-09-17 15:30:57 +02: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
StorageInput.h
StorageJoin.cpp
StorageJoin.h
StorageKeeperMap.cpp
StorageKeeperMap.h
StorageLog.cpp Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
StorageLog.h
StorageLogSettings.cpp
StorageLogSettings.h
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h
StorageMaterializedView.cpp
StorageMaterializedView.h
StorageMemory.cpp
StorageMemory.h
StorageMerge.cpp
StorageMerge.h
StorageMergeTree.cpp Fxi 2023-09-19 13:47:32 +02:00
StorageMergeTree.h Change interface 2023-08-29 16:26:48 +02:00
StorageMongoDB.cpp
StorageMongoDB.h
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp
StorageMySQL.h
StorageNull.cpp Minor code cleanup: remove some redundant includes of InterpreterAlterQuery.h 2023-08-23 14:16:36 +00:00
StorageNull.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StoragePostgreSQL.cpp
StoragePostgreSQL.h
StorageProxy.h Change interface 2023-08-29 16:26:48 +02:00
StorageRedis.cpp
StorageRedis.h
StorageReplicatedMergeTree.cpp Merge pull request #54550 from ClickHouse/fix_zero_copy_garbage 2023-09-13 15:02:05 +02:00
StorageReplicatedMergeTree.h Make function slightly more readable 2023-09-12 21:41:05 +02:00
StorageS3.cpp Merge pull request #54651 from CheSema/limit_backoff_timeout 2023-09-18 19:41:26 +02:00
StorageS3.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
StorageS3Cluster.cpp
StorageS3Cluster.h Merge branch 'master' into fast-count-from-files 2023-08-23 15:13:20 +02:00
StorageS3Settings.cpp
StorageS3Settings.h
StorageSet.cpp
StorageSet.h
StorageSnapshot.cpp Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
StorageSnapshot.h Revert "Planner prepare filters for analysis" 2023-08-24 12:52:03 +03:00
StorageSQLite.cpp
StorageSQLite.h
StorageStripeLog.cpp
StorageStripeLog.h
StorageTableFunction.h Change interface 2023-08-29 16:26:48 +02:00
StorageURL.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
StorageURL.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
StorageURLCluster.cpp
StorageURLCluster.h Merge branch 'master' into fast-count-from-files 2023-08-23 15:13:20 +02:00
StorageValues.cpp
StorageValues.h
StorageView.cpp Support SAMPLE BY for VIEW 2023-09-10 08:24:46 +02: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 Better 2023-08-10 06:34:10 +00:00
transformQueryForExternalDatabase.h
transformQueryForExternalDatabaseAnalyzer.cpp Fixing 01086_odbc_roundtrip with analyzer. 2023-08-31 15:23:27 +00:00
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 Fixing 01748_partition_id_pruning 2023-09-01 14:29:31 +00:00
VirtualColumnUtils.h Fixing 01748_partition_id_pruning 2023-09-01 14:29:31 +00:00