ClickHouse/src/Storages
vdimir 2686a189de
Apply suggestion for code review, changes in StorageSystemTables getFilteredTables
Co-authored-by: Azat Khuzhin <a3at.mail@gmail.com>
2021-12-30 15:36:38 +03:00
..
Distributed Reduce dependencies on ASTFunction.h 2021-11-26 18:21:54 +01:00
examples
FileLog Fix incorrect include 2021-12-24 12:25:26 +03:00
fuzzers
HDFS Fix style 2021-12-29 12:21:01 +03:00
Kafka Cleanup trash from Kafka and HDFS 2021-12-25 06:10:59 +03:00
LiveView StorageLiveView fix function style 2021-12-16 12:29:20 +03:00
MergeTree Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
MySQL Update defaults 2021-12-15 08:18:43 +00:00
PostgreSQL Merge branch 'master' into materialized-postgresql-fix-cleanup 2021-12-27 17:25:51 +03:00
RabbitMQ Fix 2021-12-12 00:19:06 +03:00
RocksDB Updated additional cases 2021-12-20 15:55:07 +03:00
System Apply suggestion for code review, changes in StorageSystemTables getFilteredTables 2021-12-30 15:36:38 +03:00
tests Fix unit tests 2021-12-27 15:31:49 +03:00
WindowView small update 2021-12-13 02:38:16 +00:00
AlterCommands.cpp Reduce dependencies on ASTFunction.h 2021-11-26 18:21:54 +01:00
AlterCommands.h
CheckResults.h
CMakeLists.txt
ColumnCodec.h
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h
ColumnsDescription.cpp
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
ExecutableSettings.h Updated executable function integration tests 2021-12-28 22:55:30 +03:00
ExternalDataSourceConfiguration.cpp Pass timeouts for mysql 2021-12-13 22:12:33 +00:00
ExternalDataSourceConfiguration.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
extractKeyExpressionList.cpp
extractKeyExpressionList.h Better naming 2020-05-28 16:09:03 +03:00
getStructureOfRemoteTable.cpp
getStructureOfRemoteTable.h
IndicesDescription.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
IndicesDescription.h
IStorage_fwd.h
IStorage.cpp Dictionaries fix comment 2021-12-28 23:50:48 +03:00
IStorage.h flush all InMemoryDataParts when wal is not enabled 2021-12-14 16:31:17 +08:00
KeyDescription.cpp
KeyDescription.h
MarkCache.h
MemorySettings.cpp
MemorySettings.h
MutationCommands.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
MutationCommands.h
PartitionCommands.cpp Reduce dependencies on ASTIdentifier.h 2021-11-26 16:49:40 +01:00
PartitionCommands.h
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 Another try 2021-12-17 20:36:37 +03: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
ReadInOrderOptimizer.h
registerStorages.cpp Merge branch 'master' of github.com:ClickHouse/ClickHouse into vxider-window-view 2021-11-18 17:29:11 +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 Better Projection IN 2021-10-29 20:24:36 +08:00
SetSettings.cpp
SetSettings.h
StorageBuffer.cpp Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageBuffer.h change alter_lock to std::timed_mutex 2021-10-26 13:37:00 +03:00
StorageDictionary.cpp Fixed tests 2021-12-28 23:50:48 +03:00
StorageDictionary.h Dictionaries fix comment 2021-12-28 23:50:48 +03:00
StorageDistributed.cpp Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageDistributed.h Reduce dependencies on ASTFunction.h 2021-11-26 18:21:54 +01:00
StorageExecutable.cpp Updated ShellCommandSource 2021-12-28 22:55:31 +03:00
StorageExecutable.h Updated ShellCommandSource 2021-12-28 22:55:31 +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 Governance/view_comment 2021-12-02 08:19:03 +00:00
StorageFactory.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageFile.cpp Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageFile.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageGenerateRandom.cpp support Date32 for genarateRandom engine 2021-12-13 15:52:12 +08:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp fix MATERIALIZE TTL with WHERE and GROUP BY 2021-12-13 17:21:05 +03:00
StorageInMemoryMetadata.h
StorageInput.cpp
StorageInput.h
StorageJoin.cpp fix storage join settings with persistency (#32066) 2021-12-03 12:06:58 +03:00
StorageJoin.h fix storage join settings with persistency (#32066) 2021-12-03 12:06:58 +03:00
StorageLog.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
StorageLog.h Support BACKUP & RESTORE for log family. 2021-11-01 12:07:17 +03:00
StorageLogSettings.cpp
StorageLogSettings.h
StorageMaterializedMySQL.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
StorageMaterializedMySQL.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageMaterializedView.cpp Merge branch 'master' into Governance/view_comment 2021-12-02 08:19:03 +00:00
StorageMaterializedView.h Merge branch 'master' into Governance/view_comment 2021-12-02 08:19:03 +00:00
StorageMemory.cpp
StorageMemory.h
StorageMerge.cpp Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageMerge.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageMergeTree.cpp fix skipping of some mutations 2021-12-15 21:19:29 +03:00
StorageMergeTree.h flush all InMemoryDataParts when wal is not enabled 2021-12-14 16:31:17 +08:00
StorageMongoDB.cpp Done 2021-12-13 16:09:18 +00:00
StorageMongoDB.h Reduce dependencies on ASTSelectWithUnionQuery.h 2021-11-26 19:27:16 +01:00
StorageMongoDBSocketFactory.cpp Remove cruft 2021-10-28 02:10:39 +03:00
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Pass timeouts for mysql 2021-12-13 22:12:33 +00: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 Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageReplicatedMergeTree.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageS3.cpp Add more tests and fixes 2021-12-29 12:18:56 +03:00
StorageS3.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageS3Cluster.cpp Parallel reading from replicas (#29279) 2021-12-09 13:39:28 +03:00
StorageS3Cluster.h Remove cruft 2021-10-28 02:10:39 +03:00
StorageS3Settings.cpp
StorageS3Settings.h
StorageSet.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
StorageSet.h
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
StorageURL.cpp Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageURL.h Implement schema inference for most input formats 2021-12-29 12:18:56 +03:00
StorageValues.cpp
StorageValues.h
StorageView.cpp Reduce dependencies on ASTFunction.h 2021-11-26 18:21:54 +01:00
StorageView.h
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 Fix 2021-12-27 11:59:33 +03:00
transformQueryForExternalDatabase.h
TTLDescription.cpp Reduce dependencies on ASTLiteral.h 2021-11-26 17:54:57 +01:00
TTLDescription.h
TTLMode.h
VirtualColumnUtils.cpp
VirtualColumnUtils.h