..
Cache
DataLakes
Merge branch 'master' into formats-with-subcolumns
2023-08-02 15:24:56 +02:00
Distributed
Fix logging for asynchronous non-batched distributed sends ( #52583 )
2023-08-07 20:57:42 +02:00
examples
FileLog
fuzzers
HDFS
Merge branch 'master' into formats-with-subcolumns
2023-08-04 13:01:12 +02:00
Hive
Correctly disable async insert with deduplication when it's not needed ( #50663 )
2023-06-07 20:33:08 +02:00
Kafka
review fixes
2023-07-28 16:06:03 +00:00
LiveView
Remove ALTER of LIVE VIEW
2023-06-22 20:32:29 +02:00
MeiliSearch
Make IAST::FormatSettings more regular, pt. III
2023-07-20 10:34:05 +00:00
MergeTree
Disable using fs cache for backup/restore #2 .
2023-08-03 13:52:35 +02:00
MySQL
NATS
Correctly disable async insert with deduplication when it's not needed ( #50663 )
2023-06-07 20:33:08 +02:00
PostgreSQL
Update src/Storages/PostgreSQL/MaterializedPostgreSQLConsumer.cpp
2023-07-20 19:03:06 +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
S3Queue
Fix build for S3Queue
2023-08-03 14:20:19 +00:00
System
Merge pull request #52956 from ClickHouse/fixes_for_databases
2023-08-03 19:13:41 +03:00
tests
Correctly disable async insert with deduplication when it's not needed ( #50663 )
2023-06-07 20:33:08 +02:00
WindowView
Remove non-const function Context::getClientInfo().
2023-07-17 15:02:07 +02:00
AlterCommands.cpp
enable_qpl_deflate_codec --> enable_deflate_qpl_codec
2023-06-09 12:43:33 +00:00
AlterCommands.h
buildQueryTreeForShard.cpp
Refactor InDepthQueryTreeVisitorWithContext
2023-07-27 21:24:39 +00:00
buildQueryTreeForShard.h
Use query tree to rewrite the query
2023-06-12 16:51:40 +00:00
checkAndGetLiteralArgument.cpp
add more check + line break
2023-07-05 15:04:38 +00:00
checkAndGetLiteralArgument.h
CheckResults.h
CMakeLists.txt
ColumnDefault.cpp
ColumnDefault.h
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
ConstraintsDescription.cpp
Make serializeAST() more regular
2023-07-20 10:39:26 +00:00
ConstraintsDescription.h
DataDestinationType.h
ExecutableSettings.cpp
ExecutableSettings.h
ExternalDataSourceConfiguration.cpp
ExternalDataSourceConfiguration.h
extractKeyExpressionList.cpp
extractKeyExpressionList.h
extractTableFunctionArgumentsFromSelectQuery.cpp
extractTableFunctionArgumentsFromSelectQuery.h
Freeze.cpp
Freeze.h
getStructureOfRemoteTable.cpp
Merge pull request #51141 from ClickHouse/azure_blob_storage_sas_token
2023-08-01 12:27:17 +02:00
getStructureOfRemoteTable.h
getVirtualsForStorage.cpp
getVirtualsForStorage.h
IMessageProducer.cpp
IMessageProducer.h
IndicesDescription.cpp
Make serializeAST() more regular
2023-07-20 10:39:26 +00:00
IndicesDescription.h
IStorage_fwd.h
IStorage.cpp
Fix build
2023-07-17 19:15:07 +02:00
IStorage.h
Merge branch 'master' into add_delay_for_replicated
2023-07-26 12:48:48 +03:00
IStorageCluster.cpp
Fix schema inference with named collection, refactor Cluster table functions
2023-05-12 13:58:45 +00:00
IStorageCluster.h
KeyDescription.cpp
KeyDescription.h
KVStorageUtils.cpp
Cleanup.
2023-06-22 14:23:04 +00:00
KVStorageUtils.h
LightweightDeleteDescription.cpp
LightweightDeleteDescription.h
MarkCache.h
MemorySettings.cpp
MemorySettings.h
MessageQueueSink.cpp
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
NamedCollectionsHelpers.cpp
Rename
2023-06-15 12:35:22 +02:00
NamedCollectionsHelpers.h
Merge remote-tracking branch 'upstream/master' into add-separate-access-for-use-named-collections
2023-06-14 13:33:56 +02:00
PartitionCommands.cpp
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
prepareReadingFromFormat.cpp
Fix tests
2023-07-06 17:47:01 +00:00
prepareReadingFromFormat.h
Fix tests
2023-07-05 17:56:03 +00:00
ProjectionsDescription.cpp
Merge pull request #52151 from amosbird/fix_52075
2023-07-21 18:30:27 +02:00
ProjectionsDescription.h
ReadFinalForExternalReplicaStorage.cpp
ReadFinalForExternalReplicaStorage.h
ReadInOrderOptimizer.cpp
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 remote-tracking branch 'upstream/master' into s3queue
2023-06-30 13:56:43 +02:00
registerStorages.h
removeGroupingFunctionSpecializations.cpp
removeGroupingFunctionSpecializations.h
RenamingRestrictions.h
SelectQueryDescription.cpp
SelectQueryDescription.h
SelectQueryInfo.cpp
Fixing build.
2023-05-23 20:47:35 +00:00
SelectQueryInfo.h
select only required columns from system.databases
2023-08-02 23:23:52 +02:00
SetSettings.cpp
SetSettings.h
StorageAzureBlob.cpp
Merge branch 'master' into azure_table_function_cluster
2023-08-04 21:39:32 +02:00
StorageAzureBlob.h
Merge branch 'master' into azure_table_function_cluster
2023-08-04 21:39:32 +02:00
StorageAzureBlobCluster.cpp
Fixed glob iterator for table function cluster path without regex characters
2023-06-28 11:09:19 +02:00
StorageAzureBlobCluster.h
Fixed cluster with distributed_processing
2023-06-09 15:17:08 +02:00
StorageBuffer.cpp
Make shutdown of replicated tables softer
2023-07-05 18:11:25 +02:00
StorageBuffer.h
Make shutdown of replicated tables softer
2023-07-05 18:11:25 +02:00
StorageConfiguration.h
StorageDictionary.cpp
StorageDictionary.h
StorageDistributed.cpp
Merge branch 'master' into add_delay_for_replicated
2023-07-24 16:07:38 +02:00
StorageDistributed.h
Merge branch 'master' into add_delay_for_replicated
2023-07-24 16:07:38 +02:00
StorageDummy.cpp
Refactor a bit.
2023-06-16 19:38:50 +00:00
StorageDummy.h
Fix Object data type for StorageDistributed
2023-06-02 23:41:25 +02:00
StorageExecutable.cpp
StorageExecutable.h
StorageExternalDistributed.cpp
Add schema inference to more table engines
2023-05-19 00:44:27 +00:00
StorageExternalDistributed.h
StorageFactory.cpp
StorageFactory.h
new redis engine schema design
2023-06-02 10:05:54 +08:00
StorageFile.cpp
Merge branch 'master' into add-reading-from-archives
2023-08-06 10:21:47 +00:00
StorageFile.h
Merge branch 'master' into add-reading-from-archives
2023-08-04 12:42:46 +00:00
StorageGenerateRandom.cpp
Control memory usage in generateRandom
2023-06-04 04:44:51 +02:00
StorageGenerateRandom.h
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
StorageInput.h
StorageJoin.cpp
addJoinedBlock -> addBlockToJoin
2023-07-05 17:03:18 +00: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
Disable using fs cache for backup/restore #2 .
2023-08-03 13:52:35 +02: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
StorageLogSettings.h
StorageMaterializedMySQL.cpp
StorageMaterializedMySQL.h
Introduce IStorage::supportsTrivialCountOptimization()
2023-07-24 05:50:44 +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
Disable using fs cache for backup/restore #2 .
2023-08-03 13:52:35 +02:00
StorageMemory.h
Merge branch 'master' into refactor-subqueries-for-in
2023-06-09 20:04:27 +02:00
StorageMerge.cpp
Add a note about not working _table filter for Merge with analyzer
2023-07-27 16:35:17 +02:00
StorageMerge.h
Fixes for parallel replicas ( #50195 )
2023-05-25 14:41:04 +02:00
StorageMergeTree.cpp
Disable using fs cache for backup/restore #2 .
2023-08-03 13:52:35 +02:00
StorageMergeTree.h
don't create empty parts on drop partittion if we have a transaction ( #52945 )
2023-08-03 13:16:32 +03:00
StorageMongoDB.cpp
Fix build
2023-07-06 06:31:09 +00: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
StorageMongoDBSocketFactory.h
StorageMySQL.cpp
MaterializedMySQL: Support unquoted utf-8 strings in DDL
2023-07-24 11:12:10 +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
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
Merge branch 'master' into add_delay_for_replicated
2023-07-26 12:48:48 +03: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
Disable using fs cache for backup/restore #2 .
2023-08-03 13:52:35 +02:00
StorageReplicatedMergeTree.h
Merge branch 'master' into add_delay_for_replicated
2023-07-26 12:48:48 +03:00
StorageS3.cpp
Merge branch 'master' into formats-with-subcolumns
2023-08-02 15:24:56 +02:00
StorageS3.h
Merge branch 'master' into formats-with-subcolumns
2023-08-02 15:24:56 +02:00
StorageS3Cluster.cpp
Merge branch 'master' into better-progress-bar-2
2023-07-24 19:59:38 +02:00
StorageS3Cluster.h
Support reading subcolumns from file/s3/hdfs/url/azureBlobStorage table functions
2023-07-04 21:17:26 +00:00
StorageS3Settings.cpp
More generic approach to disable native copy
2023-07-09 08:20:02 +02:00
StorageS3Settings.h
Merge branch 'master' of github.com:ClickHouse/ClickHouse into ADQM-984
2023-07-26 09:58:26 +00:00
StorageSet.cpp
Cleanup.
2023-06-22 14:23:04 +00: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
Fixed clang tidy build by removing unued variable
2023-07-29 11:15:56 +02:00
StorageSnapshot.h
Create new StorageView with substituted parameters for every SELECT query of a parameterized view
2023-07-25 14:04:55 +02: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
Disable using fs cache for backup/restore #2 .
2023-08-03 13:52:35 +02: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
Merge pull request #52626 from ClickHouse/fix_deadlock_in_persistent_table_functions
2023-07-27 09:38:48 +02:00
StorageURL.cpp
Merge branch 'master' into formats-with-subcolumns
2023-08-02 15:24:56 +02:00
StorageURL.h
Merge branch 'master' into formats-with-subcolumns
2023-07-26 13:30:35 +02:00
StorageURLCluster.cpp
Fix build
2023-06-21 02:33:38 +02:00
StorageURLCluster.h
Support reading subcolumns from file/s3/hdfs/url/azureBlobStorage table functions
2023-07-04 21:17:26 +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
Create new StorageView with substituted parameters for every SELECT query of a parameterized view
2023-07-25 14:04:55 +02:00
StorageView.h
Create new StorageView with substituted parameters for every SELECT query of a parameterized view
2023-07-25 14:04:55 +02: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
Make IAST::FormatSettings more regular, pt. III
2023-07-20 10:34:05 +00:00
transformQueryForExternalDatabase.h
transformQueryForExternalDatabaseAnalyzer.cpp
transformQueryForExternalDatabaseAnalyzer.h
TTLDescription.cpp
enable_qpl_deflate_codec --> enable_deflate_qpl_codec
2023-06-09 12:43:33 +00:00
TTLDescription.h
TTLMode.h
UVLoop.h
VirtualColumnUtils.cpp
RFC: Fix filtering by virtual columns with OR expression
2023-07-27 16:35:17 +02:00
VirtualColumnUtils.h
Replace all Context references with std::weak_ptr ( #22297 )
2021-04-11 02:33:54 +03:00