.. |
Cache
|
Add union mode for schema inference to infer union schema of files with different schemas
|
2023-10-20 20:46:41 +00:00 |
DataLakes
|
Remove some code
|
2024-01-13 03:48:04 +01:00 |
Distributed
|
Merge remote-tracking branch 'rschu1ze/master' into qatzstd_main
|
2024-01-07 14:11:22 +00:00 |
examples
|
|
|
FileLog
|
Better text_log with ErrnoException
|
2023-12-15 19:27:56 +01:00 |
fuzzers
|
|
|
HDFS
|
Remove some code
|
2024-01-13 03:48:04 +01:00 |
Hive
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
Kafka
|
Clean cached messages on destroy kafka consumer
|
2023-12-29 14:30:21 +01:00 |
LiveView
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
MaterializedView
|
Fix WriteBuffer assert if refresh is cancelled at the wrong moment
|
2023-12-28 18:34:28 +00:00 |
MergeTree
|
Merge branch 'master' into analyzer-fix-index-set
|
2024-01-13 04:15:10 +01:00 |
MySQL
|
Intorduce *List definition for muli enum settings
|
2023-11-28 19:09:02 +00:00 |
NATS
|
fix tests
|
2023-12-04 21:40:19 +00:00 |
PostgreSQL
|
Fxi
|
2023-12-14 16:05:40 +01:00 |
RabbitMQ
|
fix tests
|
2023-12-04 21:40:19 +00:00 |
RocksDB
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
S3Queue
|
Cleanup
|
2024-01-02 17:50:06 +00:00 |
Statistics
|
rename some code
|
2023-11-28 16:32:47 +01:00 |
System
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
tests
|
add test
|
2023-12-15 15:29:15 +00:00 |
WindowView
|
Some fixups
|
2024-01-07 22:28:08 +00:00 |
AlterCommands.cpp
|
Merge remote-tracking branch 'rschu1ze/master' into qatzstd_main
|
2024-01-07 14:11:22 +00:00 |
AlterCommands.h
|
Things
|
2023-12-28 17:56:05 +00:00 |
BlockNumberColumn.cpp
|
|
|
BlockNumberColumn.h
|
|
|
buildQueryTreeForShard.cpp
|
Another try.
|
2023-12-16 15:41:02 +00:00 |
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
|
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 comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +01:00 |
ColumnsDescription.h
|
Add comments to all columns of system tables (#58356)
|
2024-01-12 16:39:22 +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
|
|
|
ExternalDataSourceConfiguration.h
|
|
|
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
|
|
|
Freeze.cpp
|
|
|
Freeze.h
|
|
|
getStructureOfRemoteTable.cpp
|
|
|
getStructureOfRemoteTable.h
|
|
|
IMessageProducer.cpp
|
|
|
IMessageProducer.h
|
|
|
IndicesDescription.cpp
|
Revert "Revert "Support use alias column in indices""
|
2023-12-05 18:22:32 +00:00 |
IndicesDescription.h
|
|
|
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
|
Cleanup
|
2024-01-02 17:50:06 +00:00 |
IStorageCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
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
|
|
|
LightweightDeleteDescription.h
|
|
|
MarkCache.h
|
|
|
MemorySettings.cpp
|
|
|
MemorySettings.h
|
|
|
MessageQueueSink.cpp
|
|
|
MessageQueueSink.h
|
|
|
MutationCommands.cpp
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
MutationCommands.h
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
NamedCollectionsHelpers.cpp
|
Update src/Storages/NamedCollectionsHelpers.cpp
|
2023-11-21 11:14:48 +01:00 |
NamedCollectionsHelpers.h
|
Fix style
|
2024-01-08 08:50:34 +00:00 |
PartitionCommands.cpp
|
|
|
PartitionCommands.h
|
|
|
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
|
remove old code of projection analysis
|
2023-10-12 23:25:20 +00:00 |
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
|
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
|
Merge pull request #54366 from canhld94/final_no_copy
|
2024-01-14 04:21:07 +01:00 |
SetSettings.cpp
|
|
|
SetSettings.h
|
|
|
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
|
Remove some code
|
2024-01-13 03:48:04 +01:00 |
StorageAzureBlob.h
|
Merge remote-tracking branch 'rschu1ze/master' into regex-std-re2
|
2024-01-07 22:31:35 +00:00 |
StorageAzureBlobCluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageAzureBlobCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageBuffer.cpp
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2024-01-03 16:01:44 +00:00 |
StorageBuffer.h
|
Revert "Merge pull request #58274 from ClickHouse/revert-58267"
|
2023-12-28 14:07:59 +01: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-custom-key-failover
|
2024-01-08 20:43:20 +00:00 |
StorageDistributed.h
|
Make DirectoryMonitor handle cluster node list change (#42826)
|
2023-12-08 14:41:51 +01:00 |
StorageDummy.cpp
|
|
|
StorageDummy.h
|
|
|
StorageExecutable.cpp
|
fix tests
|
2023-12-04 21:40:19 +00:00 |
StorageExecutable.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
StorageExternalDistributed.cpp
|
remove old code of projection analysis
|
2023-10-12 23:25:20 +00:00 |
StorageExternalDistributed.h
|
|
|
StorageFactory.cpp
|
|
|
StorageFactory.h
|
|
|
StorageFile.cpp
|
Merge remote-tracking branch 'rschu1ze/master' into replace-std_regexp-by-re2
|
2024-01-10 10:02:53 +00:00 |
StorageFile.h
|
Merge branch 'master' into try-to-remove-pk-analysis-on-ast
|
2024-01-05 10:54:46 +00:00 |
StorageFileCluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageFileCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +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
|
Things
|
2023-12-28 17:56:05 +00:00 |
StorageInMemoryMetadata.h
|
Slightly more things
|
2023-12-28 17:56:05 +00: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
|
fix
|
2023-12-11 15:50:27 +00:00 |
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
|
Remove mayBenefitFromIndexForIn
|
2023-12-27 17:42:40 +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
|
Add missing includes
|
2024-01-13 01:48:55 +03:00 |
StorageMaterializedMySQL.cpp
|
|
|
StorageMaterializedMySQL.h
|
|
|
StorageMaterializedView.cpp
|
Max materialized views size for table
|
2024-01-15 10:02:57 +08:00 |
StorageMaterializedView.h
|
Merge pull request #57520 from Avogar/ignore-mv-with-dropped-target-table
|
2024-01-04 15:33:27 +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
|
fix build and tests
|
2024-01-03 16:59:13 +00:00 |
StorageMerge.h
|
Review fixes.
|
2024-01-03 10:12:08 +00:00 |
StorageMergeTree.cpp
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2024-01-06 20:58:17 +00:00 |
StorageMergeTree.h
|
Check if I can remove KeyCondition analysis on AST.
|
2024-01-03 17:50:46 +00:00 |
StorageMongoDB.cpp
|
|
|
StorageMongoDB.h
|
|
|
StorageMongoDBSocketFactory.cpp
|
|
|
StorageMongoDBSocketFactory.h
|
|
|
StorageMySQL.cpp
|
|
|
StorageMySQL.h
|
|
|
StorageNull.cpp
|
|
|
StorageNull.h
|
fix: StorageNull supports subcolumns
|
2023-10-22 16:24:01 +08:00 |
StoragePostgreSQL.cpp
|
Move Allocator code into module part
|
2023-12-27 15:42:08 +01:00 |
StoragePostgreSQL.h
|
bugfix: addresses_expr ignored for psql named collections
|
2023-12-14 17:17:14 +01:00 |
StorageProxy.h
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2024-01-03 16:01:44 +00:00 |
StorageRedis.cpp
|
|
|
StorageRedis.h
|
|
|
StorageReplicatedMergeTree.cpp
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2024-01-06 20:58:17 +00:00 |
StorageReplicatedMergeTree.h
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2024-01-06 20:58:17 +00:00 |
StorageS3.cpp
|
Merge pull request #58539 from canhld94/file_custom_compress_level
|
2024-01-09 13:43:38 -05:00 |
StorageS3.h
|
Merge branch 'master' into try-to-remove-pk-analysis-on-ast
|
2024-01-05 10:54:46 +00:00 |
StorageS3Cluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageS3Cluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageS3Settings.cpp
|
Move Allocator code into module part
|
2023-12-27 15:42:08 +01:00 |
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
|
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
|
|
|
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
|
Remove some code
|
2024-01-13 03:48:04 +01:00 |
StorageURL.h
|
Merge branch 'master' into try-to-remove-pk-analysis-on-ast
|
2024-01-05 10:54:46 +00:00 |
StorageURLCluster.cpp
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageURLCluster.h
|
Use predicate in getTaskIteratorExtension.
|
2024-01-02 17:14:16 +00:00 |
StorageValues.cpp
|
|
|
StorageValues.h
|
|
|
StorageView.cpp
|
Revert "Support SAMPLE BY for VIEW"
|
2023-10-09 00:08:46 +03:00 |
StorageView.h
|
|
|
StorageXDBC.cpp
|
Add reading step to URL
|
2024-01-02 15:18:13 +00:00 |
StorageXDBC.h
|
Add reading step to URL
|
2024-01-02 15:18:13 +00:00 |
TableLockHolder.h
|
|
|
transformQueryForExternalDatabase.cpp
|
Fix transform query for external database
|
2023-12-15 08:34:58 +00:00 |
transformQueryForExternalDatabase.h
|
|
|
transformQueryForExternalDatabaseAnalyzer.cpp
|
|
|
transformQueryForExternalDatabaseAnalyzer.h
|
|
|
TTLDescription.cpp
|
Merge remote-tracking branch 'rschu1ze/master' into qatzstd_main
|
2024-01-07 14:11:22 +00:00 |
TTLDescription.h
|
Fix tests
|
2023-11-23 16:02:33 +01:00 |
TTLMode.h
|
|
|
UVLoop.h
|
|
|
VirtualColumnUtils.cpp
|
Fixing index hint
|
2024-01-05 11:50:09 +00:00 |
VirtualColumnUtils.h
|
Fixing index hint
|
2024-01-05 11:50:09 +00:00 |