ClickHouse/src/Storages
2023-05-23 23:10:34 +08:00
..
Cache Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
DataLakes Switch Block::NameMap to google::dense_hash_map over HashMap 2023-05-12 05:52:57 +02:00
Distributed Fix processing pending batch for Distributed async INSERT after restart 2023-05-15 15:57:30 +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 Get rid of finalize callback in object storages 2023-05-19 17:29:37 +02:00
Hive Remove dependency from DB::Context in readers 2023-05-02 21:45:27 +02:00
Kafka apply review suggestions 2023-05-22 15:18:29 +02:00
LiveView Remove -Wshadow suppression which leaked into global namespace 2023-04-13 08:46:40 +00:00
MeiliSearch Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
MergeTree Fix invalid index analysis for date related keys 2023-05-23 23:10:34 +08:00
MySQL Fox 2023-04-13 19:36:25 +02:00
NATS Highly questionable refactoring (getInputMultistream() nonsense) 2023-04-17 04:58:32 +00:00
PostgreSQL replace NO DELAY with SYNC in tests 2023-05-03 20:08:49 +02:00
RabbitMQ fix convertation 2023-05-10 17:50:42 +00:00
RocksDB Merge pull request #48435 from ClickHouse/kv-update-only-affected-rows 2023-04-06 12:33:54 +02:00
System New system table zookeeper connection (#45245) 2023-05-19 17:06:43 +03:00
tests Remove unused mockSystemDatabase from gtest_transform_query_for_external_database 2023-03-29 11:02:50 +00:00
WindowView use Poco::Timestamp() instead of std::time 2023-04-20 14:36:54 +00:00
addColumnsStructureToQueryWithClusterEngine.cpp Correctly append arguments 2023-05-04 08:30:45 +00:00
addColumnsStructureToQueryWithClusterEngine.h Correctly append arguments 2023-05-04 08:30:45 +00:00
AlterCommands.cpp Merge pull request #49563 from evillique/object-column-alter 2023-05-06 18:17:16 +03:00
AlterCommands.h
checkAndGetLiteralArgument.cpp
checkAndGetLiteralArgument.h
CheckResults.h
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h
ColumnsDescription.cpp Allow using Alias column type for KafkaEngine 2023-05-15 15:39:58 +02:00
ColumnsDescription.h Allow using Alias column type for KafkaEngine 2023-05-15 15:39:58 +02:00
CompressionCodecSelector.h
ConstraintsDescription.cpp
ConstraintsDescription.h
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h
ExternalDataSourceConfiguration.cpp
ExternalDataSourceConfiguration.h
extractKeyExpressionList.cpp
extractKeyExpressionList.h
Freeze.cpp
Freeze.h
getStructureOfRemoteTable.cpp
getStructureOfRemoteTable.h
getVirtualsForStorage.cpp
getVirtualsForStorage.h
IMessageProducer.cpp
IMessageProducer.h
IndicesDescription.cpp
IndicesDescription.h
IStorage_fwd.h
IStorage.cpp Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
IStorage.h Merge pull request #49434 from ClickHouse/ins 2023-05-09 08:10:15 +03:00
IStorageCluster.h
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp
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
MutationCommands.cpp
MutationCommands.h
NamedCollectionsHelpers.cpp
NamedCollectionsHelpers.h
PartitionCommands.cpp
PartitionCommands.h
PartitionedSink.cpp
PartitionedSink.h Fix double whitespace in exception message 2023-04-15 23:54:10 +02:00
ProjectionsDescription.cpp
ProjectionsDescription.h
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h
ReadFromStorageProgress.cpp
ReadFromStorageProgress.h
ReadInOrderOptimizer.cpp
ReadInOrderOptimizer.h
registerStorages.cpp fix build without parquet 2023-04-17 21:37:32 -07:00
registerStorages.h
removeGroupingFunctionSpecializations.cpp
removeGroupingFunctionSpecializations.h
RenamingRestrictions.h
SelectQueryDescription.cpp
SelectQueryDescription.h
SelectQueryInfo.h
SetSettings.cpp
SetSettings.h
StorageBuffer.cpp Only check MV on ALTER when necessary 2023-03-27 17:45:15 +02:00
StorageBuffer.h
StorageConfiguration.h
StorageDictionary.cpp
StorageDictionary.h Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
StorageDistributed.cpp Fixes for clang-17 2023-05-13 02:57:31 +02:00
StorageDistributed.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
StorageDummy.cpp
StorageDummy.h
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
StorageFile.cpp Disable mmap for server 2023-05-10 03:16:52 +02:00
StorageFile.h Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
StorageGenerateRandom.cpp Fix IBM 2023-04-21 12:38:45 +02:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp
StorageInMemoryMetadata.h
StorageInput.cpp
StorageInput.h
StorageJoin.cpp Fix key not found error for queries with multiple StorageJoin 2023-04-25 11:28:54 +00:00
StorageJoin.h
StorageKeeperMap.cpp Merge pull request #48435 from ClickHouse/kv-update-only-affected-rows 2023-04-06 12:33:54 +02:00
StorageKeeperMap.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
StorageLog.cpp Add backup setting "decrypt_files_from_encrypted_disks" 2023-05-16 14:27:27 +02:00
StorageLog.h
StorageLogSettings.cpp
StorageLogSettings.h
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h
StorageMaterializedView.cpp Fix race between DROP MatView and RESTART REPLICAS (#47863) 2023-04-01 15:26:00 +03:00
StorageMaterializedView.h
StorageMemory.cpp Corrections after review. 2023-05-17 03:23:16 +02:00
StorageMemory.h move pipe compute into initializePipeline 2023-05-02 14:59:41 +02:00
StorageMerge.cpp Merge pull request #48062 from Algunenano/unnecessary_alter_checks 2023-04-03 17:23:11 -04:00
StorageMerge.h Fix crash in EXPLAIN PIPELINE for Merge over Distributed 2023-04-02 10:48:23 +02:00
StorageMergeTree.cpp Add backup setting "decrypt_files_from_encrypted_disks" 2023-05-16 14:27:27 +02:00
StorageMergeTree.h add lock 2023-05-10 23:00:49 +00:00
StorageMongoDB.cpp Add support for {server_uuid} macro 2023-04-09 03:04:26 +02:00
StorageMongoDB.h fix typo 2023-05-15 16:51:20 +08:00
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Fix style 2023-05-19 01:31:45 +00:00
StorageMySQL.h Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
StorageNull.cpp Only check MV on ALTER when necessary 2023-03-27 17:45:15 +02:00
StorageNull.h Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
StoragePostgreSQL.cpp Merge pull request #50000 from evillique/add-schema-inference 2023-05-22 17:24:30 +02:00
StoragePostgreSQL.h Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
StorageProxy.h
StorageReplicatedMergeTree.cpp apply review suggestions 2023-05-22 15:18:29 +02:00
StorageReplicatedMergeTree.h use flag has_exclusive_blobs to track the part's originate 2023-05-06 03:07:29 +02:00
StorageS3.cpp Get rid of finalize callback in object storages 2023-05-19 17:29:37 +02:00
StorageS3.h Switch Block::NameMap to google::dense_hash_map over HashMap 2023-05-12 05:52:57 +02:00
StorageS3Cluster.cpp Correctly append arguments 2023-05-04 08:30:45 +00:00
StorageS3Cluster.h Correctly append arguments 2023-05-04 08:30:45 +00:00
StorageS3Settings.cpp Add ability to use strict parts size for S3 (compatibility with R2) 2023-04-28 11:01:56 +02:00
StorageS3Settings.h Add ability to use strict parts size for S3 (compatibility with R2) 2023-04-28 11:01:56 +02:00
StorageSet.cpp Merge remote-tracking branch 'origin/master' into optimize-compilation 2023-04-13 16:04:09 +02:00
StorageSet.h Improve file includes 2023-03-24 03:44:52 +01:00
StorageSnapshot.cpp
StorageSnapshot.h
StorageSQLite.cpp Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
StorageSQLite.h Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
StorageStripeLog.cpp Add backup setting "decrypt_files_from_encrypted_disks" 2023-05-16 14:27:27 +02:00
StorageStripeLog.h
StorageTableFunction.h
StorageURL.cpp Merge pull request #49356 from Ziy1-Tan/vcol 2023-05-22 18:10:32 +02:00
StorageURL.h Merge pull request #49356 from Ziy1-Tan/vcol 2023-05-22 18:10:32 +02:00
StorageValues.cpp
StorageValues.h
StorageView.cpp
StorageView.h
StorageXDBC.cpp
StorageXDBC.h
TableLockHolder.h
transformQueryForExternalDatabase.cpp
transformQueryForExternalDatabase.h
transformQueryForExternalDatabaseAnalyzer.cpp
transformQueryForExternalDatabaseAnalyzer.h
TTLDescription.cpp
TTLDescription.h
TTLMode.h
UVLoop.h
VirtualColumnUtils.cpp Do not skip building set even when reading from remote 2023-05-02 21:31:56 +02:00
VirtualColumnUtils.h