Revert "CC"

This reverts commit ee194928d2.
This commit is contained in:
Ivan Lezhankin 2021-04-22 16:55:18 +03:00
parent afd6639e46
commit d9626e73c3
106 changed files with 133 additions and 56 deletions

View File

@ -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
{

View File

@ -15,6 +15,7 @@
namespace DB
{
class Context;
class IDataType;
using DataTypePtr = std::shared_ptr<const IDataType>;

View File

@ -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.

View File

@ -11,6 +11,8 @@ namespace DB
class ExpressionActions;
using ExpressionActionsPtr = std::shared_ptr<ExpressionActions>;
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)

View File

@ -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

View File

@ -13,6 +13,8 @@
namespace DB
{
class Context;
class Throttler;
using ThrottlerPtr = std::shared_ptr<Throttler>;

View File

@ -9,6 +9,7 @@ namespace DB
class DatabaseLazyIterator;
class Context;
/** Lazy engine of databases.
* Works like DatabaseOrdinary, but stores in memory only cache.

View File

@ -10,6 +10,8 @@
namespace DB
{
class Context;
std::pair<String, StoragePtr> createTableFromAST(
ASTCreateQuery ast_create_query,
const String & database_name,

View File

@ -6,6 +6,7 @@
namespace DB
{
class Context;
class ExternalDictionariesLoader;

View File

@ -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
{

View File

@ -23,6 +23,8 @@
namespace DB
{
class Context;
enum class MySQLDataTypesSupport;
/** Real-time access to table list and table structure from remote MySQL

View File

@ -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.

View File

@ -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

View File

@ -10,6 +10,8 @@
namespace DB
{
class Context;
namespace ErrorCodes
{
extern const int ILLEGAL_COLUMN;

View File

@ -18,6 +18,11 @@ namespace Aws::Http::Standard
class StandardHttpResponse;
}
namespace DB
{
class Context;
}
namespace DB::S3
{
class ClientFactory;

View File

@ -8,7 +8,7 @@
namespace DB
{
class Context;
using DatabaseAndTable = std::pair<DatabasePtr, StoragePtr>;
class AccessRightsElements;

View File

@ -9,6 +9,8 @@
namespace DB
{
class Context;
class InterpreterFactory
{
public:

View File

@ -22,6 +22,7 @@ namespace DB
struct SubqueryForSet;
class InterpreterSelectWithUnionQuery;
class Context;
class QueryPlan;
struct TreeRewriterResult;

View File

@ -8,6 +8,7 @@
namespace DB
{
class AccessControlManager;
class Context;
class AccessRightsElements;
struct IAccessEntity;
using AccessEntityPtr = std::shared_ptr<const IAccessEntity>;

View File

@ -6,6 +6,7 @@
namespace DB
{
class Context;
class InterpreterShowPrivilegesQuery : public IInterpreter
{

View File

@ -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.
*/

View File

@ -13,6 +13,7 @@ namespace Poco { class Logger; }
namespace DB
{
class Context;
class AccessRightsElements;
class ASTSystemQuery;

View File

@ -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

View File

@ -12,6 +12,7 @@
namespace DB
{
class Context;
class QueryPlan;
class QueryPipeline;

View File

@ -12,6 +12,7 @@ namespace DB
class ASTSelectQuery;
class ASTIdentifier;
struct ASTTablesInSelectQueryElement;
class Context;
class QueryNormalizer

View File

@ -16,6 +16,7 @@ namespace DB
struct Range;
class Context;
class IFunctionBase;
using FunctionBasePtr = std::shared_ptr<IFunctionBase>;

View File

@ -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

View File

@ -18,6 +18,7 @@
namespace DB
{
class Context;
class ASTSelectQuery;
struct DatabaseAndTableWithAlias;
class Block;

View File

@ -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.

View File

@ -9,6 +9,7 @@ namespace DB
{
class WriteBuffer;
class Context;
/** Prints the result in the form of beautiful tables.

View File

@ -9,6 +9,7 @@ namespace DB
{
class WriteBuffer;
class Context;
/** Stream to output data in format "each value in separate row".

View File

@ -11,6 +11,8 @@
namespace DB
{
class Context;
class HTTPServer : public Poco::Net::TCPServer
{
public:

View File

@ -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.

View File

@ -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<AlterCommand>
{

View File

@ -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.

View File

@ -13,6 +13,7 @@
namespace DB
{
class Context;
class IFunction;
using FunctionBasePtr = std::shared_ptr<IFunctionBase>;
class ExpressionActions;

View File

@ -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.

View File

@ -12,6 +12,7 @@
namespace DB
{
class Context;
class WriteBuffer;
class ReadBuffer;

View File

@ -12,6 +12,7 @@ namespace DB
* common prefix, which is needed for
* performing reading in order of PK.
*/
class Context;
class ReadInOrderOptimizer
{

View File

@ -14,6 +14,8 @@ namespace rocksdb
namespace DB
{
class Context;
class StorageEmbeddedRocksDB final : public ext::shared_ptr_helper<StorageEmbeddedRocksDB>, public IStorage
{
friend struct ext::shared_ptr_helper<StorageEmbeddedRocksDB>;

View File

@ -19,6 +19,7 @@ namespace DB
{
struct Settings;
class Context;
class IVolume;
using VolumePtr = std::shared_ptr<IVolume>;

View File

@ -13,6 +13,7 @@
namespace DB
{
class Context;
class ASTCreateQuery;
class ASTStorage;
struct StorageID;

View File

@ -18,6 +18,8 @@
namespace DB
{
class Context;
struct ClientAuthentificationBuilder
{
String access_key_id;

View File

@ -9,6 +9,8 @@
namespace DB
{
class Context;
/** Base class for system tables whose all columns have String type.
*/

View File

@ -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.

View File

@ -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<StorageSystemBuildOptions>, public IStorageSystemOneBlock<StorageSystemBuildOptions>

View File

@ -9,6 +9,7 @@
namespace DB
{
class Context;
class Cluster;
/** Implements system table 'clusters'

View File

@ -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<StorageSystemColumns>, public IStorage

View File

@ -6,6 +6,8 @@
namespace DB
{
class Context;
/** System table "contributors" with list of clickhouse contributors
*/

View File

@ -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<StorageSystemCurrentRoles>, public IStorageSystemOneBlock<StorageSystemCurrentRoles>

View File

@ -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.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements `databases` system table, which allows you to get information about all databases.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
class StorageSystemDictionaries final : public ext::shared_ptr_helper<StorageSystemDictionaries>, public IStorageSystemOneBlock<StorageSystemDictionaries>

View File

@ -9,7 +9,7 @@
namespace DB
{
class Context;
/** Implements the system table `disks`, which allows you to get information about all disks.

View File

@ -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.

View File

@ -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<StorageSystemEnabledRoles>, public IStorageSystemOneBlock<StorageSystemEnabledRoles>

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/**

View File

@ -6,7 +6,7 @@
namespace DB
{
class Context;
/** Implements `events` system table, which allows you to obtain information for profiling.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements `functions`system table, which allows you to get a list

View File

@ -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<StorageSystemGrants>, public IStorageSystemOneBlock<StorageSystemGrants>

View File

@ -6,7 +6,7 @@
namespace DB
{
class Context;
/** System table "licenses" with list of licenses of 3rd party libraries

View File

@ -8,7 +8,7 @@
namespace DB
{
class Context;
/** Information about macros for introspection.

View File

@ -8,7 +8,7 @@
namespace DB
{
class Context;
/** implements system table "merge_tree_settings" and "replicated_merge_tree_settings",

View File

@ -10,7 +10,7 @@
namespace DB
{
class Context;
class StorageSystemMerges final : public ext::shared_ptr_helper<StorageSystemMerges>, public IStorageSystemOneBlock<StorageSystemMerges>

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements `metrics` system table, which provides information about the operation of the server.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
class StorageSystemModels final : public ext::shared_ptr_helper<StorageSystemModels>, public IStorageSystemOneBlock<StorageSystemModels>

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/// Implements the `mutations` system table, which provides information about the status of mutations

View File

@ -8,7 +8,7 @@
namespace DB
{
class Context;
/** Implements a table engine for the system table "numbers".

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements storage for the system table One.

View File

@ -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.

View File

@ -9,7 +9,7 @@
namespace DB
{
class Context;
struct StoragesInfo
{

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements system table 'parts_columns' which allows to get information about

View File

@ -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<StorageSystemPrivileges>, public IStorageSystemOneBlock<StorageSystemPrivileges>

View File

@ -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.

View File

@ -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<StorageSystemQuotaLimits>, public IStorageSystemOneBlock<StorageSystemQuotaLimits>

View File

@ -6,7 +6,7 @@
namespace DB
{
class Context;
struct QuotaUsage;

View File

@ -6,7 +6,7 @@
namespace DB
{
class Context;
/** Implements the `quotas` system tables, which allows you to get information about quotas.
*/

View File

@ -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.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements `replicas` system table, which provides information about the status of the replicated tables.

View File

@ -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<StorageSystemReplicatedFetches>, public IStorageSystemOneBlock<StorageSystemReplicatedFetches >

View File

@ -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.

View File

@ -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<StorageSystemRoleGrants>, public IStorageSystemOneBlock<StorageSystemRoleGrants>

View File

@ -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<StorageSystemRoles>, public IStorageSystemOneBlock<StorageSystemRoles>

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/// Implements `row_policies` system table, which allows you to get information about row policies.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** implements system table "settings", which allows to get information about the current settings.

View File

@ -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<StorageSystemSettingsProfileElements>, public IStorageSystemOneBlock<StorageSystemSettingsProfileElements>

View File

@ -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<StorageSystemSettingsProfiles>, public IStorageSystemOneBlock<StorageSystemSettingsProfiles>

View File

@ -14,7 +14,7 @@ class Logger;
namespace DB
{
class Context;
/// Allows to introspect stack trace of all server threads.

View File

@ -9,7 +9,7 @@
namespace DB
{
class Context;
/** Implements the system table `storage`, which allows you to get information about all disks.

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements the system table `tables`, which allows you to get information about all tables.

View File

@ -6,7 +6,7 @@
namespace DB
{
class Context;
/** System table "time_zones" with list of timezones pulled from /contrib/cctz/testdata/zoneinfo

View File

@ -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<StorageSystemUserDirectories>, public IStorageSystemOneBlock<StorageSystemUserDirectories>

View File

@ -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<StorageSystemUsers>, public IStorageSystemOneBlock<StorageSystemUsers>

View File

@ -7,7 +7,7 @@
namespace DB
{
class Context;
/** Implements `zookeeper` system table, which allows you to view the data in ZooKeeper for debugging purposes.

View File

@ -6,6 +6,7 @@
namespace DB
{
class Context;
class AsynchronousMetrics;
class IDatabase;

View File

@ -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.

View File

@ -11,7 +11,7 @@
namespace DB
{
class Context;
/** Interface for table functions.
*

View File

@ -5,7 +5,7 @@
namespace DB
{
class ColumnsDescription;
class Context;
/*
* function(source, format, structure) - creates a temporary storage from formatted source

View File

@ -4,7 +4,7 @@
namespace DB
{
class Context;
/* file(path, format, structure) - creates a temporary storage from file
*

View File

@ -15,7 +15,7 @@
namespace DB
{
class Context;
using TableFunctionCreator = std::function<TableFunctionPtr()>;

Some files were not shown because too many files have changed in this diff Show More