ClickHouse/src/Storages
robot-clickhouse-ci-1 c66ff09627
Merge pull request #51253 from kssenii/delete-non-evictable-feature
Delete feature do_not_evict_index_and_mark_files in fs cache
2023-06-24 02:37:52 +02:00
..
Cache Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
DataLakes Better 2023-06-14 11:37:57 +02:00
Distributed More fixes 2023-06-09 20:50:17 +00:00
examples Fix build 2023-05-03 00:09:52 +02:00
FileLog Highly questionable refactoring (getInputMultistream() nonsense) 2023-04-17 04:58:32 +00:00
fuzzers
HDFS fix other classes based on SinkToStorage 2023-06-22 14:33:25 +02:00
Hive Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
Kafka Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
LiveView Remove ALTER of LIVE VIEW 2023-06-22 20:32:29 +02:00
MeiliSearch Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
MergeTree Merge pull request #51297 from ClickHouse/fix-metadata-loading 2023-06-23 21:45:21 +03:00
MySQL Fox 2023-04-13 19:36:25 +02:00
NATS Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
PostgreSQL replace NO DELAY with SYNC in tests 2023-05-03 20:08:49 +02:00
RabbitMQ Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
RocksDB Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
System Merge remote-tracking branch 'upstream/master' into delete-non-evictable-feature 2023-06-21 20:52:08 +02:00
tests Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
WindowView Merge branch 'master' into zvonand-implicit-tz 2023-06-08 18:34:45 +03:00
AlterCommands.cpp enable_qpl_deflate_codec --> enable_deflate_qpl_codec 2023-06-09 12:43:33 +00:00
AlterCommands.h remove useless code 2023-01-25 16:11:15 +00:00
buildQueryTreeForShard.cpp Fix style 2023-06-12 17:33:15 +00:00
buildQueryTreeForShard.h Use query tree to rewrite the query 2023-06-12 16:51:40 +00:00
checkAndGetLiteralArgument.cpp s390x build support 2023-01-20 21:16:55 +00:00
checkAndGetLiteralArgument.h
CheckResults.h
CMakeLists.txt
ColumnDefault.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ColumnDefault.h dedicated flag for ephemeral default, make ephemeral accept expression instead of literal 2022-12-11 00:40:35 +00:00
ColumnDependency.h
ColumnsDescription.cpp Add extensive testing cases for deflate qpl codec 2023-06-09 12:42:59 +00:00
ColumnsDescription.h Allow using Alias column type for KafkaEngine 2023-05-15 15:39:58 +02:00
CompressionCodecSelector.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ConstraintsDescription.cpp Add support for substitute column 2023-03-17 13:38:01 +00:00
ConstraintsDescription.h Add support for substitute column 2023-03-17 13:38:01 +00:00
DataDestinationType.h Part movement between shards 2021-04-27 14:20:12 +01:00
ExecutableSettings.cpp
ExecutableSettings.h Better alias definition 2023-02-01 13:54:03 +00:00
ExternalDataSourceConfiguration.cpp Remove redundant 2023-02-27 12:32:13 +01:00
ExternalDataSourceConfiguration.h Finish for streaming engines 2023-02-21 14:50:55 +01:00
extractKeyExpressionList.cpp
extractKeyExpressionList.h
extractTableFunctionArgumentsFromSelectQuery.cpp Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
extractTableFunctionArgumentsFromSelectQuery.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
Freeze.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
Freeze.h
getStructureOfRemoteTable.cpp Fix nested distributed SELECT in WITH clause 2023-06-03 20:22:51 +02:00
getStructureOfRemoteTable.h
getVirtualsForStorage.cpp
getVirtualsForStorage.h
IMessageProducer.cpp Fix race 2023-02-13 16:02:41 +01:00
IMessageProducer.h Fix race 2023-02-13 16:02:41 +01:00
IndicesDescription.cpp fix skip indexes 2023-03-06 15:29:13 +00:00
IndicesDescription.h
IStorage_fwd.h
IStorage.cpp Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
IStorage.h Disable parallelize_output_from_storages for all system tables 2023-06-14 19:11:23 +03:00
IStorageCluster.cpp Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
IStorageCluster.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
KeyDescription.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
KeyDescription.h
KVStorageUtils.cpp new redis engine schema design 2023-06-02 10:05:54 +08:00
KVStorageUtils.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
LightweightDeleteDescription.cpp
LightweightDeleteDescription.h
MarkCache.h Reduce inter-header dependencies 2023-05-02 21:15:18 +02:00
MemorySettings.cpp
MemorySettings.h Better alias definition 2023-02-01 13:54:03 +00:00
MessageQueueSink.cpp Add logging 2023-02-10 18:14:49 +01:00
MessageQueueSink.h release buffers with exception context 2023-06-22 13:00:13 +02:00
MutationCommands.cpp refactoring near alter conversions 2023-05-25 22:54:54 +00:00
MutationCommands.h Revert "Revert "Fix several RENAME COLUMN bugs."" 2023-02-27 12:27:57 +01:00
NamedCollectionsHelpers.cpp Review fixes 2023-03-17 13:56:02 +01:00
NamedCollectionsHelpers.h Add redis storage 2023-06-02 10:05:54 +08:00
PartitionCommands.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
PartitionCommands.h
PartitionedSink.cpp release buffers with exception context 2023-06-22 13:00:13 +02:00
PartitionedSink.h release buffers with exception context 2023-06-22 13:00:13 +02:00
ProjectionsDescription.cpp forbid old ctor of Exception 2023-01-23 22:18:05 +01:00
ProjectionsDescription.h
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h
ReadFromStorageProgress.cpp Improve progress bar for file/s3/hdfs/url table functions. Step 1 2023-06-16 15:51:18 +00:00
ReadFromStorageProgress.h Fix tests and builds 2023-06-20 13:01:47 +00:00
ReadInOrderOptimizer.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ReadInOrderOptimizer.h
RedisCommon.cpp fix code style 2023-06-02 10:05:54 +08:00
RedisCommon.h fix build error for dwrwin 2023-06-02 10:05:54 +08:00
registerStorages.cpp Merge branch 'master' into support_redis 2023-06-09 11:45:12 -04:00
registerStorages.h
removeGroupingFunctionSpecializations.cpp Resolve as FunctionGrouping 2023-03-14 03:33:31 +00:00
removeGroupingFunctionSpecializations.h Move visitor 2023-03-10 14:36:56 +00:00
RenamingRestrictions.h Minor code polishing 2022-12-22 14:31:42 +01:00
SelectQueryDescription.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
SelectQueryDescription.h Analyzer support LiveView 2023-02-16 12:17:03 +01:00
SelectQueryInfo.h Add 'partitions' field for system.query_log 2023-05-24 20:42:31 +08:00
SetSettings.cpp
SetSettings.h Better alias definition 2023-02-01 13:54:03 +00:00
StorageAzureBlob.cpp fix other classes based on SinkToStorage 2023-06-22 14:33:25 +02:00
StorageAzureBlob.h Improve progress bar for file/s3/hdfs/url table functions. Step 1 2023-06-16 15:51:18 +00:00
StorageBuffer.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageBuffer.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageConfiguration.h Simplify code around storage s3 configuration 2023-02-06 16:23:17 +01:00
StorageDictionary.cpp Apply some CTAD 2023-03-02 13:36:47 +00:00
StorageDictionary.h Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading() 2023-05-05 04:20:27 +00:00
StorageDistributed.cpp Fix style 2023-06-12 17:33:15 +00:00
StorageDistributed.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageDummy.cpp Fix Object data type for StorageDistributed 2023-06-02 23:41:25 +02:00
StorageDummy.h Fix Object data type for StorageDistributed 2023-06-02 23:41:25 +02:00
StorageExecutable.cpp Avoid std::out_of_range exception in StorageExecutable 2022-12-28 16:21:58 +00:00
StorageExecutable.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
StorageExternalDistributed.cpp Add schema inference to more table engines 2023-05-19 00:44:27 +00:00
StorageExternalDistributed.h Replace for table function remote, and external storage 2023-02-21 14:33:37 +01:00
StorageFactory.cpp Remove PVS-Studio 2023-02-19 23:30:05 +01:00
StorageFactory.h new redis engine schema design 2023-06-02 10:05:54 +08:00
StorageFile.cpp fix other classes based on SinkToStorage 2023-06-22 14:33:25 +02:00
StorageFile.h Merge pull request #49626 from alekseygolub/renamefile 2023-06-12 15:01:22 +02:00
StorageGenerateRandom.cpp Control memory usage in generateRandom 2023-06-04 04:44:51 +02:00
StorageGenerateRandom.h Fix SipHash integer hashing and byte order issue in GenerateRandom for s390x 2023-03-14 11:54:17 -04:00
StorageInMemoryMetadata.cpp Proper mutation of skip indices and projections 2023-06-04 18:32:08 +08:00
StorageInMemoryMetadata.h Proper mutation of skip indices and projections 2023-06-04 18:32:08 +08:00
StorageInput.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
StorageInput.h
StorageJoin.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageJoin.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageKeeperMap.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageKeeperMap.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageLog.cpp Fix Log family table return wrong rows count after truncate (#50585) 2023-06-09 14:32:45 +03:00
StorageLog.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageLogSettings.cpp fix 2023-02-11 13:58:19 +00:00
StorageLogSettings.h Storage Log faminy support settings storage policy 2023-02-04 14:28:31 +00:00
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMaterializedView.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMaterializedView.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMemory.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMemory.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMerge.cpp Fixes for parallel replicas (#50195) 2023-05-25 14:41:04 +02:00
StorageMerge.h Fixes for parallel replicas (#50195) 2023-05-25 14:41:04 +02:00
StorageMergeTree.cpp Merge branch 'master' into rmt_better_background_tasks_scheduling 2023-06-17 22:19:21 +03:00
StorageMergeTree.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMongoDB.cpp Merge branch 'master' into update-mongo 2023-06-10 10:58:02 +02:00
StorageMongoDB.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMongoDBSocketFactory.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
StorageMongoDBSocketFactory.h
StorageMySQL.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageMySQL.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageNull.cpp Only check MV on ALTER when necessary 2023-03-27 17:45:15 +02:00
StorageNull.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StoragePostgreSQL.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StoragePostgreSQL.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageProxy.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageRedis.cpp add notifications in docs 2023-06-13 09:33:38 +08:00
StorageRedis.h fix build error 2023-06-12 10:15:32 +08:00
StorageReplicatedMergeTree.cpp Merge pull request #44149 from zvonand/zvonand-implicit-tz 2023-06-23 14:28:49 +02:00
StorageReplicatedMergeTree.h disable table structure check for secondary queries from Replicated db 2023-06-22 19:06:28 +02:00
StorageS3.cpp release buffers with exception context 2023-06-22 13:00:13 +02:00
StorageS3.h Improve progress bar for file/s3/hdfs/url table functions. Step 1 2023-06-16 15:51:18 +00:00
StorageS3Cluster.cpp fix style 2023-05-15 16:39:26 +00:00
StorageS3Cluster.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +00:00
StorageS3Settings.cpp add test with merge tree table 2023-05-26 18:59:21 +02:00
StorageS3Settings.h add test with merge tree table 2023-05-26 18:59:21 +02:00
StorageSet.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageSet.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageSnapshot.cpp Added is_create_parameterized_view flag in ActionsVisitor, added functions for column manipulation for parameterized view in StorageView, updated tests to fix flaky test issues and addressed small review comments- 40907 Parameterized views as table functions 2023-01-03 11:00:39 +01:00
StorageSnapshot.h refactoring near alter conversions 2023-05-25 22:54:54 +00:00
StorageSQLite.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageSQLite.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageStripeLog.cpp Fix Log family table return wrong rows count after truncate (#50585) 2023-06-09 14:32:45 +03:00
StorageStripeLog.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageTableFunction.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageURL.cpp Merge branch 'master' into memory-leak 2023-06-23 15:35:53 +02:00
StorageURL.h fix other classes based on SinkToStorage 2023-06-22 14:33:25 +02:00
StorageURLCluster.cpp fix style 2023-05-15 16:39:26 +00:00
StorageURLCluster.h Fix schema inference with named collection, refactor Cluster table functions 2023-05-12 13:58:45 +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 Added space to if expression of replaceQueryParameterWithValue function 2023-03-14 09:26:53 +01:00
StorageView.h Addressed review comments for parameterized view bug fix 2023-03-14 09:23:12 +01:00
StorageXDBC.cpp Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
StorageXDBC.h Correctly disable async insert with deduplication when it's not needed (#50663) 2023-06-07 20:33:08 +02:00
TableLockHolder.h
transformQueryForExternalDatabase.cpp Better transformQueryForExternalDatabase for analyzer 2023-03-22 16:58:34 +00:00
transformQueryForExternalDatabase.h Support transformQueryForExternalDatabase for analyzer 2023-03-22 08:59:04 +01:00
transformQueryForExternalDatabaseAnalyzer.cpp Better transformQueryForExternalDatabase for analyzer 2023-03-22 16:58:34 +00:00
transformQueryForExternalDatabaseAnalyzer.h Support transformQueryForExternalDatabase for analyzer 2023-03-22 08:59:04 +01:00
TTLDescription.cpp enable_qpl_deflate_codec --> enable_deflate_qpl_codec 2023-06-09 12:43:33 +00:00
TTLDescription.h
TTLMode.h
UVLoop.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
VirtualColumnUtils.cpp Do not skip building set even when reading from remote 2023-05-02 21:31:56 +02:00
VirtualColumnUtils.h