ClickHouse/src/Storages
2023-12-04 19:02:37 +01:00
..
Cache used assert_cast instead of dynamic_cast 2023-09-05 22:57:40 +00:00
DataLakes Support Iceberg metadata files for metastore tables 2023-11-15 17:45:07 +00:00
Distributed Merge remote-tracking branch 'origin/master' into pr-cleanup-narrow-dependency 2023-11-21 16:05:48 +00:00
examples
FileLog Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
fuzzers fix fuzzers, cmake refactor, add target fuzzers 2023-09-01 14:20:50 +00:00
HDFS Add information about new _size virtual column in file/s3/url/hdfs/azure table functions 2023-11-28 18:15:07 +00:00
Hive Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
Kafka Fix build 2023-11-13 10:09:23 +01:00
LiveView Better shutdown 2023-11-06 15:47:57 +01:00
MergeTree Merge pull request #57275 from ClickHouse/vdimir/merge_task_tmp_data 2023-12-04 14:52:20 +01:00
MySQL Intorduce *List definition for muli enum settings 2023-11-28 19:09:02 +00:00
NATS Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
PostgreSQL Remove a tab 2023-11-20 00:46:14 +01:00
RabbitMQ Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
RocksDB Merge pull request #56816 from AVMusorin/improve-settings-rocksdb 2023-11-27 11:42:15 +01:00
S3Queue Merge branch 'master' into size-virtual-column 2023-11-22 19:25:00 +01:00
Statistics rename some code 2023-11-28 16:32:47 +01:00
System Minor cache changes 2023-12-04 19:02:37 +01:00
tests Fix 2023-11-09 06:23:23 +00:00
WindowView Better shutdown 2023-11-06 15:47:57 +01:00
AlterCommands.cpp Merge branch 'master' into fix-56932 2023-12-02 21:19:45 +01:00
AlterCommands.h Merge branch 'master' into hanfei/statistic 2023-10-30 04:53:18 +01:00
BlockNumberColumn.cpp Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
BlockNumberColumn.h Added a new column _block_number (#47532) 2023-09-20 11:31:12 +02:00
buildQueryTreeForShard.cpp
buildQueryTreeForShard.h
checkAndGetLiteralArgument.cpp
checkAndGetLiteralArgument.h
CheckResults.h Improve CHECK TABLE system query 2023-10-23 09:35:26 +00:00
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
ColumnDependency.h
ColumnsDescription.cpp remove wrong code 2023-11-28 16:46:55 +01:00
ColumnsDescription.h Merge branch 'master' into hanfei/statistic 2023-11-27 23:31:23 +01:00
CompressionCodecSelector.h
ConstraintsDescription.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
ConstraintsDescription.h
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h
ExternalDataSourceConfiguration.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +00:00
ExternalDataSourceConfiguration.h Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02:00
extractKeyExpressionList.cpp
extractKeyExpressionList.h Better naming 2020-05-28 16:09:03 +03:00
extractTableFunctionArgumentsFromSelectQuery.cpp
extractTableFunctionArgumentsFromSelectQuery.h
Freeze.cpp Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02:00
Freeze.h
getStructureOfRemoteTable.cpp Handle clusterAllReplicas/remote cases to avoid unnecessary logging 2023-09-12 12:52:29 +00:00
getStructureOfRemoteTable.h
IMessageProducer.cpp
IMessageProducer.h
IndicesDescription.cpp review fix 2023-11-27 03:50:34 +00:00
IndicesDescription.h Refactor IHints 2023-09-10 03:48:12 +00:00
IStorage_fwd.h
IStorage.cpp rename some code 2023-11-28 16:32:47 +01:00
IStorage.h Merge branch 'master' into hanfei/statistic 2023-11-27 23:31:23 +01:00
IStorageCluster.cpp Cleanup iteration: settings usage 2023-11-21 13:29:04 +00:00
IStorageCluster.h
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp Remove default value for argument 'ignore_aliases' from IAST::getTreeHash() 2023-11-13 10:27:38 +00:00
KVStorageUtils.h Fix rocksdb with analyzer. 2023-11-06 18:46:39 +00:00
LightweightDeleteDescription.cpp Capitalized const name 2022-07-25 16:32:16 +02:00
LightweightDeleteDescription.h
MarkCache.h
MemorySettings.cpp
MemorySettings.h
MessageQueueSink.cpp
MessageQueueSink.h
MutationCommands.cpp make code beautiful 2023-09-27 11:01:53 +02:00
MutationCommands.h update docs and refine statements 2023-09-08 02:27:17 +02:00
NamedCollectionsHelpers.cpp Update src/Storages/NamedCollectionsHelpers.cpp 2023-11-21 11:14:48 +01:00
NamedCollectionsHelpers.h
PartitionCommands.cpp
PartitionCommands.h Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02: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 Refactor IHints 2023-09-10 03:48:12 +00:00
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h
ReadInOrderOptimizer.cpp
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 review fix 2023-11-27 03:50:34 +00:00
ReplaceAliasByExpressionVisitor.h review fix 2023-11-27 03:50:34 +00:00
SelectQueryDescription.cpp
SelectQueryDescription.h
SelectQueryInfo.cpp
SelectQueryInfo.h Merge remote-tracking branch 'blessed/master' into parallel_replicas_row_estimation 2023-08-29 11:17:34 +02:00
SetSettings.cpp
SetSettings.h Move obsolete format settings to separate section 2023-09-20 16:00:28 +00:00
StatisticsDescription.cpp refine exception messages 2023-09-27 17:59:53 +02:00
StatisticsDescription.h address comments 2023-10-30 00:39:16 +01:00
StorageAzureBlob.cpp Add information about new _size virtual column in file/s3/url/hdfs/azure table functions 2023-11-28 18:15:07 +00:00
StorageAzureBlob.h Add information about new _size virtual column in file/s3/url/hdfs/azure table functions 2023-11-28 18:15:07 +00:00
StorageAzureBlobCluster.cpp Add _size virtual column to s3/file/hdfs/url/azureBlobStorage engines 2023-11-22 18:12:36 +00:00
StorageAzureBlobCluster.h
StorageBuffer.cpp Re-fix 'Block structure mismatch' on concurrent ALTER and INSERTs in Buffer table (#56140) 2023-10-31 13:41:54 -07:00
StorageBuffer.h Re-fix 'Block structure mismatch' on concurrent ALTER and INSERTs in Buffer table (#56140) 2023-10-31 13:41:54 -07:00
StorageConfiguration.h
StorageDictionary.cpp Better shutdown 2023-11-06 15:47:57 +01:00
StorageDictionary.h Better shutdown 2023-11-06 15:47:57 +01:00
StorageDistributed.cpp Merge remote-tracking branch 'origin/master' into pr-cleanup-narrow-dependency 2023-11-21 16:05:48 +00:00
StorageDistributed.h Merge pull request #56367 from canhld94/ch_table_reinit_new_disk 2023-11-14 15:54:22 +01:00
StorageDummy.cpp
StorageDummy.h Revert "Revert "Planner prepare filters for analysis"" 2023-08-24 12:32:56 +02:00
StorageExecutable.cpp Add index to table system.numbers (#50909) 2023-12-01 19:59:25 +01:00
StorageExecutable.h
StorageExternalDistributed.cpp
StorageExternalDistributed.h
StorageFactory.cpp
StorageFactory.h Refactor IHints 2023-09-10 03:48:12 +00:00
StorageFile.cpp Merge pull request #57391 from evillique/better-partitioned-write-to-file 2023-12-01 17:23:54 +01:00
StorageFile.h resolve conflicts 2023-11-29 16:03:07 +01:00
StorageFileCluster.cpp merge master + resolve conflicts 2023-11-28 15:51:21 +01:00
StorageFileCluster.h merge master + resolve conflicts 2023-11-28 15:51:21 +01:00
StorageFuzzJSON.cpp Merge pull request #57372 from jkartseva/fuzz-json-verbose-exception 2023-11-30 08:20:54 +01:00
StorageFuzzJSON.h Follow-up to #56490: Fix build with -DENABLE_LIBRARIES=0 2023-11-28 19:59:43 +00:00
StorageGenerateRandom.cpp Fix UInt256 and IPv4 random data generation on s390x 2023-09-13 04:55:02 -07:00
StorageGenerateRandom.h
StorageInMemoryMetadata.cpp refine code 2023-09-26 19:16:01 +02:00
StorageInMemoryMetadata.h refine code 2023-09-26 19:16:01 +02:00
StorageInput.cpp Fixing style. 2023-11-14 14:55:21 +00:00
StorageInput.h Fixing style. 2023-11-15 13:56:51 +00:00
StorageJoin.cpp
StorageJoin.h StorageJoin: supports trivial count() 2023-10-19 06:30:25 +00:00
StorageKeeperMap.cpp Cleanup 2023-11-17 10:27:19 +00:00
StorageKeeperMap.h Small fixes and add test 2023-11-09 15:56:57 +00:00
StorageLog.cpp wip CHECK query for all tables 2023-10-27 15:22:10 +00:00
StorageLog.h wip CHECK query for all tables 2023-10-27 15:22:10 +00:00
StorageLogSettings.cpp
StorageLogSettings.h Storage Log faminy support settings storage policy 2023-02-04 14:28:31 +00:00
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h
StorageMaterializedView.cpp Followup 2023-11-28 14:01:31 +01:00
StorageMaterializedView.h Better shutdown 2023-11-06 15:47:57 +01:00
StorageMemory.cpp fix alter table tests 2023-11-30 21:42:13 +03:00
StorageMemory.h allow ALTER for TEMPORARY table 2023-11-30 21:42:12 +03:00
StorageMerge.cpp merge_row_policy: cleanup after merge 2023-11-18 21:45:17 +00:00
StorageMerge.h merge_row_policy: make clang-tidy happy 2023-11-21 22:06:18 +00:00
StorageMergeTree.cpp Merge pull request #56502 from amosbird/fix-56481 2023-11-11 02:29:04 +01:00
StorageMergeTree.h Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
StorageMongoDB.cpp
StorageMongoDB.h
StorageMongoDBSocketFactory.cpp
StorageMongoDBSocketFactory.h
StorageMySQL.cpp
StorageMySQL.h update comment 2023-09-19 08:18:37 +00:00
StorageNull.cpp Minor code cleanup: remove some redundant includes of InterpreterAlterQuery.h 2023-08-23 14:16:36 +00:00
StorageNull.h fix: StorageNull supports subcolumns 2023-10-22 16:24:01 +08:00
StoragePostgreSQL.cpp
StoragePostgreSQL.h
StorageProxy.h Merge remote-tracking branch 'origin/master' into minor-improvements-for-s3-queue 2023-11-06 15:51:11 +01:00
StorageRedis.cpp
StorageRedis.h
StorageReplicatedMergeTree.cpp Merge pull request #57385 from vitlibar/fix-inconsistent-metadata-for-backup-2 2023-12-04 10:29:57 +01:00
StorageReplicatedMergeTree.h Better Readonly metric 2023-11-27 14:25:45 +00:00
StorageS3.cpp Merge pull request #56813 from jsc0218/SystemTablesFilterEngine 2023-12-01 16:02:27 +01:00
StorageS3.h Add information about new _size virtual column in file/s3/url/hdfs/azure table functions 2023-11-28 18:15:07 +00:00
StorageS3Cluster.cpp Add _size virtual column to s3/file/hdfs/url/azureBlobStorage engines 2023-11-22 18:12:36 +00:00
StorageS3Cluster.h
StorageS3Settings.cpp
StorageS3Settings.h Minor cache changes 2023-12-04 19:02:37 +01:00
StorageSet.cpp Fix totalBytes() 2023-10-15 10:40:37 +02:00
StorageSet.h Merging #52352 2023-10-14 02:52:53 +02:00
StorageSnapshot.cpp Merge branch 'master' into revert-53782-revert-52762-planner-prepare-filters-for-analysis 2023-10-09 14:44:00 +02:00
StorageSnapshot.h Revert "Revert "Planner prepare filters for analysis"" 2023-08-24 12:32:56 +02:00
StorageSQLite.cpp
StorageSQLite.h
StorageStripeLog.cpp Split source and worker processors in InterpreterCheckQuery 2023-10-27 15:22:10 +00:00
StorageStripeLog.h wip CHECK query for all tables 2023-10-27 15:22:10 +00:00
StorageTableFunction.h Better shutdown 2023-11-06 15:47:57 +01:00
StorageURL.cpp Add information about new _size virtual column in file/s3/url/hdfs/azure table functions 2023-11-28 18:15:07 +00:00
StorageURL.h Add information about new _size virtual column in file/s3/url/hdfs/azure table functions 2023-11-28 18:15:07 +00:00
StorageURLCluster.cpp Add _size virtual column to s3/file/hdfs/url/azureBlobStorage engines 2023-11-22 18:12:36 +00:00
StorageURLCluster.h
StorageValues.cpp
StorageValues.h
StorageView.cpp Revert "Support SAMPLE BY for VIEW" 2023-10-09 00:08:46 +03:00
StorageView.h
StorageXDBC.cpp Fix parsing error in WithNames formats while reading subset of columns with disabled input_format_with_names_use_header 2023-09-11 14:55:37 +00:00
StorageXDBC.h Fix parsing error in WithNames formats while reading subset of columns with disabled input_format_with_names_use_header 2023-09-11 14:55:37 +00:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp Update src/Storages/transformQueryForExternalDatabase.cpp 2023-11-08 23:20:12 +08:00
transformQueryForExternalDatabase.h
transformQueryForExternalDatabaseAnalyzer.cpp Fixing 01086_odbc_roundtrip with analyzer. 2023-08-31 15:23:27 +00:00
transformQueryForExternalDatabaseAnalyzer.h
TTLDescription.cpp
TTLDescription.h
TTLMode.h
UVLoop.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
VirtualColumnUtils.cpp Cleanup 2023-11-28 18:35:19 +00:00
VirtualColumnUtils.h Re-implement filtering a bit. 2023-11-28 16:17:35 +00:00