ClickHouse/src/Storages
2022-05-18 01:56:56 +00:00
..
Cache Merge pull request #36650 from bigo-sg/hive_text_parallel_parsing 2022-05-03 15:56:28 +02:00
Distributed remove last mentions of data streams 2022-05-09 19:15:24 +00:00
examples Remove Arcadia 2022-04-16 00:20:47 +02:00
FileLog Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
fuzzers
HDFS Finalize write buffers in case of exception 2022-05-06 17:30:18 +00:00
Hive Fix build, pt. V 2022-05-04 15:50:52 +02:00
Kafka remove last mentions of data streams 2022-05-09 19:15:24 +00:00
LiveView remove last mentions of data streams 2022-05-09 19:15:24 +00:00
MeiliSearch refactor code & change exception numbers 2022-05-16 16:13:05 +03:00
MergeTree Merge pull request #37164 from kssenii/ficx-async-reads-assertions 2022-05-17 11:29:14 +02:00
MySQL Settings changes as key value 2021-12-27 17:45:00 +03:00
PostgreSQL Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
RabbitMQ Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
RocksDB Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
System Enable clang-tidy modernize-deprecated-headers & hicpp-deprecated-headers 2022-05-09 08:23:33 +02:00
tests Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
WindowView Merge branch 'master' into wv-engine 2022-05-17 02:24:18 +00:00
AlterCommands.cpp Require mutations for DROP COLUMN by root column name for nested columns 2022-04-29 07:09:34 +03:00
AlterCommands.h Fix Alter ttl modification unsupported table engine 2022-01-24 21:48:52 +08:00
CheckResults.h
CMakeLists.txt
ColumnCodec.h
ColumnDefault.cpp added EPHEMERAL default for column (preliminary) 2022-02-07 23:21:10 +00:00
ColumnDefault.h added EPHEMERAL default for column (preliminary) 2022-02-07 23:21:10 +00:00
ColumnDependency.h
ColumnsDescription.cpp Fix ALTER DROP COLUMN of nested column with compact parts 2022-04-29 07:12:34 +03:00
ColumnsDescription.h Fix ALTER DROP COLUMN of nested column with compact parts 2022-04-29 07:12:34 +03:00
CompressionCodecSelector.h Fix clang-tidy warnings in Server, Storages folders 2022-03-14 18:17:35 +00:00
ConstraintsDescription.cpp Activate clang-tidy warning "readability-container-contains" 2022-04-18 23:53:11 +02:00
ConstraintsDescription.h clang-tidy check performance-move-const-arg fix 2022-03-02 18:15:27 +00:00
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h Updated executable function integration tests 2021-12-28 22:55:30 +03:00
ExternalDataSourceConfiguration.cpp Fix 2022-03-24 19:10:53 +01:00
ExternalDataSourceConfiguration.h Better s3 settings 2022-04-04 16:14:56 +02:00
extractKeyExpressionList.cpp
extractKeyExpressionList.h
getStructureOfRemoteTable.cpp cache common type on objects in MergeTree 2022-02-09 23:47:53 +03:00
getStructureOfRemoteTable.h add more comments 2022-03-01 19:32:55 +03:00
getVirtualsForStorage.cpp Better 2022-03-28 22:40:27 +02:00
getVirtualsForStorage.h Fix clang-tidy, style check 2022-03-29 14:20:21 +02:00
IndicesDescription.cpp Add name hints for data skipping indices 2022-02-20 11:48:22 +00:00
IndicesDescription.h add hints for column description 2022-04-04 07:24:42 +00:00
IStorage_fwd.h
IStorage.cpp Implement BACKUP/RESTORE ON CLUSTER. 2022-04-25 16:34:33 +02:00
IStorage.h BACKUP ON CLUSTER correctly collects data of a replicated table from all replicas now, 2022-05-12 13:33:42 +02:00
KeyDescription.cpp Update KeyDescription.cpp 2022-02-07 13:59:03 +03:00
KeyDescription.h fix local metadata differ zk metadata 2022-01-27 16:33:40 +08:00
MarkCache.h Fix clang-tidy warnings in Server, Storages folders 2022-03-14 18:17:35 +00:00
MemorySettings.cpp
MemorySettings.h
MutationCommands.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
MutationCommands.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
PartitionCommands.cpp Reduce dependencies on ASTIdentifier.h 2021-11-26 16:49:40 +01:00
PartitionCommands.h
PartitionedSink.cpp Finalize write buffers in case of exception 2022-05-06 17:30:18 +00:00
PartitionedSink.h Finalize write buffers in case of exception 2022-05-06 17:30:18 +00:00
ProjectionsDescription.cpp ProjectionsDescription: pass through min_block_size_bytes for SquashingChunksTransform 2022-04-29 17:04:56 +03:00
ProjectionsDescription.h add hints for projections 2022-04-04 07:24:42 +00:00
ReadFinalForExternalReplicaStorage.cpp Merge pull request #36444 from rschu1ze/clang-tidy-fixes 2022-04-21 16:11:27 +02:00
ReadFinalForExternalReplicaStorage.h Merge remote-tracking branch 'origin/sparse-serialization' into HEAD 2021-11-09 15:36:25 +03:00
ReadInOrderOptimizer.cpp Activate clang-tidy warning "readability-container-contains" 2022-04-18 23:53:11 +02:00
ReadInOrderOptimizer.h support read_in_order optimization if prefix of sorting key is fixed 2021-12-14 15:54:20 +03:00
registerStorages.cpp Merge branch 'master' into MeiliSearch 2022-04-06 17:07:55 +03: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 Make SelectQueryInfo pseudo-copyable 2022-04-07 17:46:50 +08:00
SetSettings.cpp
SetSettings.h
StorageBuffer.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageBuffer.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageDictionary.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageDictionary.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageDistributed.cpp remove last mentions of data streams 2022-05-09 19:15:24 +00:00
StorageDistributed.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageExecutable.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageExecutable.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageExternalDistributed.cpp Fix build, pt. IV 2022-05-04 12:01:29 +02:00
StorageExternalDistributed.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageFactory.cpp improve 2022-02-01 16:59:41 +00:00
StorageFactory.h Fix Alter ttl modification unsupported table engine 2022-01-24 21:48:52 +08:00
StorageFile.cpp Fix test 2022-05-11 14:36:34 +02:00
StorageFile.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageGenerateRandom.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageGenerateRandom.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageInMemoryMetadata.cpp Activate clang-tidy warning "readability-container-contains" 2022-04-18 23:53:11 +02:00
StorageInMemoryMetadata.h Merge remote-tracking branch 'upstream/master' into HEAD 2022-03-03 22:25:28 +00:00
StorageInput.cpp Merge remote-tracking branch 'origin/sparse-serialization' into HEAD 2021-11-09 15:36:25 +03:00
StorageInput.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageJoin.cpp remove last mentions of data streams 2022-05-09 19:15:24 +00:00
StorageJoin.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageLog.cpp Use query scopes for async backup/restore. 2022-05-13 10:35:02 +02:00
StorageLog.h Merge pull request #36864 from vitlibar/backup-improvements-4 2022-05-05 15:37:51 +02:00
StorageLogSettings.cpp
StorageLogSettings.h
StorageMaterializedMySQL.cpp Merge remote-tracking branch 'origin/sparse-serialization' into HEAD 2021-12-01 15:54:33 +03:00
StorageMaterializedMySQL.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageMaterializedView.cpp Merge pull request #36864 from vitlibar/backup-improvements-4 2022-05-05 15:37:51 +02:00
StorageMaterializedView.h Merge pull request #36864 from vitlibar/backup-improvements-4 2022-05-05 15:37:51 +02:00
StorageMemory.cpp Use query scopes for async backup/restore. 2022-05-13 10:35:02 +02:00
StorageMemory.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageMerge.cpp remove last mentions of data streams 2022-05-09 19:15:24 +00:00
StorageMerge.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageMergeTree.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageMergeTree.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageMongoDB.cpp Enable clang-tidy readability-misleading-indentation 2022-05-08 19:12:01 +02:00
StorageMongoDB.h Fix build, pt. III 2022-05-04 11:20:56 +02:00
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Fix build, pt. IV 2022-05-04 12:01:29 +02:00
StorageMySQL.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageNull.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageNull.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StoragePostgreSQL.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StoragePostgreSQL.h remove last mentions of data streams 2022-05-09 19:15:24 +00:00
StorageProxy.h use snapshots for semistructured data, durability fixes 2022-03-17 18:26:18 +01:00
StorageReplicatedMergeTree.cpp Merge pull request #37168 from vitlibar/backup-improvements-5 2022-05-16 21:25:54 +02:00
StorageReplicatedMergeTree.h fix logical error on truncate table 2022-05-06 16:12:31 +02:00
StorageS3.cpp Finalize write buffers in case of exception 2022-05-06 17:30:18 +00:00
StorageS3.h remove last mentions of data streams 2022-05-09 19:15:24 +00:00
StorageS3Cluster.cpp base should not depend on Common 2022-04-29 10:26:35 +08:00
StorageS3Cluster.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageS3Settings.cpp Fix 2022-04-19 11:31:27 +02:00
StorageS3Settings.h Fix 2022-04-08 12:30:24 +02:00
StorageSet.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageSet.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageSnapshot.cpp Activate clang-tidy warning "readability-container-contains" 2022-04-18 23:53:11 +02:00
StorageSnapshot.h fix reading from type object 2022-03-28 17:23:34 +00:00
StorageSQLite.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageSQLite.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageStripeLog.cpp Merge pull request #37168 from vitlibar/backup-improvements-5 2022-05-16 21:25:54 +02:00
StorageStripeLog.h Merge pull request #36864 from vitlibar/backup-improvements-4 2022-05-05 15:37:51 +02:00
StorageTableFunction.h use snapshots for semistructured data, durability fixes 2022-03-17 18:26:18 +01:00
StorageURL.cpp Finalize write buffers in case of exception 2022-05-06 17:30:18 +00:00
StorageURL.h Finalize write buffers in case of exception 2022-05-06 17:30:18 +00:00
StorageValues.cpp Merge remote-tracking branch 'origin/sparse-serialization' into HEAD 2021-11-09 15:36:25 +03:00
StorageValues.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageView.cpp Remove inherited create() method + disallow copying 2022-05-02 08:46:52 +02:00
StorageView.h Don't let storages inherit from boost::noncopyable 2022-05-03 09:07:08 +02:00
StorageXDBC.cpp base should not depend on Common 2022-04-29 10:26:35 +08:00
StorageXDBC.h base should not depend on Common 2022-04-29 10:26:35 +08:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp Fix 2021-12-27 11:59:33 +03:00
transformQueryForExternalDatabase.h
TTLDescription.cpp Activate clang-tidy warning "readability-container-contains" 2022-04-18 23:53:11 +02:00
TTLDescription.h support TTL TO [DISK|VOLUME] [IF EXISTS] 2022-02-10 19:26:23 +03:00
TTLMode.h
VirtualColumnUtils.cpp
VirtualColumnUtils.h