ClickHouse/src/Storages
2023-07-31 09:27:01 +00:00
..
Cache Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
DataLakes "reconfig" support for CH Keeper 2023-07-07 00:20:54 +03:00
Distributed Remove non-const function Context::getClientInfo(). 2023-07-17 15:02:07 +02:00
examples Fix build 2023-05-03 00:09:52 +02:00
FileLog Highly questionable refactoring (getInputMultistream() nonsense) 2023-04-17 04:58:32 +00:00
fuzzers
HDFS Merge pull request #52627 from ClickHouse/fix_build_with_clang15 2023-07-27 09:49:29 +02:00
Hive Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
Kafka Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
LiveView Remove ALTER of LIVE VIEW 2023-06-22 20:32:29 +02:00
MeiliSearch Make IAST::FormatSettings more regular, pt. III 2023-07-20 10:34:05 +00:00
MergeTree Merge pull request #52689 from CurtizJ/fix-extra-column-prewhere 2023-07-30 15:30:53 +02:00
MySQL Fox 2023-04-13 19:36:25 +02:00
NATS Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
PostgreSQL Update src/Storages/PostgreSQL/MaterializedPostgreSQLConsumer.cpp 2023-07-20 19:03:06 +02:00
RabbitMQ Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
RocksDB Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
System Merge pull request #52315 from xiedeyantu/add-alias 2023-07-30 22:37:31 +02:00
tests Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
WindowView Remove non-const function Context::getClientInfo(). 2023-07-17 15:02:07 +02:00
AlterCommands.cpp enable_qpl_deflate_codec --> enable_deflate_qpl_codec 2023-06-09 12:43:33 +00:00
AlterCommands.h
buildQueryTreeForShard.cpp Refactor InDepthQueryTreeVisitorWithContext 2023-07-27 21:24:39 +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
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h
ColumnsDescription.cpp Add extensive testing cases for deflate qpl codec 2023-06-09 12:42:59 +00:00
ColumnsDescription.h Allow using Alias column type for KafkaEngine 2023-05-15 15:39:58 +02:00
CompressionCodecSelector.h
ConstraintsDescription.cpp Make serializeAST() more regular 2023-07-20 10:39:26 +00:00
ConstraintsDescription.h
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h
ExternalDataSourceConfiguration.cpp
ExternalDataSourceConfiguration.h
extractKeyExpressionList.cpp
extractKeyExpressionList.h
extractTableFunctionArgumentsFromSelectQuery.cpp Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
extractTableFunctionArgumentsFromSelectQuery.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
Freeze.cpp
Freeze.h
getStructureOfRemoteTable.cpp Merge pull request #52068 from azat/replicated-cluster-prep1 2023-07-24 22:57:44 +03:00
getStructureOfRemoteTable.h
getVirtualsForStorage.cpp
getVirtualsForStorage.h
IMessageProducer.cpp
IMessageProducer.h
IndicesDescription.cpp Make serializeAST() more regular 2023-07-20 10:39:26 +00:00
IndicesDescription.h
IStorage_fwd.h
IStorage.cpp Fix build 2023-07-17 19:15:07 +02:00
IStorage.h Merge branch 'master' into add_delay_for_replicated 2023-07-26 12:48:48 +03:00
IStorageCluster.cpp Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
IStorageCluster.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp Cleanup. 2023-06-22 14:23:04 +00:00
KVStorageUtils.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
LightweightDeleteDescription.cpp
LightweightDeleteDescription.h
MarkCache.h Reduce inter-header dependencies 2023-05-02 21:15:18 +02:00
MemorySettings.cpp
MemorySettings.h
MessageQueueSink.cpp
MessageQueueSink.h release buffers with exception context 2023-06-22 13:00:13 +02:00
MutationCommands.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
MutationCommands.h
NamedCollectionsHelpers.cpp Rename 2023-06-15 12:35:22 +02: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
PartitionedSink.cpp release buffers with exception context 2023-06-22 13:00:13 +02:00
PartitionedSink.h release buffers with exception context 2023-06-22 13:00:13 +02:00
ProjectionsDescription.cpp Merge pull request #52151 from amosbird/fix_52075 2023-07-21 18:30:27 +02:00
ProjectionsDescription.h
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h
ReadInOrderOptimizer.cpp
ReadInOrderOptimizer.h
RedisCommon.cpp fix code style 2023-06-02 10:05:54 +08:00
RedisCommon.h fix build error for dwrwin 2023-06-02 10:05:54 +08:00
registerStorages.cpp Merge branch 'master' into support_redis 2023-06-09 11:45:12 -04:00
registerStorages.h
removeGroupingFunctionSpecializations.cpp Resolve as FunctionGrouping 2023-03-14 03:33:31 +00:00
removeGroupingFunctionSpecializations.h
RenamingRestrictions.h
SelectQueryDescription.cpp
SelectQueryDescription.h
SelectQueryInfo.cpp Fixing build. 2023-05-23 20:47:35 +00:00
SelectQueryInfo.h Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02:00
SetSettings.cpp
SetSettings.h
StorageAzureBlob.cpp Fixes 2023-06-29 11:59:09 +00:00
StorageAzureBlob.h Fixes 2023-06-29 11:59:09 +00:00
StorageBuffer.cpp Make shutdown of replicated tables softer 2023-07-05 18:11:25 +02:00
StorageBuffer.h Make shutdown of replicated tables softer 2023-07-05 18:11:25 +02:00
StorageConfiguration.h
StorageDictionary.cpp
StorageDictionary.h Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
StorageDistributed.cpp Merge branch 'master' into add_delay_for_replicated 2023-07-24 16:07:38 +02:00
StorageDistributed.h Merge branch 'master' into add_delay_for_replicated 2023-07-24 16:07:38 +02:00
StorageDummy.cpp Refactor a bit. 2023-06-16 19:38:50 +00:00
StorageDummy.h Fix Object data type for StorageDistributed 2023-06-02 23:41:25 +02:00
StorageExecutable.cpp
StorageExecutable.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
StorageExternalDistributed.cpp Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
StorageExternalDistributed.h
StorageFactory.cpp
StorageFactory.h new redis engine schema design 2023-06-02 10:05:54 +08:00
StorageFile.cpp Refactoring 2023-07-31 08:50:09 +00:00
StorageFile.h Fix build 2023-07-28 12:26:56 +00:00
StorageGenerateRandom.cpp Control memory usage in generateRandom 2023-06-04 04:44:51 +02:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp Proper mutation of skip indices and projections 2023-06-04 18:32:08 +08:00
StorageInMemoryMetadata.h Proper mutation of skip indices and projections 2023-06-04 18:32:08 +08:00
StorageInput.cpp
StorageInput.h
StorageJoin.cpp addJoinedBlock -> addBlockToJoin 2023-07-05 17:03:18 +00:00
StorageJoin.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageKeeperMap.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageKeeperMap.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageLog.cpp Fix Log family table return wrong rows count after truncate (#50585) 2023-06-09 14:32:45 +03:00
StorageLog.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageLogSettings.cpp
StorageLogSettings.h
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h Introduce IStorage::supportsTrivialCountOptimization() 2023-07-24 05:50:44 +02:00
StorageMaterializedView.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMaterializedView.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMemory.cpp Refactor a bit. 2023-06-16 19:38:50 +00:00
StorageMemory.h Merge branch 'master' into refactor-subqueries-for-in 2023-06-09 20:04:27 +02:00
StorageMerge.cpp Add a note about not working _table filter for Merge with analyzer 2023-07-27 16:35:17 +02:00
StorageMerge.h Fixes for parallel replicas (#50195) 2023-05-25 14:41:04 +02:00
StorageMergeTree.cpp Fix build 2023-07-18 22:19:35 +02:00
StorageMergeTree.h Merge branch 'master' into fix-potentially-bad-code 2023-07-18 22:18:22 +02: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 MaterializedMySQL: Support unquoted utf-8 strings in DDL 2023-07-24 11:12:10 +02:00
StorageMySQL.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageNull.cpp
StorageNull.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StoragePostgreSQL.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StoragePostgreSQL.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageProxy.h Merge branch 'master' into add_delay_for_replicated 2023-07-26 12:48:48 +03: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 use same executor for GET_PART and ATTACH_PART 2023-07-28 07:08:11 +00:00
StorageReplicatedMergeTree.h Merge branch 'master' into add_delay_for_replicated 2023-07-26 12:48:48 +03:00
StorageS3.cpp Merge branch 'master' into better-progress-bar-2 2023-07-24 19:59:38 +02:00
StorageS3.h Merge branch 'master' into better-progress-bar-2 2023-07-18 13:37:53 +02:00
StorageS3Cluster.cpp Merge branch 'master' into better-progress-bar-2 2023-07-24 19:59:38 +02:00
StorageS3Cluster.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
StorageS3Settings.cpp More generic approach to disable native copy 2023-07-09 08:20:02 +02:00
StorageS3Settings.h More generic approach to disable native copy 2023-07-09 08:20:02 +02:00
StorageSet.cpp Cleanup. 2023-06-22 14:23:04 +00:00
StorageSet.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageSnapshot.cpp Fixed clang tidy build by removing unued variable 2023-07-29 11:15:56 +02:00
StorageSnapshot.h Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02:00
StorageSQLite.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02: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 Fix Log family table return wrong rows count after truncate (#50585) 2023-06-09 14:32:45 +03:00
StorageStripeLog.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageTableFunction.h Merge pull request #52626 from ClickHouse/fix_deadlock_in_persistent_table_functions 2023-07-27 09:38:48 +02:00
StorageURL.cpp Merge branch 'master' into better-progress-bar-2 2023-07-26 13:12:24 +02:00
StorageURL.h Merge branch 'master' of github.com:ClickHouse/ClickHouse into better-progress-bar-2 2023-06-28 18:53:08 +00:00
StorageURLCluster.cpp Fix build 2023-06-21 02:33:38 +02:00
StorageURLCluster.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +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 Create new StorageView with substituted parameters for every SELECT query of a parameterized view 2023-07-25 14:04:55 +02: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 Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageXDBC.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp Make IAST::FormatSettings more regular, pt. III 2023-07-20 10:34:05 +00: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 RFC: Fix filtering by virtual columns with OR expression 2023-07-27 16:35:17 +02:00
VirtualColumnUtils.h