diff --git a/programs/odbc-bridge/SchemaAllowedHandler.h b/programs/odbc-bridge/SchemaAllowedHandler.h index c4d5f85cff9..d7b922ed05b 100644 --- a/programs/odbc-bridge/SchemaAllowedHandler.h +++ b/programs/odbc-bridge/SchemaAllowedHandler.h @@ -10,6 +10,8 @@ namespace DB { +class Context; + /// This handler establishes connection to database, and retrieves whether schema is allowed. class SchemaAllowedHandler : public HTTPRequestHandler, WithContext { diff --git a/src/AggregateFunctions/AggregateFunctionFactory.h b/src/AggregateFunctions/AggregateFunctionFactory.h index 380b27ed804..d308a5f559b 100644 --- a/src/AggregateFunctions/AggregateFunctionFactory.h +++ b/src/AggregateFunctions/AggregateFunctionFactory.h @@ -15,6 +15,7 @@ namespace DB { +class Context; class IDataType; using DataTypePtr = std::shared_ptr; diff --git a/src/Common/Config/ConfigReloader.h b/src/Common/Config/ConfigReloader.h index f25135925be..2e4399d3c4e 100644 --- a/src/Common/Config/ConfigReloader.h +++ b/src/Common/Config/ConfigReloader.h @@ -17,6 +17,8 @@ namespace Poco { class Logger; } namespace DB { +class Context; + /** Every two seconds checks configuration files for update. * If configuration is changed, then config will be reloaded by ConfigProcessor * and the reloaded config will be applied via Updater functor. diff --git a/src/DataStreams/AddingDefaultBlockOutputStream.h b/src/DataStreams/AddingDefaultBlockOutputStream.h index 440ec8df3ad..a8235d6623a 100644 --- a/src/DataStreams/AddingDefaultBlockOutputStream.h +++ b/src/DataStreams/AddingDefaultBlockOutputStream.h @@ -11,6 +11,8 @@ namespace DB class ExpressionActions; using ExpressionActionsPtr = std::shared_ptr; +class Context; + /** This stream adds three types of columns into block * 1. Columns, that are missed inside request, but present in table without defaults (missed columns) * 2. Columns, that are missed inside request, but present in table with defaults (columns with default values) diff --git a/src/DataStreams/RemoteBlockInputStream.h b/src/DataStreams/RemoteBlockInputStream.h index 5de8b357c67..b0029da91bb 100644 --- a/src/DataStreams/RemoteBlockInputStream.h +++ b/src/DataStreams/RemoteBlockInputStream.h @@ -15,6 +15,8 @@ namespace DB { +class Context; + /** This class allows one to launch queries on remote replicas of one shard and get results */ class RemoteBlockInputStream : public IBlockInputStream diff --git a/src/DataStreams/RemoteQueryExecutor.h b/src/DataStreams/RemoteQueryExecutor.h index 271a269d588..a9cffd9cf97 100644 --- a/src/DataStreams/RemoteQueryExecutor.h +++ b/src/DataStreams/RemoteQueryExecutor.h @@ -13,6 +13,8 @@ namespace DB { +class Context; + class Throttler; using ThrottlerPtr = std::shared_ptr; diff --git a/src/Databases/DatabaseLazy.h b/src/Databases/DatabaseLazy.h index a8070a8a510..99a71b342fa 100644 --- a/src/Databases/DatabaseLazy.h +++ b/src/Databases/DatabaseLazy.h @@ -9,6 +9,7 @@ namespace DB class DatabaseLazyIterator; +class Context; /** Lazy engine of databases. * Works like DatabaseOrdinary, but stores in memory only cache. diff --git a/src/Databases/DatabaseOnDisk.h b/src/Databases/DatabaseOnDisk.h index c219dfb7206..677465e306e 100644 --- a/src/Databases/DatabaseOnDisk.h +++ b/src/Databases/DatabaseOnDisk.h @@ -10,6 +10,8 @@ namespace DB { +class Context; + std::pair createTableFromAST( ASTCreateQuery ast_create_query, const String & database_name, diff --git a/src/Databases/DatabaseWithDictionaries.h b/src/Databases/DatabaseWithDictionaries.h index 5a133d41e9b..d10908c7c06 100644 --- a/src/Databases/DatabaseWithDictionaries.h +++ b/src/Databases/DatabaseWithDictionaries.h @@ -6,6 +6,7 @@ namespace DB { +class Context; class ExternalDictionariesLoader; diff --git a/src/Databases/DatabasesCommon.h b/src/Databases/DatabasesCommon.h index 10138289063..da1bd6c1852 100644 --- a/src/Databases/DatabasesCommon.h +++ b/src/Databases/DatabasesCommon.h @@ -13,6 +13,8 @@ namespace DB { +class Context; + /// A base class for databases that manage their own list of tables. class DatabaseWithOwnTablesBase : public IDatabase, protected WithContext { diff --git a/src/Databases/MySQL/DatabaseConnectionMySQL.h b/src/Databases/MySQL/DatabaseConnectionMySQL.h index 6cdfee77c33..7e81003e9a9 100644 --- a/src/Databases/MySQL/DatabaseConnectionMySQL.h +++ b/src/Databases/MySQL/DatabaseConnectionMySQL.h @@ -23,6 +23,8 @@ namespace DB { +class Context; + enum class MySQLDataTypesSupport; /** Real-time access to table list and table structure from remote MySQL diff --git a/src/Databases/PostgreSQL/DatabasePostgreSQL.h b/src/Databases/PostgreSQL/DatabasePostgreSQL.h index ec4428caf92..3505c38e499 100644 --- a/src/Databases/PostgreSQL/DatabasePostgreSQL.h +++ b/src/Databases/PostgreSQL/DatabasePostgreSQL.h @@ -15,6 +15,8 @@ namespace DB { +class Context; + /** Real-time access to table list and table structure from remote PostgreSQL. * All tables are created after pull-out structure from remote PostgreSQL. diff --git a/src/Formats/FormatSchemaInfo.h b/src/Formats/FormatSchemaInfo.h index 78012f515a4..67f1baca84b 100644 --- a/src/Formats/FormatSchemaInfo.h +++ b/src/Formats/FormatSchemaInfo.h @@ -4,6 +4,7 @@ namespace DB { +class Context; /// Extracts information about where the format schema file is from passed context and keep it. class FormatSchemaInfo diff --git a/src/Functions/array/arrayScalarProduct.h b/src/Functions/array/arrayScalarProduct.h index c70ae96d0fa..6a23d6a45d8 100644 --- a/src/Functions/array/arrayScalarProduct.h +++ b/src/Functions/array/arrayScalarProduct.h @@ -10,6 +10,8 @@ namespace DB { +class Context; + namespace ErrorCodes { extern const int ILLEGAL_COLUMN; diff --git a/src/IO/S3/PocoHTTPClient.h b/src/IO/S3/PocoHTTPClient.h index 7afb95af552..34b8ea801bd 100644 --- a/src/IO/S3/PocoHTTPClient.h +++ b/src/IO/S3/PocoHTTPClient.h @@ -18,6 +18,11 @@ namespace Aws::Http::Standard class StandardHttpResponse; } +namespace DB +{ +class Context; +} + namespace DB::S3 { class ClientFactory; diff --git a/src/Interpreters/InterpreterDropQuery.h b/src/Interpreters/InterpreterDropQuery.h index d55aeecc199..8e8d577deec 100644 --- a/src/Interpreters/InterpreterDropQuery.h +++ b/src/Interpreters/InterpreterDropQuery.h @@ -8,7 +8,7 @@ namespace DB { - +class Context; using DatabaseAndTable = std::pair; class AccessRightsElements; diff --git a/src/Interpreters/InterpreterFactory.h b/src/Interpreters/InterpreterFactory.h index 56fe5b8ca09..c122fe11b7d 100644 --- a/src/Interpreters/InterpreterFactory.h +++ b/src/Interpreters/InterpreterFactory.h @@ -9,6 +9,8 @@ namespace DB { +class Context; + class InterpreterFactory { public: diff --git a/src/Interpreters/InterpreterSelectQuery.h b/src/Interpreters/InterpreterSelectQuery.h index 5f4dac94406..66b3fc65eff 100644 --- a/src/Interpreters/InterpreterSelectQuery.h +++ b/src/Interpreters/InterpreterSelectQuery.h @@ -22,6 +22,7 @@ namespace DB struct SubqueryForSet; class InterpreterSelectWithUnionQuery; +class Context; class QueryPlan; struct TreeRewriterResult; diff --git a/src/Interpreters/InterpreterShowCreateAccessEntityQuery.h b/src/Interpreters/InterpreterShowCreateAccessEntityQuery.h index 67e1bf9395f..6d026d2b81b 100644 --- a/src/Interpreters/InterpreterShowCreateAccessEntityQuery.h +++ b/src/Interpreters/InterpreterShowCreateAccessEntityQuery.h @@ -8,6 +8,7 @@ namespace DB { class AccessControlManager; +class Context; class AccessRightsElements; struct IAccessEntity; using AccessEntityPtr = std::shared_ptr; diff --git a/src/Interpreters/InterpreterShowPrivilegesQuery.h b/src/Interpreters/InterpreterShowPrivilegesQuery.h index c563600b1ca..75989263405 100644 --- a/src/Interpreters/InterpreterShowPrivilegesQuery.h +++ b/src/Interpreters/InterpreterShowPrivilegesQuery.h @@ -6,6 +6,7 @@ namespace DB { +class Context; class InterpreterShowPrivilegesQuery : public IInterpreter { diff --git a/src/Interpreters/InterpreterShowTablesQuery.h b/src/Interpreters/InterpreterShowTablesQuery.h index f927270b59f..b61be568e35 100644 --- a/src/Interpreters/InterpreterShowTablesQuery.h +++ b/src/Interpreters/InterpreterShowTablesQuery.h @@ -7,6 +7,9 @@ namespace DB { +class Context; + + /** Return a list of tables or databases meets specified conditions. * Interprets a query through replacing it to SELECT query from system.tables or system.databases. */ diff --git a/src/Interpreters/InterpreterSystemQuery.h b/src/Interpreters/InterpreterSystemQuery.h index 9ccfb396904..d9f9e6c5d96 100644 --- a/src/Interpreters/InterpreterSystemQuery.h +++ b/src/Interpreters/InterpreterSystemQuery.h @@ -13,6 +13,7 @@ namespace Poco { class Logger; } namespace DB { +class Context; class AccessRightsElements; class ASTSystemQuery; diff --git a/src/Interpreters/JoinToSubqueryTransformVisitor.h b/src/Interpreters/JoinToSubqueryTransformVisitor.h index f7695738dfa..a024a168509 100644 --- a/src/Interpreters/JoinToSubqueryTransformVisitor.h +++ b/src/Interpreters/JoinToSubqueryTransformVisitor.h @@ -8,6 +8,7 @@ namespace DB { class ASTSelectQuery; +class Context; /// AST transformer. It replaces multiple joins to (subselect + join) track. /// 'select * from t1 join t2 on ... join t3 on ... join t4 on ...' would be rewritten with diff --git a/src/Interpreters/MutationsInterpreter.h b/src/Interpreters/MutationsInterpreter.h index 001459830cb..34a9b61771d 100644 --- a/src/Interpreters/MutationsInterpreter.h +++ b/src/Interpreters/MutationsInterpreter.h @@ -12,6 +12,7 @@ namespace DB { +class Context; class QueryPlan; class QueryPipeline; diff --git a/src/Interpreters/QueryNormalizer.h b/src/Interpreters/QueryNormalizer.h index 36981f8b340..3dcccea1cfb 100644 --- a/src/Interpreters/QueryNormalizer.h +++ b/src/Interpreters/QueryNormalizer.h @@ -12,6 +12,7 @@ namespace DB class ASTSelectQuery; class ASTIdentifier; struct ASTTablesInSelectQueryElement; +class Context; class QueryNormalizer diff --git a/src/Interpreters/Set.h b/src/Interpreters/Set.h index 0b01cea0e45..c9bfbf0625c 100644 --- a/src/Interpreters/Set.h +++ b/src/Interpreters/Set.h @@ -16,6 +16,7 @@ namespace DB struct Range; +class Context; class IFunctionBase; using FunctionBasePtr = std::shared_ptr; diff --git a/src/Interpreters/StorageID.h b/src/Interpreters/StorageID.h index a766d19b5f9..2b2a8daa009 100644 --- a/src/Interpreters/StorageID.h +++ b/src/Interpreters/StorageID.h @@ -26,6 +26,7 @@ static constexpr char const * TABLE_WITH_UUID_NAME_PLACEHOLDER = "_"; class ASTQueryWithTableAndOutput; class ASTIdentifier; +class Context; // TODO(ilezhankin): refactor and merge |ASTTableIdentifier| struct StorageID diff --git a/src/Interpreters/TableJoin.h b/src/Interpreters/TableJoin.h index 962c5d65c74..71a27849297 100644 --- a/src/Interpreters/TableJoin.h +++ b/src/Interpreters/TableJoin.h @@ -18,6 +18,7 @@ namespace DB { +class Context; class ASTSelectQuery; struct DatabaseAndTableWithAlias; class Block; diff --git a/src/Processors/Formats/Impl/ParallelParsingInputFormat.h b/src/Processors/Formats/Impl/ParallelParsingInputFormat.h index 0433c53d658..a7ca546568a 100644 --- a/src/Processors/Formats/Impl/ParallelParsingInputFormat.h +++ b/src/Processors/Formats/Impl/ParallelParsingInputFormat.h @@ -21,6 +21,8 @@ namespace ErrorCodes extern const int LOGICAL_ERROR; } +class Context; + /** * ORDER-PRESERVING parallel parsing of data formats. * It splits original data into chunks. Then each chunk is parsed by different thread. diff --git a/src/Processors/Formats/Impl/PrettyBlockOutputFormat.h b/src/Processors/Formats/Impl/PrettyBlockOutputFormat.h index f68b47d809b..02b438d2571 100644 --- a/src/Processors/Formats/Impl/PrettyBlockOutputFormat.h +++ b/src/Processors/Formats/Impl/PrettyBlockOutputFormat.h @@ -9,6 +9,7 @@ namespace DB { class WriteBuffer; +class Context; /** Prints the result in the form of beautiful tables. diff --git a/src/Processors/Formats/Impl/VerticalRowOutputFormat.h b/src/Processors/Formats/Impl/VerticalRowOutputFormat.h index 11f693eac06..9e89f677f87 100644 --- a/src/Processors/Formats/Impl/VerticalRowOutputFormat.h +++ b/src/Processors/Formats/Impl/VerticalRowOutputFormat.h @@ -9,6 +9,7 @@ namespace DB { class WriteBuffer; +class Context; /** Stream to output data in format "each value in separate row". diff --git a/src/Server/HTTP/HTTPServer.h b/src/Server/HTTP/HTTPServer.h index 0f75259e01f..d95bdff0baa 100644 --- a/src/Server/HTTP/HTTPServer.h +++ b/src/Server/HTTP/HTTPServer.h @@ -11,6 +11,8 @@ namespace DB { +class Context; + class HTTPServer : public Poco::Net::TCPServer { public: diff --git a/src/Server/ReplicasStatusHandler.h b/src/Server/ReplicasStatusHandler.h index 10e56f00180..eda0b15ed6f 100644 --- a/src/Server/ReplicasStatusHandler.h +++ b/src/Server/ReplicasStatusHandler.h @@ -5,6 +5,7 @@ namespace DB { +class Context; class IServer; /// Replies "Ok.\n" if all replicas on this server don't lag too much. Otherwise output lag information. diff --git a/src/Storages/AlterCommands.h b/src/Storages/AlterCommands.h index 259551b0372..d6c80bc5ed4 100644 --- a/src/Storages/AlterCommands.h +++ b/src/Storages/AlterCommands.h @@ -157,6 +157,8 @@ struct AlterCommand /// Return string representation of AlterCommand::Type String alterTypeToString(const AlterCommand::Type type); +class Context; + /// Vector of AlterCommand with several additional functions class AlterCommands : public std::vector { diff --git a/src/Storages/Distributed/DistributedBlockOutputStream.h b/src/Storages/Distributed/DistributedBlockOutputStream.h index 78106fe6e10..a9425a98ebf 100644 --- a/src/Storages/Distributed/DistributedBlockOutputStream.h +++ b/src/Storages/Distributed/DistributedBlockOutputStream.h @@ -22,6 +22,7 @@ namespace Poco namespace DB { +class Context; class StorageDistributed; /** If insert_sync_ is true, the write is synchronous. Uses insert_timeout_ if it is not zero. diff --git a/src/Storages/MergeTree/KeyCondition.h b/src/Storages/MergeTree/KeyCondition.h index 60761400219..bd51769ad1f 100644 --- a/src/Storages/MergeTree/KeyCondition.h +++ b/src/Storages/MergeTree/KeyCondition.h @@ -13,6 +13,7 @@ namespace DB { +class Context; class IFunction; using FunctionBasePtr = std::shared_ptr; class ExpressionActions; diff --git a/src/Storages/MergeTree/MergeTreeData.h b/src/Storages/MergeTree/MergeTreeData.h index 6278be5319e..46c0014d9f7 100644 --- a/src/Storages/MergeTree/MergeTreeData.h +++ b/src/Storages/MergeTree/MergeTreeData.h @@ -38,6 +38,7 @@ namespace DB class AlterCommands; class MergeTreePartsMover; class MutationCommands; +class Context; struct JobAndPool; /// Auxiliary struct holding information about the future merged or mutated part. diff --git a/src/Storages/MutationCommands.h b/src/Storages/MutationCommands.h index c0f8d1ab4de..ecf819eed9b 100644 --- a/src/Storages/MutationCommands.h +++ b/src/Storages/MutationCommands.h @@ -12,6 +12,7 @@ namespace DB { +class Context; class WriteBuffer; class ReadBuffer; diff --git a/src/Storages/ReadInOrderOptimizer.h b/src/Storages/ReadInOrderOptimizer.h index ec4647b472a..0af1121db32 100644 --- a/src/Storages/ReadInOrderOptimizer.h +++ b/src/Storages/ReadInOrderOptimizer.h @@ -12,6 +12,7 @@ namespace DB * common prefix, which is needed for * performing reading in order of PK. */ +class Context; class ReadInOrderOptimizer { diff --git a/src/Storages/RocksDB/StorageEmbeddedRocksDB.h b/src/Storages/RocksDB/StorageEmbeddedRocksDB.h index f301819e0be..64255392c35 100644 --- a/src/Storages/RocksDB/StorageEmbeddedRocksDB.h +++ b/src/Storages/RocksDB/StorageEmbeddedRocksDB.h @@ -14,6 +14,8 @@ namespace rocksdb namespace DB { +class Context; + class StorageEmbeddedRocksDB final : public ext::shared_ptr_helper, public IStorage { friend struct ext::shared_ptr_helper; diff --git a/src/Storages/StorageDistributed.h b/src/Storages/StorageDistributed.h index 7981c688ab3..886a8e032de 100644 --- a/src/Storages/StorageDistributed.h +++ b/src/Storages/StorageDistributed.h @@ -19,6 +19,7 @@ namespace DB { struct Settings; +class Context; class IVolume; using VolumePtr = std::shared_ptr; diff --git a/src/Storages/StorageFactory.h b/src/Storages/StorageFactory.h index 4c0371cafcf..43f6a6d6f7d 100644 --- a/src/Storages/StorageFactory.h +++ b/src/Storages/StorageFactory.h @@ -13,6 +13,7 @@ namespace DB { +class Context; class ASTCreateQuery; class ASTStorage; struct StorageID; diff --git a/src/Storages/StorageS3Cluster.h b/src/Storages/StorageS3Cluster.h index e37f2295972..c98840d62fc 100644 --- a/src/Storages/StorageS3Cluster.h +++ b/src/Storages/StorageS3Cluster.h @@ -18,6 +18,8 @@ namespace DB { +class Context; + struct ClientAuthentificationBuilder { String access_key_id; diff --git a/src/Storages/System/IStorageSystemOneBlock.h b/src/Storages/System/IStorageSystemOneBlock.h index cc5682b3e00..36e92d5a1f4 100644 --- a/src/Storages/System/IStorageSystemOneBlock.h +++ b/src/Storages/System/IStorageSystemOneBlock.h @@ -9,6 +9,8 @@ namespace DB { +class Context; + /** Base class for system tables whose all columns have String type. */ diff --git a/src/Storages/System/StorageSystemAsynchronousMetrics.h b/src/Storages/System/StorageSystemAsynchronousMetrics.h index 59d41071cd1..eee029bbe51 100644 --- a/src/Storages/System/StorageSystemAsynchronousMetrics.h +++ b/src/Storages/System/StorageSystemAsynchronousMetrics.h @@ -7,6 +7,7 @@ namespace DB { class AsynchronousMetrics; +class Context; /** Implements system table asynchronous_metrics, which allows to get values of periodically (asynchronously) updated metrics. diff --git a/src/Storages/System/StorageSystemBuildOptions.h b/src/Storages/System/StorageSystemBuildOptions.h index e1201c76d88..8a22a3dcb45 100644 --- a/src/Storages/System/StorageSystemBuildOptions.h +++ b/src/Storages/System/StorageSystemBuildOptions.h @@ -7,6 +7,9 @@ namespace DB { +class Context; + + /** System table "build_options" with many params used for clickhouse building */ class StorageSystemBuildOptions final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemClusters.h b/src/Storages/System/StorageSystemClusters.h index e5595cd09f7..81aefaff1c4 100644 --- a/src/Storages/System/StorageSystemClusters.h +++ b/src/Storages/System/StorageSystemClusters.h @@ -9,6 +9,7 @@ namespace DB { +class Context; class Cluster; /** Implements system table 'clusters' diff --git a/src/Storages/System/StorageSystemColumns.h b/src/Storages/System/StorageSystemColumns.h index 1f6c82d2617..5cd8c5b38fd 100644 --- a/src/Storages/System/StorageSystemColumns.h +++ b/src/Storages/System/StorageSystemColumns.h @@ -7,6 +7,8 @@ namespace DB { +class Context; + /** Implements system table 'columns', that allows to get information about columns for every table. */ class StorageSystemColumns final : public ext::shared_ptr_helper, public IStorage diff --git a/src/Storages/System/StorageSystemContributors.h b/src/Storages/System/StorageSystemContributors.h index 9ea41ddba5e..c4a50263c5b 100644 --- a/src/Storages/System/StorageSystemContributors.h +++ b/src/Storages/System/StorageSystemContributors.h @@ -6,6 +6,8 @@ namespace DB { +class Context; + /** System table "contributors" with list of clickhouse contributors */ diff --git a/src/Storages/System/StorageSystemCurrentRoles.h b/src/Storages/System/StorageSystemCurrentRoles.h index 966b2f3098f..77ab95547fa 100644 --- a/src/Storages/System/StorageSystemCurrentRoles.h +++ b/src/Storages/System/StorageSystemCurrentRoles.h @@ -6,6 +6,7 @@ namespace DB { +class Context; /// Implements `current_roles` system table, which allows you to get information about current roles. class StorageSystemCurrentRoles final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemDDLWorkerQueue.h b/src/Storages/System/StorageSystemDDLWorkerQueue.h index 3518fc0524d..d1afa2d546a 100644 --- a/src/Storages/System/StorageSystemDDLWorkerQueue.h +++ b/src/Storages/System/StorageSystemDDLWorkerQueue.h @@ -10,7 +10,7 @@ namespace DB { - +class Context; /** System table "distributed_ddl_queue" with list of queries that are currently in the DDL worker queue. diff --git a/src/Storages/System/StorageSystemDatabases.h b/src/Storages/System/StorageSystemDatabases.h index f4acae71a81..33f91fee837 100644 --- a/src/Storages/System/StorageSystemDatabases.h +++ b/src/Storages/System/StorageSystemDatabases.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements `databases` system table, which allows you to get information about all databases. diff --git a/src/Storages/System/StorageSystemDictionaries.h b/src/Storages/System/StorageSystemDictionaries.h index f81d6474d70..63b33adaaff 100644 --- a/src/Storages/System/StorageSystemDictionaries.h +++ b/src/Storages/System/StorageSystemDictionaries.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; class StorageSystemDictionaries final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemDisks.h b/src/Storages/System/StorageSystemDisks.h index 177c8d6c593..fa0f6fe4b8a 100644 --- a/src/Storages/System/StorageSystemDisks.h +++ b/src/Storages/System/StorageSystemDisks.h @@ -9,7 +9,7 @@ namespace DB { - +class Context; /** Implements the system table `disks`, which allows you to get information about all disks. diff --git a/src/Storages/System/StorageSystemDistributionQueue.h b/src/Storages/System/StorageSystemDistributionQueue.h index 856bafc50a5..9314418d242 100644 --- a/src/Storages/System/StorageSystemDistributionQueue.h +++ b/src/Storages/System/StorageSystemDistributionQueue.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements the `distribution_queue` system table, which allows you to view the INSERT queues for the Distributed tables. diff --git a/src/Storages/System/StorageSystemEnabledRoles.h b/src/Storages/System/StorageSystemEnabledRoles.h index f358d0f5c28..13b0533b790 100644 --- a/src/Storages/System/StorageSystemEnabledRoles.h +++ b/src/Storages/System/StorageSystemEnabledRoles.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `enabled_roles` system table, which allows you to get information about enabled roles. class StorageSystemEnabledRoles final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemErrors.h b/src/Storages/System/StorageSystemErrors.h index fdcd8b9002b..ff3af11d251 100644 --- a/src/Storages/System/StorageSystemErrors.h +++ b/src/Storages/System/StorageSystemErrors.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** diff --git a/src/Storages/System/StorageSystemEvents.h b/src/Storages/System/StorageSystemEvents.h index d12a41b4065..6071cb7b2b3 100644 --- a/src/Storages/System/StorageSystemEvents.h +++ b/src/Storages/System/StorageSystemEvents.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /** Implements `events` system table, which allows you to obtain information for profiling. diff --git a/src/Storages/System/StorageSystemFunctions.h b/src/Storages/System/StorageSystemFunctions.h index c9d99c91e90..62942721995 100644 --- a/src/Storages/System/StorageSystemFunctions.h +++ b/src/Storages/System/StorageSystemFunctions.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements `functions`system table, which allows you to get a list diff --git a/src/Storages/System/StorageSystemGrants.h b/src/Storages/System/StorageSystemGrants.h index 22019b791e1..8c8a0f9f7bf 100644 --- a/src/Storages/System/StorageSystemGrants.h +++ b/src/Storages/System/StorageSystemGrants.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `grants` system table, which allows you to get information about grants. class StorageSystemGrants final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemLicenses.h b/src/Storages/System/StorageSystemLicenses.h index c76f49b6ea7..43bb1c20c22 100644 --- a/src/Storages/System/StorageSystemLicenses.h +++ b/src/Storages/System/StorageSystemLicenses.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /** System table "licenses" with list of licenses of 3rd party libraries diff --git a/src/Storages/System/StorageSystemMacros.h b/src/Storages/System/StorageSystemMacros.h index 899a6e139fb..298aa488265 100644 --- a/src/Storages/System/StorageSystemMacros.h +++ b/src/Storages/System/StorageSystemMacros.h @@ -8,7 +8,7 @@ namespace DB { - +class Context; /** Information about macros for introspection. diff --git a/src/Storages/System/StorageSystemMergeTreeSettings.h b/src/Storages/System/StorageSystemMergeTreeSettings.h index 70c2b953749..b02b191fb69 100644 --- a/src/Storages/System/StorageSystemMergeTreeSettings.h +++ b/src/Storages/System/StorageSystemMergeTreeSettings.h @@ -8,7 +8,7 @@ namespace DB { - +class Context; /** implements system table "merge_tree_settings" and "replicated_merge_tree_settings", diff --git a/src/Storages/System/StorageSystemMerges.h b/src/Storages/System/StorageSystemMerges.h index b6a69385d19..5898bf62825 100644 --- a/src/Storages/System/StorageSystemMerges.h +++ b/src/Storages/System/StorageSystemMerges.h @@ -10,7 +10,7 @@ namespace DB { - +class Context; class StorageSystemMerges final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemMetrics.h b/src/Storages/System/StorageSystemMetrics.h index 94e9b4ea05b..af5d32ec46b 100644 --- a/src/Storages/System/StorageSystemMetrics.h +++ b/src/Storages/System/StorageSystemMetrics.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements `metrics` system table, which provides information about the operation of the server. diff --git a/src/Storages/System/StorageSystemModels.h b/src/Storages/System/StorageSystemModels.h index 82fe623bf79..832a9d550db 100644 --- a/src/Storages/System/StorageSystemModels.h +++ b/src/Storages/System/StorageSystemModels.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; class StorageSystemModels final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemMutations.h b/src/Storages/System/StorageSystemMutations.h index ebb5482e83b..1f41ff6051b 100644 --- a/src/Storages/System/StorageSystemMutations.h +++ b/src/Storages/System/StorageSystemMutations.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /// Implements the `mutations` system table, which provides information about the status of mutations diff --git a/src/Storages/System/StorageSystemNumbers.h b/src/Storages/System/StorageSystemNumbers.h index 5acb94b5bff..708ace7a4cd 100644 --- a/src/Storages/System/StorageSystemNumbers.h +++ b/src/Storages/System/StorageSystemNumbers.h @@ -8,7 +8,7 @@ namespace DB { - +class Context; /** Implements a table engine for the system table "numbers". diff --git a/src/Storages/System/StorageSystemOne.h b/src/Storages/System/StorageSystemOne.h index a9649efc969..a14d5e15726 100644 --- a/src/Storages/System/StorageSystemOne.h +++ b/src/Storages/System/StorageSystemOne.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements storage for the system table One. diff --git a/src/Storages/System/StorageSystemParts.h b/src/Storages/System/StorageSystemParts.h index d6f6a9f7a89..d67e62049cd 100644 --- a/src/Storages/System/StorageSystemParts.h +++ b/src/Storages/System/StorageSystemParts.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements system table 'parts' which allows to get information about data parts for tables of MergeTree family. diff --git a/src/Storages/System/StorageSystemPartsBase.h b/src/Storages/System/StorageSystemPartsBase.h index 7921322ea1c..33f82d04252 100644 --- a/src/Storages/System/StorageSystemPartsBase.h +++ b/src/Storages/System/StorageSystemPartsBase.h @@ -9,7 +9,7 @@ namespace DB { - +class Context; struct StoragesInfo { diff --git a/src/Storages/System/StorageSystemPartsColumns.h b/src/Storages/System/StorageSystemPartsColumns.h index 31fecd92528..ec12a608cd1 100644 --- a/src/Storages/System/StorageSystemPartsColumns.h +++ b/src/Storages/System/StorageSystemPartsColumns.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements system table 'parts_columns' which allows to get information about diff --git a/src/Storages/System/StorageSystemPrivileges.h b/src/Storages/System/StorageSystemPrivileges.h index 1942a3319b7..618e1c91597 100644 --- a/src/Storages/System/StorageSystemPrivileges.h +++ b/src/Storages/System/StorageSystemPrivileges.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `privileges` system table, which allows you to get information about access types. class StorageSystemPrivileges final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemProcesses.h b/src/Storages/System/StorageSystemProcesses.h index b0f0045763b..4f876348a4b 100644 --- a/src/Storages/System/StorageSystemProcesses.h +++ b/src/Storages/System/StorageSystemProcesses.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements `processes` system table, which allows you to get information about the queries that are currently executing. diff --git a/src/Storages/System/StorageSystemQuotaLimits.h b/src/Storages/System/StorageSystemQuotaLimits.h index 7391c44e34a..8f496734e0f 100644 --- a/src/Storages/System/StorageSystemQuotaLimits.h +++ b/src/Storages/System/StorageSystemQuotaLimits.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `quota_limits` system table, which allows you to get information about the limits set for quotas. class StorageSystemQuotaLimits final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemQuotaUsage.h b/src/Storages/System/StorageSystemQuotaUsage.h index 9ca3f1da162..806c3eb3f4a 100644 --- a/src/Storages/System/StorageSystemQuotaUsage.h +++ b/src/Storages/System/StorageSystemQuotaUsage.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; struct QuotaUsage; diff --git a/src/Storages/System/StorageSystemQuotas.h b/src/Storages/System/StorageSystemQuotas.h index ed98e281e0f..fb74ea9b05f 100644 --- a/src/Storages/System/StorageSystemQuotas.h +++ b/src/Storages/System/StorageSystemQuotas.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /** Implements the `quotas` system tables, which allows you to get information about quotas. */ diff --git a/src/Storages/System/StorageSystemQuotasUsage.h b/src/Storages/System/StorageSystemQuotasUsage.h index c308830c3a4..1f29ea9b886 100644 --- a/src/Storages/System/StorageSystemQuotasUsage.h +++ b/src/Storages/System/StorageSystemQuotasUsage.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /** Implements the `quotas_usage` system table, which allows you to get information about * how all users use the quotas. diff --git a/src/Storages/System/StorageSystemReplicas.h b/src/Storages/System/StorageSystemReplicas.h index 56cef216e25..2352d7ccdf2 100644 --- a/src/Storages/System/StorageSystemReplicas.h +++ b/src/Storages/System/StorageSystemReplicas.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements `replicas` system table, which provides information about the status of the replicated tables. diff --git a/src/Storages/System/StorageSystemReplicatedFetches.h b/src/Storages/System/StorageSystemReplicatedFetches.h index ef7134aa91a..ed25e75eb70 100644 --- a/src/Storages/System/StorageSystemReplicatedFetches.h +++ b/src/Storages/System/StorageSystemReplicatedFetches.h @@ -8,7 +8,7 @@ namespace DB { - +class Context; /// system.replicated_fetches table. Takes data from context.getReplicatedFetchList() class StorageSystemReplicatedFetches final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemReplicationQueue.h b/src/Storages/System/StorageSystemReplicationQueue.h index 25c2f02fb28..f85f23a2b20 100644 --- a/src/Storages/System/StorageSystemReplicationQueue.h +++ b/src/Storages/System/StorageSystemReplicationQueue.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements the `replication_queue` system table, which allows you to view the replication queues for the replicated tables. diff --git a/src/Storages/System/StorageSystemRoleGrants.h b/src/Storages/System/StorageSystemRoleGrants.h index edfaac6ceec..a290dcf320d 100644 --- a/src/Storages/System/StorageSystemRoleGrants.h +++ b/src/Storages/System/StorageSystemRoleGrants.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `role_grants` system table, which allows you to get information about granted roles. class StorageSystemRoleGrants final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemRoles.h b/src/Storages/System/StorageSystemRoles.h index 13347784124..38c7ed05f1e 100644 --- a/src/Storages/System/StorageSystemRoles.h +++ b/src/Storages/System/StorageSystemRoles.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `roles` system table, which allows you to get information about roles. class StorageSystemRoles final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemRowPolicies.h b/src/Storages/System/StorageSystemRowPolicies.h index b78f1ca74df..3b9ebfcc25a 100644 --- a/src/Storages/System/StorageSystemRowPolicies.h +++ b/src/Storages/System/StorageSystemRowPolicies.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /// Implements `row_policies` system table, which allows you to get information about row policies. diff --git a/src/Storages/System/StorageSystemSettings.h b/src/Storages/System/StorageSystemSettings.h index 44dfdc9d5f6..d93c09d3f80 100644 --- a/src/Storages/System/StorageSystemSettings.h +++ b/src/Storages/System/StorageSystemSettings.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** implements system table "settings", which allows to get information about the current settings. diff --git a/src/Storages/System/StorageSystemSettingsProfileElements.h b/src/Storages/System/StorageSystemSettingsProfileElements.h index 6887acf9fc4..2262ea96dde 100644 --- a/src/Storages/System/StorageSystemSettingsProfileElements.h +++ b/src/Storages/System/StorageSystemSettingsProfileElements.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `settings_profile_elements` system table, which allows you to get information about elements of settings profiles. class StorageSystemSettingsProfileElements final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemSettingsProfiles.h b/src/Storages/System/StorageSystemSettingsProfiles.h index a27d855882f..580430dc28b 100644 --- a/src/Storages/System/StorageSystemSettingsProfiles.h +++ b/src/Storages/System/StorageSystemSettingsProfiles.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `settings_profiles` system table, which allows you to get information about profiles. class StorageSystemSettingsProfiles final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemStackTrace.h b/src/Storages/System/StorageSystemStackTrace.h index 15f6580025b..7f10e309775 100644 --- a/src/Storages/System/StorageSystemStackTrace.h +++ b/src/Storages/System/StorageSystemStackTrace.h @@ -14,7 +14,7 @@ class Logger; namespace DB { - +class Context; /// Allows to introspect stack trace of all server threads. diff --git a/src/Storages/System/StorageSystemStoragePolicies.h b/src/Storages/System/StorageSystemStoragePolicies.h index e0073adabf1..70053ebc1bc 100644 --- a/src/Storages/System/StorageSystemStoragePolicies.h +++ b/src/Storages/System/StorageSystemStoragePolicies.h @@ -9,7 +9,7 @@ namespace DB { - +class Context; /** Implements the system table `storage`, which allows you to get information about all disks. diff --git a/src/Storages/System/StorageSystemTables.h b/src/Storages/System/StorageSystemTables.h index 079a6c89d00..da5e236b33f 100644 --- a/src/Storages/System/StorageSystemTables.h +++ b/src/Storages/System/StorageSystemTables.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements the system table `tables`, which allows you to get information about all tables. diff --git a/src/Storages/System/StorageSystemTimeZones.h b/src/Storages/System/StorageSystemTimeZones.h index f59338b2067..0f68b2de293 100644 --- a/src/Storages/System/StorageSystemTimeZones.h +++ b/src/Storages/System/StorageSystemTimeZones.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /** System table "time_zones" with list of timezones pulled from /contrib/cctz/testdata/zoneinfo diff --git a/src/Storages/System/StorageSystemUserDirectories.h b/src/Storages/System/StorageSystemUserDirectories.h index bf9ba1faef9..0ddb0ad49d8 100644 --- a/src/Storages/System/StorageSystemUserDirectories.h +++ b/src/Storages/System/StorageSystemUserDirectories.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `users_directories` system table, which allows you to get information about user directories. class StorageSystemUserDirectories final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemUsers.h b/src/Storages/System/StorageSystemUsers.h index be9d3588c7a..3c463a23db9 100644 --- a/src/Storages/System/StorageSystemUsers.h +++ b/src/Storages/System/StorageSystemUsers.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /// Implements `users` system table, which allows you to get information about users. class StorageSystemUsers final : public ext::shared_ptr_helper, public IStorageSystemOneBlock diff --git a/src/Storages/System/StorageSystemZooKeeper.h b/src/Storages/System/StorageSystemZooKeeper.h index deea6a719ee..226ca79facf 100644 --- a/src/Storages/System/StorageSystemZooKeeper.h +++ b/src/Storages/System/StorageSystemZooKeeper.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /** Implements `zookeeper` system table, which allows you to view the data in ZooKeeper for debugging purposes. diff --git a/src/Storages/System/attachSystemTables.h b/src/Storages/System/attachSystemTables.h index c0f572bfbad..71570506a1a 100644 --- a/src/Storages/System/attachSystemTables.h +++ b/src/Storages/System/attachSystemTables.h @@ -6,6 +6,7 @@ namespace DB { +class Context; class AsynchronousMetrics; class IDatabase; diff --git a/src/Storages/getStructureOfRemoteTable.h b/src/Storages/getStructureOfRemoteTable.h index 52eff16de2b..3f77236c756 100644 --- a/src/Storages/getStructureOfRemoteTable.h +++ b/src/Storages/getStructureOfRemoteTable.h @@ -8,7 +8,7 @@ namespace DB { - +class Context; struct StorageID; /// Find the names and types of the table columns on any server in the cluster. diff --git a/src/TableFunctions/ITableFunction.h b/src/TableFunctions/ITableFunction.h index 54ffd55bb3c..56147ffd598 100644 --- a/src/TableFunctions/ITableFunction.h +++ b/src/TableFunctions/ITableFunction.h @@ -11,7 +11,7 @@ namespace DB { - +class Context; /** Interface for table functions. * diff --git a/src/TableFunctions/ITableFunctionFileLike.h b/src/TableFunctions/ITableFunctionFileLike.h index 14bccf97fd5..7c96ce610b3 100644 --- a/src/TableFunctions/ITableFunctionFileLike.h +++ b/src/TableFunctions/ITableFunctionFileLike.h @@ -5,7 +5,7 @@ namespace DB { class ColumnsDescription; - +class Context; /* * function(source, format, structure) - creates a temporary storage from formatted source diff --git a/src/TableFunctions/TableFunctionDictionary.h b/src/TableFunctions/TableFunctionDictionary.h index 67d3fe8cb1d..aed435bebfd 100644 --- a/src/TableFunctions/TableFunctionDictionary.h +++ b/src/TableFunctions/TableFunctionDictionary.h @@ -4,7 +4,7 @@ namespace DB { - +class Context; /* file(path, format, structure) - creates a temporary storage from file * diff --git a/src/TableFunctions/TableFunctionFactory.h b/src/TableFunctions/TableFunctionFactory.h index 4b00a8509cd..59b4ffb9fd5 100644 --- a/src/TableFunctions/TableFunctionFactory.h +++ b/src/TableFunctions/TableFunctionFactory.h @@ -15,7 +15,7 @@ namespace DB { - +class Context; using TableFunctionCreator = std::function; diff --git a/src/TableFunctions/TableFunctionHDFS.h b/src/TableFunctions/TableFunctionHDFS.h index 2d4ff3bcc22..d9ee9b47868 100644 --- a/src/TableFunctions/TableFunctionHDFS.h +++ b/src/TableFunctions/TableFunctionHDFS.h @@ -10,7 +10,7 @@ namespace DB { - +class Context; /* hdfs(name_node_ip:name_node_port, format, structure) - creates a temporary storage from hdfs file * diff --git a/src/TableFunctions/TableFunctionInput.h b/src/TableFunctions/TableFunctionInput.h index e640544a4f2..5953693e711 100644 --- a/src/TableFunctions/TableFunctionInput.h +++ b/src/TableFunctions/TableFunctionInput.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /* input(structure) - allows to make INSERT SELECT from incoming stream of data */ diff --git a/src/TableFunctions/TableFunctionS3.h b/src/TableFunctions/TableFunctionS3.h index 361afb09cc6..1835fa3daa9 100644 --- a/src/TableFunctions/TableFunctionS3.h +++ b/src/TableFunctions/TableFunctionS3.h @@ -10,7 +10,7 @@ namespace DB { - +class Context; /* s3(source, [access_key_id, secret_access_key,] format, structure) - creates a temporary storage for a file in S3 */ diff --git a/src/TableFunctions/TableFunctionS3Cluster.h b/src/TableFunctions/TableFunctionS3Cluster.h index 81d83e5231e..cc857725ce6 100644 --- a/src/TableFunctions/TableFunctionS3Cluster.h +++ b/src/TableFunctions/TableFunctionS3Cluster.h @@ -10,7 +10,7 @@ namespace DB { - +class Context; /** * s3Cluster(cluster_name, source, [access_key_id, secret_access_key,] format, structure) diff --git a/src/TableFunctions/TableFunctionURL.h b/src/TableFunctions/TableFunctionURL.h index e9b0abed8b5..fde361e8bbb 100644 --- a/src/TableFunctions/TableFunctionURL.h +++ b/src/TableFunctions/TableFunctionURL.h @@ -6,7 +6,7 @@ namespace DB { - +class Context; /* url(source, format, structure) - creates a temporary storage from url */ diff --git a/src/TableFunctions/parseColumnsListForTableFunction.h b/src/TableFunctions/parseColumnsListForTableFunction.h index 2fb43cee099..e0130a2618d 100644 --- a/src/TableFunctions/parseColumnsListForTableFunction.h +++ b/src/TableFunctions/parseColumnsListForTableFunction.h @@ -7,7 +7,7 @@ namespace DB { - +class Context; /// Parses a common argument for table functions such as table structure given in string ColumnsDescription parseColumnsListFromString(const std::string & structure, ContextPtr context);