.. |
Cache
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
DataLakes
|
Switch Block::NameMap to google::dense_hash_map over HashMap
|
2023-05-12 05:52:57 +02:00 |
Distributed
|
Fix processing pending batch for Distributed async INSERT after restart
|
2023-05-15 15:57:30 +02: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
|
Merge branch 'master' into urlCluster
|
2023-05-22 14:59:34 +02:00 |
Hive
|
Remove dependency from DB::Context in readers
|
2023-05-02 21:45:27 +02:00 |
Kafka
|
apply review suggestions
|
2023-05-22 15:18:29 +02:00 |
LiveView
|
Remove -Wshadow suppression which leaked into global namespace
|
2023-04-13 08:46:40 +00:00 |
MeiliSearch
|
Add schema inference to more table engines
|
2023-05-19 00:44:27 +00:00 |
MergeTree
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
MySQL
|
Fox
|
2023-04-13 19:36:25 +02:00 |
NATS
|
Highly questionable refactoring (getInputMultistream() nonsense)
|
2023-04-17 04:58:32 +00:00 |
PostgreSQL
|
replace NO DELAY with SYNC in tests
|
2023-05-03 20:08:49 +02:00 |
RabbitMQ
|
fix convertation
|
2023-05-10 17:50:42 +00:00 |
RocksDB
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
System
|
Add zookeeper name in endpoint id (#49780)
|
2023-05-25 12:50:14 +03:00 |
tests
|
Remove unused mockSystemDatabase from gtest_transform_query_for_external_database
|
2023-03-29 11:02:50 +00:00 |
WindowView
|
use Poco::Timestamp() instead of std::time
|
2023-04-20 14:36:54 +00:00 |
AlterCommands.cpp
|
Merge pull request #49563 from evillique/object-column-alter
|
2023-05-06 18:17:16 +03:00 |
AlterCommands.h
|
|
|
checkAndGetLiteralArgument.cpp
|
|
|
checkAndGetLiteralArgument.h
|
|
|
CheckResults.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
CMakeLists.txt
|
|
|
ColumnDefault.cpp
|
|
|
ColumnDefault.h
|
|
|
ColumnDependency.h
|
|
|
ColumnsDescription.cpp
|
Allow using Alias column type for KafkaEngine
|
2023-05-15 15:39:58 +02:00 |
ColumnsDescription.h
|
Allow using Alias column type for KafkaEngine
|
2023-05-15 15:39:58 +02:00 |
CompressionCodecSelector.h
|
|
|
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
|
|
|
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
|
|
|
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
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00: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
|
|
|
KeyDescription.h
|
fix local metadata differ zk metadata
|
2022-01-27 16:33:40 +08:00 |
KVStorageUtils.cpp
|
|
|
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
|
|
|
MessageQueueSink.cpp
|
|
|
MessageQueueSink.h
|
|
|
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
|
Fix clang-tidy
|
2023-03-05 22:12:51 +01:00 |
PartitionCommands.cpp
|
|
|
PartitionCommands.h
|
|
|
PartitionedSink.cpp
|
|
|
PartitionedSink.h
|
Fix double whitespace in exception message
|
2023-04-15 23:54:10 +02:00 |
ProjectionsDescription.cpp
|
|
|
ProjectionsDescription.h
|
|
|
ReadFinalForExternalReplicaStorage.cpp
|
|
|
ReadFinalForExternalReplicaStorage.h
|
|
|
ReadFromStorageProgress.cpp
|
|
|
ReadFromStorageProgress.h
|
|
|
ReadInOrderOptimizer.cpp
|
|
|
ReadInOrderOptimizer.h
|
|
|
registerStorages.cpp
|
fix build without parquet
|
2023-04-17 21:37:32 -07: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
|
|
|
SelectQueryDescription.cpp
|
|
|
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
|
|
|
StorageBuffer.cpp
|
Only check MV on ALTER when necessary
|
2023-03-27 17:45:15 +02:00 |
StorageBuffer.h
|
[RFC] Replacing merge tree new engine (#41005)
|
2023-02-16 16:03:16 +03:00 |
StorageConfiguration.h
|
|
|
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
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageDistributed.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
StorageDummy.cpp
|
Fixed tests
|
2023-03-01 18:05:07 +01:00 |
StorageDummy.h
|
Fixed tests
|
2023-03-01 18:05:07 +01:00 |
StorageExecutable.cpp
|
|
|
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
|
|
|
StorageFile.cpp
|
Disable mmap for server
|
2023-05-10 03:16:52 +02:00 |
StorageFile.h
|
Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading()
|
2023-05-05 04:20:27 +00:00 |
StorageGenerateRandom.cpp
|
Fix IBM
|
2023-04-21 12:38:45 +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
|
Revert "Revert "Fix several RENAME COLUMN bugs.""
|
2023-02-27 12:27:57 +01:00 |
StorageInMemoryMetadata.h
|
Revert "Revert "Fix several RENAME COLUMN bugs.""
|
2023-02-27 12:27:57 +01:00 |
StorageInput.cpp
|
|
|
StorageInput.h
|
|
|
StorageJoin.cpp
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageJoin.h
|
Fix build
|
2023-03-13 10:49:51 +00:00 |
StorageKeeperMap.cpp
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageKeeperMap.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
StorageLog.cpp
|
Add backup setting "decrypt_files_from_encrypted_disks"
|
2023-05-16 14:27:27 +02:00 |
StorageLog.h
|
|
|
StorageLogSettings.cpp
|
|
|
StorageLogSettings.h
|
|
|
StorageMaterializedMySQL.cpp
|
|
|
StorageMaterializedMySQL.h
|
|
|
StorageMaterializedView.cpp
|
Fix race between DROP MatView and RESTART REPLICAS (#47863)
|
2023-04-01 15:26:00 +03:00 |
StorageMaterializedView.h
|
[RFC] Replacing merge tree new engine (#41005)
|
2023-02-16 16:03:16 +03:00 |
StorageMemory.cpp
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageMemory.h
|
move pipe compute into initializePipeline
|
2023-05-02 14:59:41 +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
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageMergeTree.h
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageMongoDB.cpp
|
Add support for {server_uuid} macro
|
2023-04-09 03:04:26 +02:00 |
StorageMongoDB.h
|
fix typo
|
2023-05-15 16:51:20 +08:00 |
StorageMongoDBSocketFactory.cpp
|
|
|
StorageMongoDBSocketFactory.h
|
|
|
StorageMySQL.cpp
|
Fix style
|
2023-05-19 01:31:45 +00:00 |
StorageMySQL.h
|
Add schema inference to more table engines
|
2023-05-19 00:44:27 +00:00 |
StorageNull.cpp
|
Only check MV on ALTER when necessary
|
2023-03-27 17:45:15 +02:00 |
StorageNull.h
|
Propagate input_format_parquet_preserve_order to parallelizeOutputAfterReading()
|
2023-05-05 04:20:27 +00:00 |
StoragePostgreSQL.cpp
|
Merge pull request #50000 from evillique/add-schema-inference
|
2023-05-22 17:24:30 +02:00 |
StoragePostgreSQL.h
|
Add schema inference to more table engines
|
2023-05-19 00:44:27 +00:00 |
StorageProxy.h
|
[RFC] Replacing merge tree new engine (#41005)
|
2023-02-16 16:03:16 +03:00 |
StorageReplicatedMergeTree.cpp
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageReplicatedMergeTree.h
|
Add zookeeper name in endpoint id (#49780)
|
2023-05-25 12:50:14 +03:00 |
StorageS3.cpp
|
Merge pull request #50109 from kssenii/abstract-async-prefetched-buffer
|
2023-05-25 15:06:44 +02:00 |
StorageS3.h
|
Switch Block::NameMap to google::dense_hash_map over HashMap
|
2023-05-12 05:52:57 +02: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 ability to use strict parts size for S3 (compatibility with R2)
|
2023-04-28 11:01:56 +02:00 |
StorageS3Settings.h
|
Add ability to use strict parts size for S3 (compatibility with R2)
|
2023-04-28 11:01:56 +02:00 |
StorageSet.cpp
|
Make async reader work with any impl
|
2023-05-22 19:54:04 +02:00 |
StorageSet.h
|
Improve file includes
|
2023-03-24 03:44:52 +01:00 |
StorageSnapshot.cpp
|
|
|
StorageSnapshot.h
|
refactoring near alter conversions
|
2023-05-25 22:54:54 +00:00 |
StorageSQLite.cpp
|
Add schema inference to more table engines
|
2023-05-19 00:44:27 +00:00 |
StorageSQLite.h
|
Add schema inference to more table engines
|
2023-05-19 00:44:27 +00:00 |
StorageStripeLog.cpp
|
Add backup setting "decrypt_files_from_encrypted_disks"
|
2023-05-16 14:27:27 +02:00 |
StorageStripeLog.h
|
|
|
StorageTableFunction.h
|
Analyzer added distributed table functions support
|
2023-02-16 12:17:03 +01:00 |
StorageURL.cpp
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into urlCluster
|
2023-05-22 19:19:57 +00:00 |
StorageURL.h
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into urlCluster
|
2023-05-22 19:19:57 +00: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
|
|
|
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
|
Support transformQueryForExternalDatabase for analyzer
|
2023-03-22 08:59:04 +01:00 |
StorageXDBC.h
|
|
|
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
|
|
|
TTLDescription.h
|
|
|
TTLMode.h
|
|
|
UVLoop.h
|
|
|
VirtualColumnUtils.cpp
|
Do not skip building set even when reading from remote
|
2023-05-02 21:31:56 +02:00 |
VirtualColumnUtils.h
|
|
|