.. |
Cache
|
Generate config.h into ${CONFIG_INCLUDE_PATH}
|
2022-09-28 12:48:26 +00:00 |
Distributed
|
Update DirectoryMonitor.cpp
|
2022-09-27 11:00:38 +08:00 |
examples
|
Merge remote-tracking branch 'upstream/master' into fix-thread-status
|
2022-09-23 19:39:07 +02: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
|
less
|
2022-10-14 14:27:52 +02:00 |
Hive
|
Generate config.h into ${CONFIG_INCLUDE_PATH}
|
2022-09-28 12:48:26 +00:00 |
Kafka
|
Fix some #include atrocities
|
2022-09-28 13:49:28 +00:00 |
LiveView
|
Remove temporary live views
|
2022-10-08 00:16:36 +02:00 |
MeiliSearch
|
Better exception messages on wrong table engines/functions argument types
|
2022-06-23 20:04:06 +00:00 |
MergeTree
|
Merge pull request #41107 from Avogar/improve-combinators
|
2022-10-18 15:24:49 +02:00 |
MySQL
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
NATS
|
Add retries for nats
|
2022-09-19 14:27:11 +02:00 |
PostgreSQL
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
RabbitMQ
|
Revert "Create new query context in StorageRabbitMQ/Nat"
|
2022-08-31 11:57:41 +02:00 |
RocksDB
|
Minor update StorageEmbeddedRocksDB::getSampleBlock
|
2022-09-08 12:43:38 +00:00 |
System
|
Merge pull request #42263 from vitlibar/refactor-udf
|
2022-10-15 12:33:10 +02:00 |
tests
|
Remove cruft
|
2022-09-17 22:16:31 +02:00 |
WindowView
|
abort instead of __builtin_unreachable in debug builds
|
2022-10-07 21:49:08 +02:00 |
AlterCommands.cpp
|
Update AlterCommands.cpp
|
2022-10-19 00:25:21 +03:00 |
AlterCommands.h
|
Fix Alter ttl modification unsupported table engine
|
2022-01-24 21:48:52 +08:00 |
checkAndGetLiteralArgument.cpp
|
address comments
|
2022-08-17 23:25:42 +08: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
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
ColumnsDescription.cpp
|
abort instead of __builtin_unreachable in debug builds
|
2022-10-07 21:49:08 +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
|
s3 header auth in ast
|
2022-09-13 15:13:28 +02:00 |
ExternalDataSourceConfiguration.h
|
s3 header auth in ast
|
2022-09-13 15:13:28 +02:00 |
extractKeyExpressionList.cpp
|
|
|
extractKeyExpressionList.h
|
|
|
Freeze.cpp
|
Update src/Storages/Freeze.cpp
|
2022-09-09 16:20:24 +03:00 |
Freeze.h
|
fix underscore
|
2022-08-23 13:59:02 +03:00 |
getStructureOfRemoteTable.cpp
|
Remove some methods
|
2022-09-10 05:04:40 +02: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 |
HeaderCollection.h
|
s3 header auth in ast
|
2022-09-13 15:13:28 +02: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
|
Fixed style
|
2022-09-28 18:59:07 +02:00 |
IStorage.h
|
Forgot to add function to header
|
2022-09-29 08:44:10 +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 |
KVStorageUtils.cpp
|
Extract common KV storage logic
|
2022-08-16 09:32:01 +00:00 |
KVStorageUtils.h
|
Extract common KV storage logic
|
2022-08-16 09:32:01 +00: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 review
|
2022-08-08 21:34:24 +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
|
Fix typos with new codespell
|
2022-09-02 08:54:48 +00:00 |
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
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
ReadInOrderOptimizer.cpp
|
Merge pull request #41701 from CurtizJ/fix-monotonic-order-by
|
2022-09-30 17:32:37 +02:00 |
ReadInOrderOptimizer.h
|
better support of read_in_order in case of fixed prefix of sorting key
|
2022-07-01 16:45:01 +00:00 |
registerStorages.cpp
|
Fix some #include atrocities
|
2022-09-28 13:49:28 +00: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
|
Tiny improvements along the code
|
2022-09-13 12:06:56 +00:00 |
SetSettings.cpp
|
|
|
SetSettings.h
|
|
|
StorageBuffer.cpp
|
Fix read from buffer with read in order (#42236)
|
2022-10-17 14:25:31 +02:00 |
StorageBuffer.h
|
Suggestions from @azat
|
2022-08-26 03:00:56 +02: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
|
Merge pull request #42168 from ClickHouse/unreachable_macro
|
2022-10-08 19:05:57 +03:00 |
StorageDistributed.h
|
Revert "Resurrect parallel distributed insert select with s3Cluster (#41535)"
|
2022-10-07 15:53:30 +02: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
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +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 5/6 of trash
|
2022-09-19 08:50:53 +02:00 |
StorageFile.h
|
Refactor, remove TTL, add size limit, add system table and system query
|
2022-08-05 16:20:15 +00:00 |
StorageGenerateRandom.cpp
|
Merge branch 'master' of github.com:ClickHouse/ClickHouse into ADQM-485
|
2022-07-25 17:55:47 +00:00 |
StorageGenerateRandom.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageInMemoryMetadata.cpp
|
Try to fix tests
|
2022-08-21 09:23:37 +00:00 |
StorageInMemoryMetadata.h
|
remove useless code
|
2022-10-12 03:48:37 +00: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
|
Rename join_common -> JoinUtils
|
2022-08-10 14:20:28 +00:00 |
StorageJoin.h
|
Simplify the code and check what will happen
|
2022-08-15 06:56:29 +02:00 |
StorageKeeperMap.cpp
|
Add support for exists in multiread
|
2022-09-29 10:39:33 +00:00 |
StorageKeeperMap.h
|
Address PR comments
|
2022-09-12 14:43:52 +00:00 |
StorageLog.cpp
|
Move back TemporaryFile -> TemporaryFileOnDisk
|
2022-08-24 16:14:11 +00:00 |
StorageLog.h
|
fix reading from StorageLog with mmap
|
2022-07-13 20:36:18 +00:00 |
StorageLogSettings.cpp
|
|
|
StorageLogSettings.h
|
|
|
StorageMaterializedMySQL.cpp
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
StorageMaterializedMySQL.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +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
|
try to fix filling of missed Nested columns with multiple levels
|
2022-09-06 13:56:32 +00:00 |
StorageMemory.h
|
Make temporary files in better places.
|
2022-07-04 11:02:58 +02:00 |
StorageMerge.cpp
|
Fix 5/6 of trash
|
2022-09-19 08:50:53 +02:00 |
StorageMerge.h
|
Fix KeyCondition with other filters
|
2022-08-11 19:20:44 +08:00 |
StorageMergeTree.cpp
|
Use alias for std::shared_ptr<MergeMutateSelectedEntry> (#42211)
|
2022-10-18 13:35:34 +02:00 |
StorageMergeTree.h
|
Use alias for std::shared_ptr<MergeMutateSelectedEntry> (#42211)
|
2022-10-18 13:35:34 +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
|
Generate config.h into ${CONFIG_INCLUDE_PATH}
|
2022-09-28 12:48:26 +00:00 |
StorageMongoDBSocketFactory.h
|
|
|
StorageMySQL.cpp
|
Fix 5/6 of trash
|
2022-09-19 08:50:53 +02:00 |
StorageMySQL.h
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00: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
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
StorageProxy.h
|
Move some resources
|
2022-05-20 19:49:31 +00:00 |
StorageReplicatedMergeTree.cpp
|
Replicated merge tree polishing
|
2022-10-21 14:02:52 +02:00 |
StorageReplicatedMergeTree.h
|
Replicated merge tree polishing
|
2022-10-21 14:02:52 +02:00 |
StorageS3.cpp
|
Generate config.h into ${CONFIG_INCLUDE_PATH}
|
2022-09-28 12:48:26 +00:00 |
StorageS3.h
|
Generate config.h into ${CONFIG_INCLUDE_PATH}
|
2022-09-28 12:48:26 +00:00 |
StorageS3Cluster.cpp
|
Revert "Resurrect parallel distributed insert select with s3Cluster (#41535)"
|
2022-10-07 15:53:30 +02:00 |
StorageS3Cluster.h
|
Revert "Resurrect parallel distributed insert select with s3Cluster (#41535)"
|
2022-10-07 15:53:30 +02:00 |
StorageS3Settings.cpp
|
Revert s3 prefixes + add retries on write requests unexpected errors
|
2022-09-16 14:43:43 +02:00 |
StorageS3Settings.h
|
Fix use_environment_credentials
|
2022-09-30 12:25:39 +02:00 |
StorageSet.cpp
|
Simplify the code and check what will happen
|
2022-08-15 06:56:29 +02:00 |
StorageSet.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageSnapshot.cpp
|
Try to fix tests
|
2022-08-21 09:23:37 +00: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
|
Consolidate config_core.h into config.h
|
2022-09-28 13:31:57 +00:00 |
StorageStripeLog.cpp
|
add flag that enables automatic canversion from Ordinary to Atomic
|
2022-08-05 21:41:25 +02: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
|
Merge remote-tracking branch 'upstream/master' into fix-thread-status
|
2022-09-23 19:39:07 +02:00 |
StorageURL.h
|
Merge pull request #40600 from FrankChen021/check_url_arg
|
2022-08-27 19:29:55 +03:00 |
StorageValues.cpp
|
|
|
StorageValues.h
|
Don't let storages inherit from boost::noncopyable
|
2022-05-03 09:07:08 +02:00 |
StorageView.cpp
|
Fix view with merge table function (#40734)
|
2022-09-01 12:20:00 +02:00 |
StorageView.h
|
Remove some commented code.
|
2022-05-30 13:18:20 +00:00 |
StorageXDBC.cpp
|
Merge pull request #40600 from FrankChen021/check_url_arg
|
2022-08-27 19:29:55 +03:00 |
StorageXDBC.h
|
Merge branch 'master' into xdbc-constraints
|
2022-08-20 21:26:07 +03:00 |
TableLockHolder.h
|
|
|
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
|
Refactor PreparedSets/SubqueryForSet
|
2022-07-26 18:39:02 +00:00 |
VirtualColumnUtils.h
|
|
|