.. |
Cache
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
DataLakes
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
Distributed
|
Merge remote-tracking branch 'ClickHouse/master' into dist/config-settings
|
2024-02-26 11:15:51 +00:00 |
examples
|
fix
|
2024-02-16 14:05:22 +01:00 |
FileLog
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
fuzzers
|
fix fuzzers, cmake refactor, add target fuzzers
|
2023-09-01 14:20:50 +00:00 |
HDFS
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
Hive
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
Kafka
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
LiveView
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
MaterializedView
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
MergeTree
|
Merge pull request #60436 from nickitat/revert_56864
|
2024-02-27 15:25:15 +01:00 |
MySQL
|
Intorduce *List definition for muli enum settings
|
2023-11-28 19:09:02 +00:00 |
NATS
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
PostgreSQL
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
RabbitMQ
|
Merge pull request #60159 from ClickHouse/fix_create_replica
|
2024-02-23 13:53:47 +01:00 |
RocksDB
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
S3Queue
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
Statistics
|
rename some code
|
2023-11-28 16:32:47 +01:00 |
System
|
Merge pull request #60436 from nickitat/revert_56864
|
2024-02-27 15:25:15 +01:00 |
tests
|
Update gtest_storage_log.cpp
|
2024-02-21 20:16:14 +01:00 |
WindowView
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
AlterCommands.cpp
|
Revert "Add definers for views (#54901)"
|
2024-02-23 12:44:31 +01:00 |
AlterCommands.h
|
Revert "Add definers for views (#54901)"
|
2024-02-23 12:44:31 +01:00 |
BlockNumberColumn.cpp
|
Added a new column _block_number (#47532)
|
2023-09-20 11:31:12 +02:00 |
BlockNumberColumn.h
|
Added a new column _block_number (#47532)
|
2023-09-20 11:31:12 +02:00 |
buildQueryTreeForShard.cpp
|
Support non global in mode.
|
2024-02-05 17:05:21 +00:00 |
buildQueryTreeForShard.h
|
Support non global in mode.
|
2024-02-05 17:05:21 +00:00 |
checkAndGetLiteralArgument.cpp
|
add more check + line break
|
2023-07-05 15:04:38 +00:00 |
checkAndGetLiteralArgument.h
|
|
|
CheckResults.h
|
Improve CHECK TABLE system query
|
2023-10-23 09:35:26 +00:00 |
CMakeLists.txt
|
|
|
ColumnDefault.cpp
|
|
|
ColumnDefault.h
|
|
|
ColumnDependency.h
|
use statistic to order prewhere conditions better
|
2023-08-09 22:57:49 +02:00 |
ColumnsDescription.cpp
|
Merge remote-tracking branch 'ClickHouse/master' into column_level_compress_block
|
2024-01-18 19:12:57 +00:00 |
ColumnsDescription.h
|
Merge remote-tracking branch 'ClickHouse/master' into column_level_compress_block
|
2024-01-18 19:12:57 +00: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
|
StorageExecutable check_exit_code default to false
|
2023-08-18 15:38:47 +08:00 |
ExternalDataSourceConfiguration.cpp
|
Remove broken lockless variant of re2
|
2023-09-14 16:40:42 +00:00 |
ExternalDataSourceConfiguration.h
|
Support clang-18 (Wmissing-field-initializers)
|
2023-08-23 15:53:45 +02:00 |
extractKeyExpressionList.cpp
|
ANTLR4 Grammar for ClickHouse and new parser (#11298)
|
2020-12-04 05:15:44 +03:00 |
extractKeyExpressionList.h
|
|
|
extractTableFunctionArgumentsFromSelectQuery.cpp
|
|
|
extractTableFunctionArgumentsFromSelectQuery.h
|
|
|
Freeze.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
Freeze.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
getStructureOfRemoteTable.cpp
|
Handle clusterAllReplicas/remote cases to avoid unnecessary logging
|
2023-09-12 12:52:29 +00:00 |
getStructureOfRemoteTable.h
|
|
|
IMessageProducer.cpp
|
Fix lazy initialization in RabbitMQ, fix possible deadlock on insert into unitialized queue engine
|
2024-01-29 20:09:09 +00:00 |
IMessageProducer.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
IndicesDescription.cpp
|
Revert "Revert "Support use alias column in indices""
|
2023-12-05 18:22:32 +00:00 |
IndicesDescription.h
|
Refactor IHints
|
2023-09-10 03:48:12 +00:00 |
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
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
IStorageCluster.h
|
Merge branch 'master' into auto-format-detection
|
2024-01-25 22:11:07 +01:00 |
KeyDescription.cpp
|
|
|
KeyDescription.h
|
|
|
KVStorageUtils.cpp
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
KVStorageUtils.h
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
LightweightDeleteDescription.cpp
|
|
|
LightweightDeleteDescription.h
|
Capitalized const name
|
2022-07-25 16:32:16 +02:00 |
MarkCache.h
|
Better parameter name
|
2023-08-22 15:43:13 +00:00 |
MemorySettings.cpp
|
|
|
MemorySettings.h
|
|
|
MessageQueueSink.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
MessageQueueSink.h
|
release buffers with exception context
|
2023-06-22 13:00:13 +02:00 |
MutationCommands.cpp
|
Support query parameters in ALTER TABLE ... PART
|
2024-01-15 14:16:54 +03:00 |
MutationCommands.h
|
add mutation command to apply deleted mask
|
2023-12-01 19:12:05 +00:00 |
NamedCollectionsHelpers.cpp
|
Revert "Add table function mergeTreeIndex "
|
2024-02-26 19:37:06 +01:00 |
NamedCollectionsHelpers.h
|
Revert "Add table function mergeTreeIndex "
|
2024-02-26 19:37:06 +01:00 |
PartitionCommands.cpp
|
add FORGET PARTITION query to remove old parition nodes from ZooKeeper
|
2024-02-02 10:03:31 +00:00 |
PartitionCommands.h
|
add FORGET PARTITION query to remove old parition nodes from ZooKeeper
|
2024-02-02 10:03:31 +00:00 |
PartitionedSink.cpp
|
Minor changes
|
2023-11-22 12:13:47 +01: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
|
Disable transform_null_in as well just in case.
|
2023-11-29 17:30:22 +00:00 |
ProjectionsDescription.h
|
Refactor IHints
|
2023-09-10 03:48:12 +00:00 |
ReadFinalForExternalReplicaStorage.cpp
|
remove old code of projection analysis
|
2023-10-12 23:25:20 +00:00 |
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
|
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
|
Minor code polishing
|
2022-12-22 14:31:42 +01:00 |
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
|
Fixing build.
|
2023-05-23 20:47:35 +00:00 |
SelectQueryInfo.h
|
Fix most tests
|
2024-02-26 02:31:58 +08:00 |
SetSettings.cpp
|
Better exceptions rethrow
|
2020-10-26 06:35:57 +03:00 |
SetSettings.h
|
Move obsolete format settings to separate section
|
2023-09-20 16:00:28 +00:00 |
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
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageAzureBlob.h
|
Addressed comments, added test for named collection
|
2024-02-04 11:28:20 +01:00 |
StorageAzureBlobCluster.cpp
|
Merge branch 'master' into auto-format-detection
|
2024-01-25 22:11:07 +01:00 |
StorageAzureBlobCluster.h
|
Try to detect file format automatically during schema inference if it's unknown
|
2024-01-23 18:59:39 +00:00 |
StorageBuffer.cpp
|
Fix build in master
|
2024-02-19 17:48:53 +01:00 |
StorageBuffer.h
|
Better if only 1 layer
|
2024-02-18 13:19:35 +01:00 |
StorageConfiguration.h
|
|
|
StorageDictionary.cpp
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageDictionary.h
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
StorageDistributed.cpp
|
Code cleanup
|
2024-03-06 14:34:03 +01:00 |
StorageDistributed.h
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageDummy.cpp
|
Fix more tests
|
2024-02-26 02:31:57 +08:00 |
StorageDummy.h
|
Fix something
|
2024-02-26 02:32:00 +08:00 |
StorageExecutable.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageExecutable.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageExternalDistributed.cpp
|
remove old code of projection analysis
|
2023-10-12 23:25:20 +00:00 |
StorageExternalDistributed.h
|
|
|
StorageFactory.cpp
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageFactory.h
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageFile.cpp
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageFile.h
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageFileCluster.cpp
|
Merge branch 'master' into auto-format-detection
|
2024-01-25 22:11:07 +01:00 |
StorageFileCluster.h
|
Try to detect file format automatically during schema inference if it's unknown
|
2024-01-23 18:59:39 +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
|
Revert "Add definers for views (#54901)"
|
2024-02-23 12:44:31 +01:00 |
StorageInMemoryMetadata.h
|
Revert "Add definers for views (#54901)"
|
2024-02-23 12:44:31 +01: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
|
Revert "Check stack size in Parser"
|
2024-02-21 11:33:08 +01:00 |
StorageJoin.h
|
StorageJoin: supports trivial count()
|
2023-10-19 06:30:25 +00:00 |
StorageKeeperMap.cpp
|
fix
|
2024-02-16 14:05:22 +01:00 |
StorageKeeperMap.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageLog.cpp
|
Merge pull request #60159 from ClickHouse/fix_create_replica
|
2024-02-23 13:53:47 +01:00 |
StorageLog.h
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageLogSettings.cpp
|
|
|
StorageLogSettings.h
|
Add missing includes
|
2024-01-13 01:48:55 +03:00 |
StorageMaterializedMySQL.cpp
|
|
|
StorageMaterializedMySQL.h
|
Style fix
|
2023-08-14 12:30:29 +04:00 |
StorageMaterializedView.cpp
|
Merge pull request #60350 from ClickHouse/revert-54901-pufit/views-sql-security
|
2024-02-23 15:15:36 +01:00 |
StorageMaterializedView.h
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageMemory.cpp
|
Unify prewhere optimization
|
2024-02-26 02:31:56 +08:00 |
StorageMemory.h
|
allow ALTER for TEMPORARY table
|
2023-11-30 21:42:12 +03:00 |
StorageMerge.cpp
|
Better name
|
2024-02-26 02:32:00 +08:00 |
StorageMerge.h
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageMergeTree.cpp
|
Revert "Merge pull request #56864 from ClickHouse/broken-projections-better-handling"
|
2024-02-27 00:13:28 +01:00 |
StorageMergeTree.h
|
Merge pull request #60159 from ClickHouse/fix_create_replica
|
2024-02-23 13:53:47 +01: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
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageMySQL.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageNull.cpp
|
Minor code cleanup: remove some redundant includes of InterpreterAlterQuery.h
|
2023-08-23 14:16:36 +00:00 |
StorageNull.h
|
fix: StorageNull supports subcolumns
|
2023-10-22 16:24:01 +08:00 |
StoragePostgreSQL.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StoragePostgreSQL.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageProxy.h
|
Merge remote-tracking branch 'upstream/master' into HEAD
|
2024-01-03 16:01:44 +00:00 |
StorageRedis.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageRedis.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
StorageReplicatedMergeTree.cpp
|
Revert "Merge pull request #56864 from ClickHouse/broken-projections-better-handling"
|
2024-02-27 00:13:28 +01:00 |
StorageReplicatedMergeTree.h
|
Merge pull request #60159 from ClickHouse/fix_create_replica
|
2024-02-23 13:53:47 +01:00 |
StorageS3.cpp
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageS3.h
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageS3Cluster.cpp
|
Merge branch 'master' into auto-format-detection
|
2024-01-25 22:11:07 +01:00 |
StorageS3Cluster.h
|
Try to detect file format automatically during schema inference if it's unknown
|
2024-01-23 18:59:39 +00:00 |
StorageS3Settings.cpp
|
Support specifying users for s3 settings
|
2024-02-19 16:43:27 +01:00 |
StorageS3Settings.h
|
Support specifying users for s3 settings
|
2024-02-19 16:43:27 +01:00 |
StorageSet.cpp
|
Updated implementation
|
2024-01-25 14:31:49 +03: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
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageSQLite.h
|
Fix INSERT into SQLite with single quote
|
2024-02-15 12:47:29 +01:00 |
StorageStripeLog.cpp
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageStripeLog.h
|
skip sanity checks on secondary create query
|
2024-02-20 21:59:28 +01:00 |
StorageTableFunction.h
|
Better shutdown
|
2023-11-06 15:47:57 +01:00 |
StorageURL.cpp
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageURL.h
|
Fix more tests
|
2024-02-26 02:31:59 +08:00 |
StorageURLCluster.cpp
|
Fix build
|
2024-01-26 15:50:16 +01:00 |
StorageURLCluster.h
|
Try to detect file format automatically during schema inference if it's unknown
|
2024-01-23 18:59:39 +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
|
Revert "Add definers for views (#54901)"
|
2024-02-23 12:44:31 +01:00 |
StorageView.h
|
Revert "Add definers for views (#54901)"
|
2024-02-23 12:44:31 +01:00 |
StorageXDBC.cpp
|
Merge branch 'master' into auto-format-detection
|
2024-01-25 22:11:07 +01:00 |
StorageXDBC.h
|
Merge branch 'master' into auto-format-detection
|
2024-01-25 22:11:07 +01:00 |
TableLockHolder.h
|
|
|
transformQueryForExternalDatabase.cpp
|
Revert "Check stack size in Parser"
|
2024-02-21 11:33:08 +01:00 |
transformQueryForExternalDatabase.h
|
Better
|
2023-08-10 06:34:10 +00:00 |
transformQueryForExternalDatabaseAnalyzer.cpp
|
Fixing 01086_odbc_roundtrip with analyzer.
|
2023-08-31 15:23:27 +00:00 |
transformQueryForExternalDatabaseAnalyzer.h
|
|
|
TTLDescription.cpp
|
Merge branch 'master' into non-ready-set-ttl
|
2024-01-13 21:11:51 +01:00 |
TTLDescription.h
|
Merge branch 'master' into non-ready-set-ttl
|
2024-01-13 21:11:51 +01:00 |
TTLMode.h
|
|
|
UVLoop.h
|
Updated implementation
|
2024-01-25 14:31:49 +03:00 |
VirtualColumnUtils.cpp
|
Forward declaration for PeekableReadBuffer
|
2024-01-30 19:24:19 +01:00 |
VirtualColumnUtils.h
|
Fixing index hint
|
2024-01-05 11:50:09 +00:00 |