ClickHouse/src/Storages
alesapin ca410b7a0b
Merge pull request #41147 from ClickHouse/enable_projections_and_zero_copy
Enable projections and zero copy replication
2022-09-22 13:05:09 +02:00
..
Cache Small refactoring 2022-08-19 16:42:23 +00:00
Distributed Update src/Storages/Distributed/DirectoryMonitor.cpp 2022-09-08 17:25:29 +08:00
examples Update src/Storages/examples/merge_selector2.cpp 2022-09-20 05:15:47 +03:00
FileLog Create metadata directory on CREATE for FileLog engine 2022-08-06 13:54:49 +03:00
fuzzers
HDFS Fix clang-tidy warnings (from clang-15) 2022-09-10 21:38:35 +02:00
Hive Merge pull request #34651 from alexX512/master 2022-08-12 17:23:37 +02:00
Kafka Small style fixes 2022-09-15 13:05:18 +02:00
LiveView Remove some methods 2022-09-10 05:04:40 +02:00
MeiliSearch
MergeTree Merge pull request #41147 from ClickHouse/enable_projections_and_zero_copy 2022-09-22 13:05:09 +02:00
MySQL Fix 2022-08-29 16:20:53 +02:00
NATS Add retries for nats 2022-09-19 14:27:11 +02:00
PostgreSQL Fix typos with new codespell 2022-09-02 08:54:48 +00:00
RabbitMQ Revert "Create new query context in StorageRabbitMQ/Nat" 2022-08-31 11:57:41 +02:00
RocksDB Minor update StorageEmbeddedRocksDB::getSampleBlock 2022-09-08 12:43:38 +00:00
System Update version to 22.10.1.1 2022-09-22 09:32:38 +02:00
tests Remove cruft 2022-09-17 22:16:31 +02:00
WindowView Remove some methods 2022-09-10 05:04:40 +02:00
AlterCommands.cpp Fix typos with new codespell 2022-09-02 08:54:48 +00:00
AlterCommands.h
checkAndGetLiteralArgument.cpp address comments 2022-08-17 23:25:42 +08:00
checkAndGetLiteralArgument.h
CheckResults.h
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h
ColumnsDescription.cpp Merge remote-tracking branch 'upstream/master' into HEAD 2022-09-02 12:48:27 +00:00
ColumnsDescription.h Cleanups 2022-07-24 12:21:18 +02:00
CompressionCodecSelector.h
ConstraintsDescription.cpp
ConstraintsDescription.h
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h
ExternalDataSourceConfiguration.cpp Fix 2022-08-29 16:20:53 +02:00
ExternalDataSourceConfiguration.h update tcp protocol, add quota_key 2022-08-03 15:44:08 -04:00
extractKeyExpressionList.cpp
extractKeyExpressionList.h
Freeze.cpp Update src/Storages/Freeze.cpp 2022-09-09 16:20:24 +03:00
Freeze.h fix underscore 2022-08-23 13:59:02 +03:00
getStructureOfRemoteTable.cpp Remove some methods 2022-09-10 05:04:40 +02:00
getStructureOfRemoteTable.h
getVirtualsForStorage.cpp
getVirtualsForStorage.h
IndicesDescription.cpp
IndicesDescription.h
IStorage_fwd.h
IStorage.cpp
IStorage.h Cleanup usages of allow_experimental_projection_optimization setting, part 1 2022-07-30 23:40:21 +02:00
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp Extract common KV storage logic 2022-08-16 09:32:01 +00:00
KVStorageUtils.h Extract common KV storage logic 2022-08-16 09:32:01 +00:00
LightweightDeleteDescription.cpp Capitalized const name 2022-07-25 16:32:16 +02:00
LightweightDeleteDescription.h Capitalized const name 2022-07-25 16:32:16 +02:00
MarkCache.h Fix review 2022-08-08 21:34:24 +00:00
MemorySettings.cpp
MemorySettings.h
MutationCommands.cpp
MutationCommands.h
PartitionCommands.cpp
PartitionCommands.h Fix typos with new codespell 2022-09-02 08:54:48 +00:00
PartitionedSink.cpp Merge branch 'master' into refactor-read-metrics-and-callbacks 2022-05-25 16:27:40 +02:00
PartitionedSink.h
ProjectionsDescription.cpp Fix building aggregate projections when external aggregation is on (#39671) 2022-08-04 23:29:26 +02:00
ProjectionsDescription.h
ReadFinalForExternalReplicaStorage.cpp Fix some more tests. 2022-06-01 15:21:47 +00:00
ReadFinalForExternalReplicaStorage.h
ReadInOrderOptimizer.cpp Merge branch 'master' into fix-read-in-order-fixed-prefix 2022-08-29 13:17:26 +02:00
ReadInOrderOptimizer.h
registerStorages.cpp Initial implementation of KeeperMap 2022-08-08 09:29:15 +00:00
registerStorages.h
SelectQueryDescription.cpp Fix LOGICAL_ERROR for MATERIALIZED VIEW over table functions (i.e. numbers()) 2021-12-11 11:04:47 +03:00
SelectQueryDescription.h
SelectQueryInfo.h Tiny improvements along the code 2022-09-13 12:06:56 +00:00
SetSettings.cpp
SetSettings.h
StorageBuffer.cpp Suggestions from @azat 2022-08-26 03:00:56 +02:00
StorageBuffer.h Suggestions from @azat 2022-08-26 03:00:56 +02:00
StorageDictionary.cpp
StorageDictionary.h
StorageDistributed.cpp Fix 5/6 of trash 2022-09-19 08:50:53 +02:00
StorageDistributed.h Revert "Parallel distributed insert select from *Cluster table functions (#39107)" 2022-08-24 15:17:15 +03:00
StorageExecutable.cpp
StorageExecutable.h
StorageExternalDistributed.cpp
StorageExternalDistributed.h
StorageFactory.cpp
StorageFactory.h
StorageFile.cpp Fix 5/6 of trash 2022-09-19 08:50:53 +02:00
StorageFile.h Refactor, remove TTL, add size limit, add system table and system query 2022-08-05 16:20:15 +00:00
StorageGenerateRandom.cpp Merge branch 'master' of github.com:ClickHouse/ClickHouse into ADQM-485 2022-07-25 17:55:47 +00:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp Try to fix tests 2022-08-21 09:23:37 +00:00
StorageInMemoryMetadata.h Cleanups 2022-07-24 12:21:18 +02:00
StorageInput.cpp
StorageInput.h
StorageJoin.cpp Rename join_common -> JoinUtils 2022-08-10 14:20:28 +00:00
StorageJoin.h Simplify the code and check what will happen 2022-08-15 06:56:29 +02:00
StorageKeeperMap.cpp Address PR comments 2022-09-12 14:43:52 +00:00
StorageKeeperMap.h Address PR comments 2022-09-12 14:43:52 +00:00
StorageLog.cpp Move back TemporaryFile -> TemporaryFileOnDisk 2022-08-24 16:14:11 +00:00
StorageLog.h
StorageLogSettings.cpp
StorageLogSettings.h
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h
StorageMaterializedView.cpp
StorageMaterializedView.h
StorageMemory.cpp try to fix filling of missed Nested columns with multiple levels 2022-09-06 13:56:32 +00:00
StorageMemory.h Make temporary files in better places. 2022-07-04 11:02:58 +02:00
StorageMerge.cpp Fix 5/6 of trash 2022-09-19 08:50:53 +02:00
StorageMerge.h Fix KeyCondition with other filters 2022-08-11 19:20:44 +08:00
StorageMergeTree.cpp fix adding of columns of type Object 2022-09-13 22:43:59 +00:00
StorageMergeTree.h remove wrong code for skipping mutations in MergeTree 2022-08-24 20:58:59 +02:00
StorageMongoDB.cpp
StorageMongoDB.h
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Fix 5/6 of trash 2022-09-19 08:50:53 +02:00
StorageMySQL.h
StorageNull.cpp
StorageNull.h
StoragePostgreSQL.cpp
StoragePostgreSQL.h
StorageProxy.h
StorageReplicatedMergeTree.cpp Nasty code 2022-09-20 17:55:06 +02:00
StorageReplicatedMergeTree.h Nasty code 2022-09-20 17:55:06 +02:00
StorageS3.cpp fix issues 2022-09-19 18:40:32 +00:00
StorageS3.h Refactor, remove TTL, add size limit, add system table and system query 2022-08-05 16:20:15 +00:00
StorageS3Cluster.cpp Revert "Parallel distributed insert select from *Cluster table functions (#39107)" 2022-08-24 15:17:15 +03:00
StorageS3Cluster.h Revert "Parallel distributed insert select from *Cluster table functions (#39107)" 2022-08-24 15:17:15 +03:00
StorageS3Settings.cpp Revert s3 prefixes + add retries on write requests unexpected errors 2022-09-16 14:43:43 +02:00
StorageS3Settings.h Revert s3 prefixes + add retries on write requests unexpected errors 2022-09-16 14:43:43 +02:00
StorageSet.cpp Simplify the code and check what will happen 2022-08-15 06:56:29 +02:00
StorageSet.h
StorageSnapshot.cpp Try to fix tests 2022-08-21 09:23:37 +00:00
StorageSnapshot.h Cleanups 2022-07-24 12:21:18 +02:00
StorageSQLite.cpp
StorageSQLite.h
StorageStripeLog.cpp Move back TemporaryFile -> TemporaryFileOnDisk 2022-08-24 16:14:11 +00:00
StorageStripeLog.h
StorageTableFunction.h
StorageURL.cpp Merge branch 'master' into tracing_context_propagation 2022-08-30 14:24:36 +08:00
StorageURL.h Merge pull request #40600 from FrankChen021/check_url_arg 2022-08-27 19:29:55 +03:00
StorageValues.cpp
StorageValues.h
StorageView.cpp Fix view with merge table function (#40734) 2022-09-01 12:20:00 +02:00
StorageView.h
StorageXDBC.cpp Merge pull request #40600 from FrankChen021/check_url_arg 2022-08-27 19:29:55 +03:00
StorageXDBC.h Merge branch 'master' into xdbc-constraints 2022-08-20 21:26:07 +03:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp
transformQueryForExternalDatabase.h
TTLDescription.cpp
TTLDescription.h Cleanups 2022-07-24 12:21:18 +02:00
TTLMode.h
UVLoop.h
VirtualColumnUtils.cpp Refactor PreparedSets/SubqueryForSet 2022-07-26 18:39:02 +00:00
VirtualColumnUtils.h