ClickHouse/src/Storages
Maksim Kita 801c6c1e99
Merge pull request #31119 from nautaa/fix-file-log
remove unnecessary assert in StorageFileLog
2021-11-24 12:28:13 +03:00
..
Distributed Fix tests 2021-11-11 20:27:23 +03:00
examples Rename "common" to "base" 2021-10-02 10:13:14 +03:00
FileLog remove unnecessary assert 2021-11-06 21:00:24 +08:00
fuzzers better 2021-08-25 15:40:56 +00:00
HDFS Merge branch 'master' into fix-write-buffers 2021-11-20 17:48:24 +03:00
Kafka Minor change 2021-11-11 21:09:21 +03:00
LiveView Merge branch 'master' into query_parameters 2021-11-16 10:37:58 +00:00
MergeTree Use shard and replica name from Replicated database arguments (#31488) 2021-11-23 12:41:54 +03:00
MySQL Introduce connection_no_wait setting for MySQL engine. 2021-09-02 22:23:37 +03:00
PostgreSQL Rename Quota::ResourceType -> QuotaType and move it to Access/Common. 2021-11-19 00:14:23 +03:00
RabbitMQ Rename RowPolicy::ConditionType -> RowPolicyFilterType and move it to Access/Common. 2021-11-19 00:14:23 +03:00
RocksDB Move some files. 2021-10-16 17:03:50 +03:00
System Merge pull request #30599 from ClickHouse/zlib-ng-own-cmake 2021-11-23 13:33:29 +03:00
tests Drop support for DatabaseOrdinary in MaterializedMySQL 2021-11-18 11:46:51 +01:00
AlterCommands.cpp minor fixes in constraints 2021-11-17 18:43:02 +03:00
AlterCommands.h allow to remove SAMPLE BY expression 2021-10-14 17:05:20 +03:00
CheckResults.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
CMakeLists.txt Lower the size of the binaries 2021-08-21 02:20:23 +00:00
ColumnCodec.h
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
ColumnsDescription.cpp Update src/Storages/ColumnsDescription.cpp 2021-09-24 14:08:33 +03:00
ColumnsDescription.h
CompressionCodecSelector.h
ConstraintsDescription.cpp minor fixes in constraints 2021-11-17 18:43:02 +03:00
ConstraintsDescription.h minor fixes in constraints 2021-11-17 18:43:02 +03:00
DataDestinationType.h
ExecutableSettings.cpp Executable added option send_chunk_header 2021-09-10 01:04:52 +03:00
ExecutableSettings.h Executable added option send_chunk_header 2021-09-10 01:04:52 +03:00
ExternalDataSourceConfiguration.cpp Fix tests 2021-11-02 07:27:13 +00:00
ExternalDataSourceConfiguration.h Review fixes 2021-10-28 15:44:12 +03:00
extractKeyExpressionList.cpp
extractKeyExpressionList.h
getStructureOfRemoteTable.cpp Remove DataStreams folder. 2021-10-15 23:18:20 +03:00
getStructureOfRemoteTable.h
IndicesDescription.cpp
IndicesDescription.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
IStorage_fwd.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
IStorage.cpp Support BACKUP & RESTORE for log family. 2021-11-01 12:07:17 +03:00
IStorage.h return fake create query when executing show create table on system's tables. (#31391) 2021-11-19 13:25:55 +03:00
JoinSettings.cpp
JoinSettings.h
KeyDescription.cpp Add empty key description builder. 2021-09-24 01:35:41 +08:00
KeyDescription.h Add empty key description builder. 2021-09-24 01:35:41 +08:00
MarkCache.h Remove DataStreams folder. 2021-10-15 23:18:20 +03:00
MemorySettings.cpp
MemorySettings.h
MutationCommands.cpp Rename "common" to "base" 2021-10-02 10:13:14 +03:00
MutationCommands.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
PartitionCommands.cpp Move some files. 2021-10-16 17:03:50 +03:00
PartitionCommands.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
PartitionedSink.cpp Rename RowPolicy::ConditionType -> RowPolicyFilterType and move it to Access/Common. 2021-11-19 00:14:23 +03:00
PartitionedSink.h For storage 2021-10-27 10:04:17 +03:00
ProjectionsDescription.cpp fix 2021-11-17 23:11:23 +08:00
ProjectionsDescription.h fix 2021-11-17 23:11:23 +08:00
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h Remove cruft 2021-10-28 02:10:39 +03:00
ReadInOrderOptimizer.cpp Better code. 2021-08-17 12:32:49 +08:00
ReadInOrderOptimizer.h
registerStorages.cpp Merge pull request #30689 from vitlibar/refactor-log-family 2021-10-31 18:50:08 +03:00
registerStorages.h
SelectQueryDescription.cpp AddDefaultDatabaseVisitor support dictGet 2021-10-14 16:31:32 +03:00
SelectQueryDescription.h
SelectQueryInfo.h Better Projection IN 2021-10-29 20:24:36 +08:00
SetSettings.cpp
SetSettings.h
StorageBuffer.cpp enable modify table comment of some table 2021-10-29 12:31:18 +00:00
StorageBuffer.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StorageDictionary.cpp Merge pull request #30500 from kitaisreal/dictionaries-read-multiple-threads 2021-10-25 15:31:50 +03:00
StorageDictionary.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageDistributed.cpp enable modify table comment of some table 2021-10-29 12:31:18 +00:00
StorageDistributed.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StorageExecutable.cpp Rename Quota::ResourceType -> QuotaType and move it to Access/Common. 2021-11-19 00:14:23 +03:00
StorageExecutable.h Remove DataStreams folder. 2021-10-15 23:18:20 +03:00
StorageExternalDistributed.cpp Partitioned write part 2 2021-10-26 14:00:41 +03:00
StorageExternalDistributed.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageFactory.cpp Merge branch 'master' into query_parameters 2021-10-18 17:34:20 +03:00
StorageFactory.h Move access-rights' source files needed for parser to a separate target. 2021-11-01 19:13:49 +03:00
StorageFile.cpp Merge branch 'master' into fix-write-buffers 2021-11-20 17:48:24 +03:00
StorageFile.h One more fix 2021-10-29 00:50:59 +03:00
StorageGenerateRandom.cpp Move some files. 2021-10-16 17:03:50 +03:00
StorageGenerateRandom.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageInMemoryMetadata.cpp Simplify projection, add minmax_count projection. 2021-08-28 11:25:37 +08:00
StorageInMemoryMetadata.h Merge branch 'master' of https://github.com/ClickHouse/ClickHouse into materialized-postgresql 2021-09-03 09:03:48 +00:00
StorageInput.cpp Move some files. 2021-10-16 17:03:50 +03:00
StorageInput.h Move some files. 2021-10-16 17:03:50 +03:00
StorageJoin.cpp Move some files. 2021-10-16 17:03:50 +03:00
StorageJoin.h Merge branch 'master' into join_deadlock 2021-10-11 10:18:17 +03:00
StorageLog.cpp Split backup implementation into two parts to help implementing other backup engines. 2021-11-10 11:03:03 +03:00
StorageLog.h Support BACKUP & RESTORE for log family. 2021-11-01 12:07:17 +03:00
StorageLogSettings.cpp
StorageLogSettings.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageMaterializedMySQL.cpp fix clang13 warning 2021-11-18 16:53:41 +01:00
StorageMaterializedMySQL.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageMaterializedView.cpp Merge branch 'master' into query_parameters 2021-11-11 11:43:00 +00:00
StorageMaterializedView.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StorageMemory.cpp Move some files. 2021-10-16 17:03:50 +03:00
StorageMemory.h Remove BlockInputStream interfaces. 2021-10-14 13:25:43 +03:00
StorageMerge.cpp Merge pull request #31044 from kssenii/fix-storage-merge-with-aliases-and-where 2021-11-11 21:46:02 +03:00
StorageMerge.h Fix build check 2021-11-11 02:03:56 +03:00
StorageMergeTree.cpp Update StorageMergeTree.cpp 2021-11-19 20:05:45 +03:00
StorageMergeTree.h remove strange multimap from mutations 2021-11-19 19:54:43 +03:00
StorageMongoDB.cpp Review fixes 2021-10-23 18:20:31 +03:00
StorageMongoDB.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageMongoDBSocketFactory.cpp Remove cruft 2021-10-28 02:10:39 +03:00
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Review fixes 2021-10-23 18:20:31 +03:00
StorageMySQL.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageNull.cpp change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StorageNull.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StoragePostgreSQL.cpp Review fixes 2021-10-23 18:20:31 +03:00
StoragePostgreSQL.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageProxy.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StorageReplicatedMergeTree.cpp Rename Quota::ResourceType -> QuotaType and move it to Access/Common. 2021-11-19 00:14:23 +03:00
StorageReplicatedMergeTree.h Merge pull request #30658 from ClickHouse/std_mutex_alter_lock 2021-10-27 11:14:11 +03:00
StorageS3.cpp Minor change 2021-11-11 21:09:21 +03:00
StorageS3.h For storage 2021-10-27 10:04:17 +03:00
StorageS3Cluster.cpp Remove cruft 2021-10-28 02:10:39 +03:00
StorageS3Cluster.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageS3Settings.cpp
StorageS3Settings.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageSet.cpp Merge branch 'master' into removing-data-streams-folder 2021-10-16 09:46:05 +03:00
StorageSet.h Merge branch 'master' into join_deadlock 2021-10-11 10:18:17 +03:00
StorageSQLite.cpp Remove DataStreams folder. 2021-10-15 23:18:20 +03:00
StorageSQLite.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageStripeLog.cpp Split backup implementation into two parts to help implementing other backup engines. 2021-11-10 11:03:03 +03:00
StorageStripeLog.h Support BACKUP & RESTORE for log family. 2021-11-01 12:07:17 +03:00
StorageTableFunction.h Move some files. 2021-10-16 17:03:50 +03:00
StorageURL.cpp Merge pull request #31004 from Avogar/output-formats 2021-11-17 20:44:46 +03:00
StorageURL.h Small refactoring in formats 2021-11-03 20:07:05 +03:00
StorageValues.cpp Move some files. 2021-10-16 17:03:50 +03:00
StorageValues.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageView.cpp Move some files. 2021-10-16 17:03:50 +03:00
StorageView.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
StorageXDBC.cpp Fix tests 2021-11-02 07:27:13 +00:00
StorageXDBC.h Fix tests 2021-11-02 07:27:13 +00:00
TableLockHolder.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
transformQueryForExternalDatabase.cpp Add support for IS NULL/IS NOT NULL for external dbs 2021-09-29 21:45:09 +03:00
transformQueryForExternalDatabase.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
TTLDescription.cpp
TTLDescription.h
TTLMode.h
VirtualColumnUtils.cpp
VirtualColumnUtils.h