ClickHouse/src/Storages
2024-03-04 18:29:05 +00:00
..
Cache Fixing more headers 2024-02-29 15:40:30 +00:00
DataLakes skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
Distributed Merge remote-tracking branch 'ClickHouse/master' into dist/config-settings 2024-02-26 11:15:51 +00:00
examples fix 2024-02-16 14:05:22 +01:00
FileLog skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
fuzzers
HDFS Fix more tests 2024-02-26 02:31:59 +08:00
Hive Fix more tests 2024-02-26 02:31:59 +08:00
Kafka Support sql created named collections in Kafka Storage for librdkafka settings 2024-02-27 18:36:36 +00:00
LiveView Live view's life is close to the end 2024-03-04 00:49:22 +01:00
MaterializedView Updated implementation 2024-01-25 14:31:49 +03:00
MergeTree Merge remote-tracking branch 'origin/master' into use-minmax-indices-always-first 2024-03-04 18:29:05 +00:00
MySQL Intorduce *List definition for muli enum settings 2023-11-28 19:09:02 +00:00
NATS skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
PostgreSQL skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
RabbitMQ Merge pull request #60159 from ClickHouse/fix_create_replica 2024-02-23 13:53:47 +01:00
RocksDB Fix more tests 2024-02-26 02:31:59 +08:00
S3Queue Fix more tests 2024-02-26 02:31:59 +08:00
Statistics rename some code 2023-11-28 16:32:47 +01:00
System Merge pull request #60420 from HowePa/format_case_insensitive 2024-03-04 19:09:10 +01:00
tests Update gtest_storage_log.cpp 2024-02-21 20:16:14 +01:00
WindowView Update to clang-19 2024-02-27 14:37:21 +01:00
AlterCommands.cpp Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
AlterCommands.h Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
BlockNumberColumn.cpp
BlockNumberColumn.h
buildQueryTreeForShard.cpp Support non global in mode. 2024-02-05 17:05:21 +00:00
buildQueryTreeForShard.h Support non global in mode. 2024-02-05 17:05:21 +00:00
checkAndGetLiteralArgument.cpp
checkAndGetLiteralArgument.h
CheckResults.h
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h
ColumnsDescription.cpp Merge remote-tracking branch 'ClickHouse/master' into column_level_compress_block 2024-01-18 19:12:57 +00:00
ColumnsDescription.h Fixing more headers 2024-02-29 15:40:30 +00:00
CompressionCodecSelector.h
ConstraintsDescription.cpp
ConstraintsDescription.h
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h StorageExecutable check_exit_code default to false 2023-08-18 15:38:47 +08:00
ExternalDataSourceConfiguration.cpp
ExternalDataSourceConfiguration.h
extractKeyExpressionList.cpp
extractKeyExpressionList.h
extractTableFunctionArgumentsFromSelectQuery.cpp
extractTableFunctionArgumentsFromSelectQuery.h
Freeze.cpp Updated implementation 2024-01-25 14:31:49 +03:00
Freeze.h Fixing more headers 2024-02-29 15:40:30 +00:00
getStructureOfRemoteTable.cpp
getStructureOfRemoteTable.h
IMessageProducer.cpp Fix lazy initialization in RabbitMQ, fix possible deadlock on insert into unitialized queue engine 2024-01-29 20:09:09 +00:00
IMessageProducer.h Updated implementation 2024-01-25 14:31:49 +03:00
IndicesDescription.cpp Revert "Revert "Support use alias column in indices"" 2023-12-05 18:22:32 +00:00
IndicesDescription.h Always apply first minmax index among available skip indices 2024-03-01 19:31:15 +00:00
IStorage_fwd.h
IStorage.cpp Merge branch 'master' into remove-old-projections-code 2023-12-20 17:45:38 +01:00
IStorage.h Check if I can remove KeyCondition analysis on AST. 2024-01-03 17:50:46 +00:00
IStorageCluster.cpp Fix: *Cluster table functions progress bar 2024-02-28 16:28:28 +00:00
IStorageCluster.h Merge branch 'master' into auto-format-detection 2024-01-25 22:11:07 +01:00
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp Fix more tests 2024-02-26 02:31:59 +08:00
KVStorageUtils.h Fix more tests 2024-02-26 02:31:59 +08:00
LightweightDeleteDescription.cpp
LightweightDeleteDescription.h
MarkCache.h
MemorySettings.cpp
MemorySettings.h
MessageQueueSink.cpp Updated implementation 2024-01-25 14:31:49 +03:00
MessageQueueSink.h
MutationCommands.cpp Support query parameters in ALTER TABLE ... PART 2024-01-15 14:16:54 +03:00
MutationCommands.h add mutation command to apply deleted mask 2023-12-01 19:12:05 +00:00
NamedCollectionsHelpers.cpp Revert "Revert "Add table function mergeTreeIndex"" 2024-02-26 22:47:39 +00:00
NamedCollectionsHelpers.h Fixing more headers 2024-02-29 15:40:30 +00:00
PartitionCommands.cpp add FORGET PARTITION query to remove old parition nodes from ZooKeeper 2024-02-02 10:03:31 +00:00
PartitionCommands.h add FORGET PARTITION query to remove old parition nodes from ZooKeeper 2024-02-02 10:03:31 +00:00
PartitionedSink.cpp Minor changes 2023-11-22 12:13:47 +01:00
PartitionedSink.h
prepareReadingFromFormat.cpp
prepareReadingFromFormat.h
ProjectionsDescription.cpp Disable transform_null_in as well just in case. 2023-11-29 17:30:22 +00:00
ProjectionsDescription.h
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h
ReadInOrderOptimizer.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ReadInOrderOptimizer.h
RedisCommon.cpp
RedisCommon.h
registerStorages.cpp Follow-up to #56490: Fix build with -DENABLE_LIBRARIES=0 2023-11-28 19:59:43 +00:00
registerStorages.h
removeGroupingFunctionSpecializations.cpp
removeGroupingFunctionSpecializations.h
RenamingRestrictions.h
ReplaceAliasByExpressionVisitor.cpp Revert "Revert "Support use alias column in indices"" 2023-12-05 18:22:32 +00:00
ReplaceAliasByExpressionVisitor.h Revert "Revert "Support use alias column in indices"" 2023-12-05 18:22:32 +00:00
SelectQueryDescription.cpp Things 2023-12-28 17:56:05 +00:00
SelectQueryDescription.h Things 2023-12-28 17:56:05 +00:00
SelectQueryInfo.cpp
SelectQueryInfo.h Fix most tests 2024-02-26 02:31:58 +08:00
SetSettings.cpp
SetSettings.h
StatisticsDescription.cpp
StatisticsDescription.h
StorageAzureBlob.cpp Merge pull request #60420 from HowePa/format_case_insensitive 2024-03-04 19:09:10 +01:00
StorageAzureBlob.h Fixing more headers 2024-02-29 15:40:30 +00:00
StorageAzureBlobCluster.cpp Merge branch 'master' into auto-format-detection 2024-01-25 22:11:07 +01:00
StorageAzureBlobCluster.h Try to detect file format automatically during schema inference if it's unknown 2024-01-23 18:59:39 +00:00
StorageBuffer.cpp Fix build in master 2024-02-19 17:48:53 +01:00
StorageBuffer.h Better if only 1 layer 2024-02-18 13:19:35 +01:00
StorageConfiguration.h
StorageDictionary.cpp skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageDictionary.h
StorageDistributed.cpp Revert "Analyzer: compute ALIAS columns right after reading" 2024-02-29 14:22:07 +01:00
StorageDistributed.h skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageDummy.cpp Fix more tests 2024-02-26 02:31:57 +08:00
StorageDummy.h Fix something 2024-02-26 02:32:00 +08:00
StorageExecutable.cpp Updated implementation 2024-01-25 14:31:49 +03:00
StorageExecutable.h Updated implementation 2024-01-25 14:31:49 +03:00
StorageExternalDistributed.cpp
StorageExternalDistributed.h
StorageFactory.cpp skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageFactory.h skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageFile.cpp Fix more tests 2024-02-26 02:31:59 +08:00
StorageFile.h Fix more tests 2024-02-26 02:31:59 +08:00
StorageFileCluster.cpp Merge branch 'master' into auto-format-detection 2024-01-25 22:11:07 +01:00
StorageFileCluster.h Try to detect file format automatically during schema inference if it's unknown 2024-01-23 18:59:39 +00:00
StorageFuzzJSON.cpp Update src/Storages/StorageFuzzJSON.cpp 2023-12-19 10:17:15 -08:00
StorageFuzzJSON.h Add malformed output generation to JSON fuzzer (#57646) 2023-12-13 19:59:31 +01:00
StorageGenerateRandom.cpp Fix tests 2023-12-12 14:13:15 +00:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
StorageInMemoryMetadata.h Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
StorageInput.cpp
StorageInput.h
StorageJoin.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
StorageJoin.h
StorageKeeperMap.cpp Fix using table_id in StorageKeeperMap. 2024-02-23 20:27:19 +01:00
StorageKeeperMap.h Fix using table_id in StorageKeeperMap. 2024-02-23 20:27:19 +01:00
StorageLog.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
StorageLog.h skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageLogSettings.cpp
StorageLogSettings.h Add missing includes 2024-01-13 01:48:55 +03:00
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h
StorageMaterializedView.cpp Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
StorageMaterializedView.h skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageMemory.cpp Unify prewhere optimization 2024-02-26 02:31:56 +08:00
StorageMemory.h allow ALTER for TEMPORARY table 2023-11-30 21:42:12 +03:00
StorageMerge.cpp Better name 2024-02-26 02:32:00 +08:00
StorageMerge.h Fix more tests 2024-02-26 02:31:59 +08:00
StorageMergeTree.cpp Revert "Merge pull request #56864 from ClickHouse/broken-projections-better-handling" 2024-02-27 00:13:28 +01:00
StorageMergeTree.h Merge pull request #60159 from ClickHouse/fix_create_replica 2024-02-23 13:53:47 +01:00
StorageMergeTreeIndex.cpp Revert "Revert "Add table function mergeTreeIndex"" 2024-02-26 22:47:39 +00:00
StorageMergeTreeIndex.h Revert "Revert "Add table function mergeTreeIndex"" 2024-02-26 22:47:39 +00:00
StorageMongoDB.cpp
StorageMongoDB.h
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Updated implementation 2024-01-25 14:31:49 +03:00
StorageMySQL.h Updated implementation 2024-01-25 14:31:49 +03:00
StorageNull.cpp
StorageNull.h
StoragePostgreSQL.cpp Updated implementation 2024-01-25 14:31:49 +03:00
StoragePostgreSQL.h Updated implementation 2024-01-25 14:31:49 +03:00
StorageProxy.h Merge remote-tracking branch 'upstream/master' into HEAD 2024-01-03 16:01:44 +00:00
StorageRedis.cpp Updated implementation 2024-01-25 14:31:49 +03:00
StorageRedis.h Updated implementation 2024-01-25 14:31:49 +03:00
StorageReplicatedMergeTree.cpp Merge branch 'master' of github.com:ClickHouse/ClickHouse into revert-60216-revert-59697-check-stack-size-in-parser 2024-02-27 17:30:32 +01:00
StorageReplicatedMergeTree.h Merge pull request #57798 from kirillgarbar/modify-engine 2024-02-28 21:55:15 +01:00
StorageS3.cpp Merge pull request #60420 from HowePa/format_case_insensitive 2024-03-04 19:09:10 +01:00
StorageS3.h Fix more tests 2024-02-26 02:31:59 +08:00
StorageS3Cluster.cpp Simple cleanup while fixing progress bar 2024-02-28 20:40:17 +00:00
StorageS3Cluster.h Simple cleanup while fixing progress bar 2024-02-28 20:40:17 +00:00
StorageS3Settings.cpp Replace boost::algorithm::starts_with() by std::string::starts_with() 2024-02-27 10:42:47 +00:00
StorageS3Settings.h Support specifying users for s3 settings 2024-02-19 16:43:27 +01:00
StorageSet.cpp Updated implementation 2024-01-25 14:31:49 +03:00
StorageSet.h
StorageSnapshot.cpp fix build and tests 2024-01-03 16:59:13 +00:00
StorageSnapshot.h Revert "remove projection from StorageSnapshot" 2024-01-03 16:00:50 +00:00
StorageSQLite.cpp skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageSQLite.h Fix INSERT into SQLite with single quote 2024-02-15 12:47:29 +01:00
StorageStripeLog.cpp skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageStripeLog.h skip sanity checks on secondary create query 2024-02-20 21:59:28 +01:00
StorageTableFunction.h
StorageURL.cpp Fix more tests 2024-02-26 02:31:59 +08:00
StorageURL.h Fix more tests 2024-02-26 02:31:59 +08:00
StorageURLCluster.cpp Fix build 2024-01-26 15:50:16 +01:00
StorageURLCluster.h Try to detect file format automatically during schema inference if it's unknown 2024-01-23 18:59:39 +00:00
StorageValues.cpp
StorageValues.h Disable parallelize_output_from_storages for storages with only one block 2023-06-14 19:11:23 +03:00
StorageView.cpp Merge pull request #60434 from ClickHouse/revert-60216-revert-59697-check-stack-size-in-parser 2024-02-28 19:20:49 +03:00
StorageView.h Add definers for views (Attempt 2) (#60439) 2024-02-27 19:00:17 -05:00
StorageXDBC.cpp Merge branch 'master' into auto-format-detection 2024-01-25 22:11:07 +01:00
StorageXDBC.h Merge branch 'master' into auto-format-detection 2024-01-25 22:11:07 +01:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
transformQueryForExternalDatabase.h
transformQueryForExternalDatabaseAnalyzer.cpp
transformQueryForExternalDatabaseAnalyzer.h
TTLDescription.cpp Merge branch 'master' into non-ready-set-ttl 2024-01-13 21:11:51 +01:00
TTLDescription.h Merge branch 'master' into non-ready-set-ttl 2024-01-13 21:11:51 +01:00
TTLMode.h
UVLoop.h Updated implementation 2024-01-25 14:31:49 +03:00
VirtualColumnUtils.cpp Fix actions execution during preliminary filtering (PK, partition pruning) 2024-02-22 15:01:57 +01:00
VirtualColumnUtils.h Fixing index hint 2024-01-05 11:50:09 +00:00