.. |
Cache
|
improvements for getFileSize
|
2022-06-20 15:22:56 +02:00 |
Distributed
|
Merge pull request #39178 from azat/dist-insert-log
|
2022-07-31 02:22:22 +03:00 |
examples
|
Fix clang-tidy in utils/examples
|
2022-07-29 11:36:51 +03:00 |
FileLog
|
Create metadata directory on CREATE for FileLog engine
|
2022-08-06 13:54:49 +03:00 |
fuzzers
|
Prefix overridden add_executable() command with "clickhouse_"
|
2022-07-11 19:36:18 +02:00 |
HDFS
|
Merge branch 'master' into fix-cancel-insert-into-function
|
2022-07-29 20:27:32 +02:00 |
Hive
|
Merge branch 'master' into use-dag-in-key-condition
|
2022-07-25 14:30:22 +02:00 |
Kafka
|
Merge pull request #38105 from arenadata/ADQM-419
|
2022-06-27 14:19:24 -04:00 |
LiveView
|
Fix typo
|
2022-06-30 18:37:19 +08:00 |
MeiliSearch
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
MergeTree
|
fix old tmp dirs cleanup
|
2022-08-09 18:44:51 +02:00 |
MySQL
|
Settings changes as key value
|
2021-12-27 17:45:00 +03:00 |
NATS
|
fix nats-io TLS support
|
2022-08-05 11:20:05 +02:00 |
PostgreSQL
|
Fix
|
2022-07-15 18:01:54 +02:00 |
RabbitMQ
|
removed default queue arguments
|
2022-07-15 13:46:52 +03:00 |
RocksDB
|
Use params for filtering by key in EmbeddedRocksDB
|
2022-07-31 10:44:01 +00:00 |
System
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2022-08-02 12:57:43 +00:00 |
tests
|
fix build
|
2022-07-14 11:33:23 +00:00 |
WindowView
|
Merge pull request #38335 from ClickHouse/deprecate_ordinary_database
|
2022-06-29 13:42:59 +03:00 |
AlterCommands.cpp
|
Capitalized const name
|
2022-07-25 16:32:16 +02:00 |
AlterCommands.h
|
Fix Alter ttl modification unsupported table engine
|
2022-01-24 21:48:52 +08:00 |
checkAndGetLiteralArgument.cpp
|
Fix build
|
2022-06-24 14:00:22 +00:00 |
checkAndGetLiteralArgument.h
|
Fix style
|
2022-06-27 13:56:43 +00:00 |
CheckResults.h
|
|
|
CMakeLists.txt
|
ready for review
|
2022-04-21 17:27:41 +08:00 |
ColumnDefault.cpp
|
added EPHEMERAL default for column (preliminary)
|
2022-02-07 23:21:10 +00:00 |
ColumnDefault.h
|
added EPHEMERAL default for column (preliminary)
|
2022-02-07 23:21:10 +00:00 |
ColumnDependency.h
|
|
|
ColumnsDescription.cpp
|
Add comment
|
2022-06-21 14:32:12 +02:00 |
ColumnsDescription.h
|
Cleanups
|
2022-07-24 12:21:18 +02:00 |
CompressionCodecSelector.h
|
Fix clang-tidy warnings in Server, Storages folders
|
2022-03-14 18:17:35 +00:00 |
ConstraintsDescription.cpp
|
Activate clang-tidy warning "readability-container-contains"
|
2022-04-18 23:53:11 +02:00 |
ConstraintsDescription.h
|
clang-tidy check performance-move-const-arg fix
|
2022-03-02 18:15:27 +00:00 |
DataDestinationType.h
|
|
|
ExecutableSettings.cpp
|
Follow-up to PR #37300: semicolon warnings
|
2022-05-20 15:06:34 +02:00 |
ExecutableSettings.h
|
Updated executable function integration tests
|
2021-12-28 22:55:30 +03:00 |
ExternalDataSourceConfiguration.cpp
|
Merge branch 'master' into nats-integration
|
2022-07-04 21:06:07 +02:00 |
ExternalDataSourceConfiguration.h
|
endpoint is added
|
2022-05-27 13:43:34 -04:00 |
extractKeyExpressionList.cpp
|
|
|
extractKeyExpressionList.h
|
|
|
Freeze.cpp
|
Merge branch 'master' into pp-system-unfreeze
|
2022-06-13 14:46:30 +00:00 |
Freeze.h
|
Add SYSTEM UNFREEZE query
|
2022-06-08 15:21:14 +03:00 |
getStructureOfRemoteTable.cpp
|
Update getStructureOfRemoteTable.cpp
|
2022-07-21 16:15:42 +03:00 |
getStructureOfRemoteTable.h
|
add more comments
|
2022-03-01 19:32:55 +03:00 |
getVirtualsForStorage.cpp
|
Better
|
2022-03-28 22:40:27 +02:00 |
getVirtualsForStorage.h
|
Fix clang-tidy, style check
|
2022-03-29 14:20:21 +02:00 |
IKVStorage.h
|
better
|
2022-07-05 10:46:08 +00:00 |
IndicesDescription.cpp
|
Follow-up to PR #37300: semicolon warnings
|
2022-05-20 15:06:34 +02:00 |
IndicesDescription.h
|
add hints for column description
|
2022-04-04 07:24:42 +00:00 |
IStorage_fwd.h
|
|
|
IStorage.cpp
|
Merge branch 'master' into better-exception-messages
|
2022-07-04 15:07:31 +02:00 |
IStorage.h
|
Cleanup usages of allow_experimental_projection_optimization setting, part 1
|
2022-07-30 23:40:21 +02:00 |
KeyDescription.cpp
|
Update KeyDescription.cpp
|
2022-02-07 13:59:03 +03:00 |
KeyDescription.h
|
fix local metadata differ zk metadata
|
2022-01-27 16:33:40 +08:00 |
LightweightDeleteDescription.cpp
|
Capitalized const name
|
2022-07-25 16:32:16 +02:00 |
LightweightDeleteDescription.h
|
Capitalized const name
|
2022-07-25 16:32:16 +02:00 |
MarkCache.h
|
Fix clang-tidy warnings in Server, Storages folders
|
2022-03-14 18:17:35 +00:00 |
MemorySettings.cpp
|
|
|
MemorySettings.h
|
|
|
MutationCommands.cpp
|
Reduce dependencies on ASTLiteral.h
|
2021-11-26 17:54:57 +01:00 |
MutationCommands.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
PartitionCommands.cpp
|
Reduce dependencies on ASTIdentifier.h
|
2021-11-26 16:49:40 +01:00 |
PartitionCommands.h
|
|
|
PartitionedSink.cpp
|
Merge branch 'master' into refactor-read-metrics-and-callbacks
|
2022-05-25 16:27:40 +02:00 |
PartitionedSink.h
|
Finalize write buffers in case of exception
|
2022-05-06 17:30:18 +00:00 |
ProjectionsDescription.cpp
|
Fix building aggregate projections when external aggregation is on (#39671)
|
2022-08-04 23:29:26 +02:00 |
ProjectionsDescription.h
|
add hints for projections
|
2022-04-04 07:24:42 +00:00 |
ReadFinalForExternalReplicaStorage.cpp
|
Fix some more tests.
|
2022-06-01 15:21:47 +00:00 |
ReadFinalForExternalReplicaStorage.h
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
ReadInOrderOptimizer.cpp
|
Fixing build.
|
2022-07-20 20:30:16 +00:00 |
ReadInOrderOptimizer.h
|
support read_in_order optimization if prefix of sorting key is fixed
|
2021-12-14 15:54:20 +03:00 |
registerStorages.cpp
|
Merge branch 'master' into nats-integration
|
2022-05-17 16:59:57 +03:00 |
registerStorages.h
|
|
|
SelectQueryDescription.cpp
|
Fix LOGICAL_ERROR for MATERIALIZED VIEW over table functions (i.e. numbers())
|
2021-12-11 11:04:47 +03:00 |
SelectQueryDescription.h
|
|
|
SelectQueryInfo.h
|
Fix ORDER BY that matches projections ORDER BY
|
2022-07-24 15:23:13 +03:00 |
SetSettings.cpp
|
|
|
SetSettings.h
|
|
|
StorageBuffer.cpp
|
Replace MemoryTrackerBlockerInThread to LockMemoryExceptionInThread in some places. Reduced MemoryTrackerBlockerInThread level to User.
|
2022-07-26 15:22:00 +00:00 |
StorageBuffer.h
|
Remove some commented code.
|
2022-05-30 13:18:20 +00:00 |
StorageDictionary.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageDictionary.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageDistributed.cpp
|
Renamed __row_exists to _row_exists
|
2022-07-18 20:07:36 +02:00 |
StorageDistributed.h
|
Remove some commented code.
|
2022-05-30 13:18:20 +00:00 |
StorageExecutable.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageExecutable.h
|
Move some resources
|
2022-05-23 19:47:32 +00:00 |
StorageExternalDistributed.cpp
|
Merge pull request #38363 from kssenii/pg-add-auto-close
|
2022-07-06 01:10:05 +02:00 |
StorageExternalDistributed.h
|
Move some resources
|
2022-05-23 19:47:32 +00:00 |
StorageFactory.cpp
|
improve
|
2022-02-01 16:59:41 +00:00 |
StorageFactory.h
|
Fix Alter ttl modification unsupported table engine
|
2022-01-24 21:48:52 +08:00 |
StorageFile.cpp
|
Fix WriteBuffer finalize when cancel insert into function
|
2022-07-21 12:18:37 +00:00 |
StorageFile.h
|
Fix comments
|
2022-05-20 14:57:27 +00:00 |
StorageGenerateRandom.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageGenerateRandom.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageInMemoryMetadata.cpp
|
Cleanups
|
2022-07-24 12:21:18 +02:00 |
StorageInMemoryMetadata.h
|
Cleanups
|
2022-07-24 12:21:18 +02:00 |
StorageInput.cpp
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
StorageInput.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageJoin.cpp
|
Join enums refactoring
|
2022-07-29 18:35:05 +02:00 |
StorageJoin.h
|
Join enums refactoring
|
2022-07-29 18:35:05 +02:00 |
StorageLog.cpp
|
fix reading from StorageLog with mmap
|
2022-07-13 20:36:18 +00:00 |
StorageLog.h
|
fix reading from StorageLog with mmap
|
2022-07-13 20:36:18 +00:00 |
StorageLogSettings.cpp
|
|
|
StorageLogSettings.h
|
|
|
StorageMaterializedMySQL.cpp
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
StorageMaterializedMySQL.h
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
StorageMaterializedView.cpp
|
Add test for partition clause. More checks for data compatibility on restore.
|
2022-06-30 08:37:18 +02:00 |
StorageMaterializedView.h
|
Add test for partition clause. More checks for data compatibility on restore.
|
2022-06-30 08:37:18 +02:00 |
StorageMemory.cpp
|
Leave only _row_exists-based implementation of lightweight delete
|
2022-07-21 11:26:13 +02:00 |
StorageMemory.h
|
Make temporary files in better places.
|
2022-07-04 11:02:58 +02:00 |
StorageMerge.cpp
|
Fixing build.
|
2022-07-27 15:45:23 +00:00 |
StorageMerge.h
|
Fixing read-in-order for Merge
|
2022-07-27 12:00:55 +00:00 |
StorageMergeTree.cpp
|
fix old tmp dirs cleanup
|
2022-08-09 18:44:51 +02:00 |
StorageMergeTree.h
|
Leave only _row_exists-based implementation of lightweight delete
|
2022-07-21 11:26:13 +02:00 |
StorageMongoDB.cpp
|
Merge remote-tracking branch 'petrenko/master' into petrenko-master
|
2022-07-13 11:28:52 +02:00 |
StorageMongoDB.h
|
Fix style check and black check
|
2022-07-12 16:29:11 +02:00 |
StorageMongoDBSocketFactory.cpp
|
Remove cruft
|
2021-10-28 02:10:39 +03:00 |
StorageMongoDBSocketFactory.h
|
|
|
StorageMySQL.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageMySQL.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageNull.cpp
|
Remove inherited create() method + disallow copying
|
2022-05-02 08:46:52 +02:00 |
StorageNull.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StoragePostgreSQL.cpp
|
Merge pull request #38363 from kssenii/pg-add-auto-close
|
2022-07-06 01:10:05 +02:00 |
StoragePostgreSQL.h
|
remove last mentions of data streams
|
2022-05-09 19:15:24 +00:00 |
StorageProxy.h
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
StorageReplicatedMergeTree.cpp
|
fix old tmp dirs cleanup
|
2022-08-09 18:44:51 +02:00 |
StorageReplicatedMergeTree.h
|
Make sure that the current replica is the first on the list
|
2022-08-04 20:26:39 +02:00 |
StorageS3.cpp
|
Fix WriteBuffer finalize when cancel insert into function
|
2022-07-21 12:18:37 +00:00 |
StorageS3.h
|
Merge branch 'master' into refactor-read-metrics-and-callbacks
|
2022-05-30 09:47:35 +00:00 |
StorageS3Cluster.cpp
|
Merge branch 'master' into refactor-read-metrics-and-callbacks
|
2022-05-25 16:27:40 +02:00 |
StorageS3Cluster.h
|
partition pruning for s3
|
2022-05-24 18:57:55 +08:00 |
StorageS3Settings.cpp
|
Revert "Fix errors of CheckTriviallyCopyableMove type"
|
2022-06-07 13:53:10 +02:00 |
StorageS3Settings.h
|
Fix
|
2022-04-08 12:30:24 +02:00 |
StorageSet.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageSet.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageSnapshot.cpp
|
Capitalized const name
|
2022-07-25 16:32:16 +02:00 |
StorageSnapshot.h
|
Cleanups
|
2022-07-24 12:21:18 +02:00 |
StorageSQLite.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageSQLite.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageStripeLog.cpp
|
fix reading from StorageLog with mmap
|
2022-07-13 20:36:18 +00:00 |
StorageStripeLog.h
|
fix reading from StorageLog with mmap
|
2022-07-13 20:36:18 +00:00 |
StorageTableFunction.h
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
StorageURL.cpp
|
Fix WriteBuffer finalize when cancel insert into function
|
2022-07-21 12:18:37 +00:00 |
StorageURL.h
|
Fix WriteBuffer finalize when cancel insert into function
|
2022-07-21 12:18:37 +00:00 |
StorageValues.cpp
|
Merge remote-tracking branch 'origin/sparse-serialization' into HEAD
|
2021-11-09 15:36:25 +03:00 |
StorageValues.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageView.cpp
|
Add new table function viewIfPermitted().
|
2022-07-15 15:44:29 +02:00 |
StorageView.h
|
Remove some commented code.
|
2022-05-30 13:18:20 +00:00 |
StorageXDBC.cpp
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
StorageXDBC.h
|
Better naming
|
2022-05-13 18:39:19 +00:00 |
TableLockHolder.h
|
change alter_lock to std::timed_mutex
|
2021-10-26 13:37:00 +03:00 |
transformQueryForExternalDatabase.cpp
|
Fix
|
2021-12-27 11:59:33 +03:00 |
transformQueryForExternalDatabase.h
|
|
|
TTLDescription.cpp
|
Small refactoring
|
2022-06-16 15:41:04 +00:00 |
TTLDescription.h
|
Cleanups
|
2022-07-24 12:21:18 +02:00 |
TTLMode.h
|
|
|
UVLoop.h
|
Fix review issues; add insert queue parameter
|
2022-05-16 16:35:17 +03:00 |
VirtualColumnUtils.cpp
|
Introduce AggregationKeysInfo
|
2022-05-25 23:22:29 +00:00 |
VirtualColumnUtils.h
|
|
|