Search in sources :

Example 1 with InformationSchemaConnector

use of io.prestosql.connector.informationschema.InformationSchemaConnector in project hetu-core by openlookeng.

the class TestTransactionManager method registerConnector.

private static void registerConnector(CatalogManager catalogManager, TransactionManager transactionManager, String catalogName, CatalogName catalog, Connector connector) {
    CatalogName systemId = createSystemTablesCatalogName(catalog);
    InternalNodeManager nodeManager = new InMemoryNodeManager();
    Metadata metadata = createTestMetadataManager(catalogManager);
    catalogManager.registerCatalog(new Catalog(catalogName, catalog, connector, createInformationSchemaCatalogName(catalog), new InformationSchemaConnector(catalogName, nodeManager, metadata, new AllowAllAccessControl()), systemId, new SystemConnector(nodeManager, connector.getSystemTables(), transactionId -> transactionManager.getConnectorTransaction(transactionId, catalog))));
}
Also used : SystemConnector(io.prestosql.connector.system.SystemConnector) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) InternalNodeManager(io.prestosql.metadata.InternalNodeManager) AllowAllAccessControl(io.prestosql.security.AllowAllAccessControl) ConnectorMetadata(io.prestosql.spi.connector.ConnectorMetadata) Metadata(io.prestosql.metadata.Metadata) CatalogName.createSystemTablesCatalogName(io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName) CatalogName.createInformationSchemaCatalogName(io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName) CatalogName(io.prestosql.spi.connector.CatalogName) Catalog(io.prestosql.metadata.Catalog) InMemoryNodeManager(io.prestosql.metadata.InMemoryNodeManager)

Example 2 with InformationSchemaConnector

use of io.prestosql.connector.informationschema.InformationSchemaConnector in project hetu-core by openlookeng.

the class TestAccessControlManager method registerBogusConnector.

private static CatalogName registerBogusConnector(CatalogManager catalogManager, TransactionManager transactionManager, AccessControl accessControl, String catalogName) {
    CatalogName catalog = new CatalogName(catalogName);
    Connector connector = new TpchConnectorFactory().create(catalogName, ImmutableMap.of(), new TestingConnectorContext());
    InMemoryNodeManager nodeManager = new InMemoryNodeManager();
    Metadata metadata = createTestMetadataManager(catalogManager);
    CatalogName systemId = createSystemTablesCatalogName(catalog);
    catalogManager.registerCatalog(new Catalog(catalogName, catalog, connector, createInformationSchemaCatalogName(catalog), new InformationSchemaConnector(catalogName, nodeManager, metadata, accessControl), systemId, new SystemConnector(nodeManager, connector.getSystemTables(), transactionId -> transactionManager.getConnectorTransaction(transactionId, catalog))));
    return catalog;
}
Also used : SystemConnector(io.prestosql.connector.system.SystemConnector) Connector(io.prestosql.spi.connector.Connector) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) SystemConnector(io.prestosql.connector.system.SystemConnector) TpchConnectorFactory(io.prestosql.plugin.tpch.TpchConnectorFactory) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) Metadata(io.prestosql.metadata.Metadata) CatalogName.createSystemTablesCatalogName(io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName) CatalogName.createInformationSchemaCatalogName(io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName) CatalogName(io.prestosql.spi.connector.CatalogName) TestingConnectorContext(io.prestosql.testing.TestingConnectorContext) Catalog(io.prestosql.metadata.Catalog) InMemoryNodeManager(io.prestosql.metadata.InMemoryNodeManager)

Example 3 with InformationSchemaConnector

use of io.prestosql.connector.informationschema.InformationSchemaConnector in project hetu-core by openlookeng.

the class TestAnalyzer method createTestingCatalog.

private Catalog createTestingCatalog(String catalogName, CatalogName catalog) {
    CatalogName systemId = createSystemTablesCatalogName(catalog);
    Connector connector = createTestingConnector();
    InternalNodeManager nodeManager = new InMemoryNodeManager();
    return new Catalog(catalogName, catalog, connector, createInformationSchemaCatalogName(catalog), new InformationSchemaConnector(catalogName, nodeManager, metadata, accessControl), systemId, new SystemConnector(nodeManager, connector.getSystemTables(), transactionId -> transactionManager.getConnectorTransaction(transactionId, catalog)));
}
Also used : SystemConnector(io.prestosql.connector.system.SystemConnector) TestingMetadata(io.prestosql.testing.TestingMetadata) Test(org.testng.annotations.Test) PropertyMetadata.integerProperty(io.prestosql.spi.session.PropertyMetadata.integerProperty) TypeSignature.parseTypeSignature(io.prestosql.spi.type.TypeSignature.parseTypeSignature) Statement(io.prestosql.sql.tree.Statement) WarningCollector(io.prestosql.execution.warnings.WarningCollector) SnapshotConfig(io.prestosql.snapshot.SnapshotConfig) INVALID_FETCH_FIRST_ROW_COUNT(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_FETCH_FIRST_ROW_COUNT) MUST_BE_AGGREGATE_OR_GROUP_BY(io.prestosql.sql.analyzer.SemanticErrorCode.MUST_BE_AGGREGATE_OR_GROUP_BY) MISMATCHED_COLUMN_ALIASES(io.prestosql.sql.analyzer.SemanticErrorCode.MISMATCHED_COLUMN_ALIASES) TransactionBuilder.transaction(io.prestosql.transaction.TransactionBuilder.transaction) TOO_MANY_ARGUMENTS(io.prestosql.sql.analyzer.SemanticErrorCode.TOO_MANY_ARGUMENTS) MULTIPLE_FIELDS_FROM_SUBQUERY(io.prestosql.sql.analyzer.SemanticErrorCode.MULTIPLE_FIELDS_FROM_SUBQUERY) AccessControl(io.prestosql.security.AccessControl) DUPLICATE_COLUMN_NAME(io.prestosql.sql.analyzer.SemanticErrorCode.DUPLICATE_COLUMN_NAME) MUST_BE_AGGREGATION_FUNCTION(io.prestosql.sql.analyzer.SemanticErrorCode.MUST_BE_AGGREGATION_FUNCTION) Metadata(io.prestosql.metadata.Metadata) TransactionInfo(io.prestosql.transaction.TransactionInfo) CANNOT_HAVE_AGGREGATIONS_WINDOWS_OR_GROUPING(io.prestosql.sql.analyzer.SemanticErrorCode.CANNOT_HAVE_AGGREGATIONS_WINDOWS_OR_GROUPING) WINDOW_REQUIRES_OVER(io.prestosql.sql.analyzer.SemanticErrorCode.WINDOW_REQUIRES_OVER) PropertyMetadata.stringProperty(io.prestosql.spi.session.PropertyMetadata.stringProperty) TaskManagerConfig(io.prestosql.execution.TaskManagerConfig) Joiner(com.google.common.base.Joiner) INVALID_WINDOW_FRAME(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_WINDOW_FRAME) COLUMN_NAME_NOT_SPECIFIED(io.prestosql.sql.analyzer.SemanticErrorCode.COLUMN_NAME_NOT_SPECIFIED) TransactionManager(io.prestosql.transaction.TransactionManager) CharType(io.prestosql.spi.type.CharType) AccessControlManager(io.prestosql.security.AccessControlManager) INVALID_PARAMETER_USAGE(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_PARAMETER_USAGE) QualifiedObjectName(io.prestosql.spi.connector.QualifiedObjectName) MISSING_SCHEMA(io.prestosql.sql.analyzer.SemanticErrorCode.MISSING_SCHEMA) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) WILDCARD_WITHOUT_FROM(io.prestosql.sql.analyzer.SemanticErrorCode.WILDCARD_WITHOUT_FROM) VARCHAR(io.prestosql.spi.type.VarcharType.VARCHAR) INVALID_PROCEDURE_ARGUMENTS(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_PROCEDURE_ARGUMENTS) InMemoryNodeManager(io.prestosql.metadata.InMemoryNodeManager) CatalogName.createSystemTablesCatalogName(io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName) Session(io.prestosql.Session) DOUBLE(io.prestosql.spi.type.DoubleType.DOUBLE) MISSING_ATTRIBUTE(io.prestosql.sql.analyzer.SemanticErrorCode.MISSING_ATTRIBUTE) SystemConnector(io.prestosql.connector.system.SystemConnector) MISSING_COLUMN(io.prestosql.sql.analyzer.SemanticErrorCode.MISSING_COLUMN) InternalNodeManager(io.prestosql.metadata.InternalNodeManager) DUPLICATE_RELATION(io.prestosql.sql.analyzer.SemanticErrorCode.DUPLICATE_RELATION) VIEW_IS_STALE(io.prestosql.sql.analyzer.SemanticErrorCode.VIEW_IS_STALE) Language(org.intellij.lang.annotations.Language) TYPE_MISMATCH(io.prestosql.sql.analyzer.SemanticErrorCode.TYPE_MISMATCH) NodeLocation(io.prestosql.sql.tree.NodeLocation) SAMPLE_PERCENTAGE_OUT_OF_RANGE(io.prestosql.sql.analyzer.SemanticErrorCode.SAMPLE_PERCENTAGE_OUT_OF_RANGE) ConnectorTableMetadata(io.prestosql.spi.connector.ConnectorTableMetadata) CubeManager(io.prestosql.cube.CubeManager) TransactionId(io.prestosql.transaction.TransactionId) VARBINARY(io.prestosql.spi.type.VarbinaryType.VARBINARY) Catalog(io.prestosql.metadata.Catalog) CatalogManager(io.prestosql.metadata.CatalogManager) MISMATCHED_SET_COLUMN_TYPES(io.prestosql.sql.analyzer.SemanticErrorCode.MISMATCHED_SET_COLUMN_TYPES) COLUMN_TYPE_UNKNOWN(io.prestosql.sql.analyzer.SemanticErrorCode.COLUMN_TYPE_UNKNOWN) AllowAllAccessControl(io.prestosql.security.AllowAllAccessControl) ConnectorMetadata(io.prestosql.spi.connector.ConnectorMetadata) SystemSessionProperties(io.prestosql.SystemSessionProperties) SqlParser(io.prestosql.sql.parser.SqlParser) QueryManagerConfig(io.prestosql.execution.QueryManagerConfig) NOT_SUPPORTED(io.prestosql.sql.analyzer.SemanticErrorCode.NOT_SUPPORTED) AMBIGUOUS_ATTRIBUTE(io.prestosql.sql.analyzer.SemanticErrorCode.AMBIGUOUS_ATTRIBUTE) HetuConfig(io.prestosql.utils.HetuConfig) REFERENCE_TO_OUTPUT_ATTRIBUTE_WITHIN_ORDER_BY_GROUPING(io.prestosql.sql.analyzer.SemanticErrorCode.REFERENCE_TO_OUTPUT_ATTRIBUTE_WITHIN_ORDER_BY_GROUPING) CATALOG_NOT_SPECIFIED(io.prestosql.sql.analyzer.SemanticErrorCode.CATALOG_NOT_SPECIFIED) REFERENCE_TO_OUTPUT_ATTRIBUTE_WITHIN_ORDER_BY_AGGREGATION(io.prestosql.sql.analyzer.SemanticErrorCode.REFERENCE_TO_OUTPUT_ATTRIBUTE_WITHIN_ORDER_BY_AGGREGATION) NON_NUMERIC_SAMPLE_PERCENTAGE(io.prestosql.sql.analyzer.SemanticErrorCode.NON_NUMERIC_SAMPLE_PERCENTAGE) PropertyMetadata(io.prestosql.spi.session.PropertyMetadata) VIEW_IS_RECURSIVE(io.prestosql.sql.analyzer.SemanticErrorCode.VIEW_IS_RECURSIVE) MUST_BE_COLUMN_REFERENCE(io.prestosql.sql.analyzer.SemanticErrorCode.MUST_BE_COLUMN_REFERENCE) BIGINT(io.prestosql.spi.type.BigintType.BIGINT) DecimalType.createDecimalType(io.prestosql.spi.type.DecimalType.createDecimalType) NESTED_AGGREGATION(io.prestosql.sql.analyzer.SemanticErrorCode.NESTED_AGGREGATION) MetadataManager.createTestMetadataManager(io.prestosql.metadata.MetadataManager.createTestMetadataManager) Collections.emptyList(java.util.Collections.emptyList) Collections.nCopies(java.util.Collections.nCopies) ArrayType(io.prestosql.spi.type.ArrayType) BeforeClass(org.testng.annotations.BeforeClass) CatalogName(io.prestosql.spi.connector.CatalogName) NESTED_WINDOW(io.prestosql.sql.analyzer.SemanticErrorCode.NESTED_WINDOW) TINYINT(io.prestosql.spi.type.TinyintType.TINYINT) String.format(java.lang.String.format) List(java.util.List) INVALID_LIMIT_ROW_COUNT(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_LIMIT_ROW_COUNT) NONDETERMINISTIC_ORDER_BY_EXPRESSION_WITH_SELECT_DISTINCT(io.prestosql.sql.analyzer.SemanticErrorCode.NONDETERMINISTIC_ORDER_BY_EXPRESSION_WITH_SELECT_DISTINCT) SessionPropertyManager(io.prestosql.metadata.SessionPropertyManager) ConnectorTransactionHandle(io.prestosql.spi.connector.ConnectorTransactionHandle) Optional(java.util.Optional) INVALID_OFFSET_ROW_COUNT(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_OFFSET_ROW_COUNT) MISSING_CATALOG(io.prestosql.sql.analyzer.SemanticErrorCode.MISSING_CATALOG) Connector(io.prestosql.spi.connector.Connector) MemoryManagerConfig(io.prestosql.memory.MemoryManagerConfig) TOO_MANY_GROUPING_SETS(io.prestosql.sql.analyzer.SemanticErrorCode.TOO_MANY_GROUPING_SETS) MISSING_ORDER_BY(io.prestosql.sql.analyzer.SemanticErrorCode.MISSING_ORDER_BY) ConnectorViewDefinition(io.prestosql.spi.connector.ConnectorViewDefinition) ORDER_BY_MUST_BE_IN_SELECT(io.prestosql.sql.analyzer.SemanticErrorCode.ORDER_BY_MUST_BE_IN_SELECT) ORDER_BY_MUST_BE_IN_AGGREGATE(io.prestosql.sql.analyzer.SemanticErrorCode.ORDER_BY_MUST_BE_IN_AGGREGATE) INTEGER(io.prestosql.spi.type.IntegerType.INTEGER) TestingSession.testSessionBuilder(io.prestosql.testing.TestingSession.testSessionBuilder) SchemaTableName(io.prestosql.spi.connector.SchemaTableName) ImmutableList(com.google.common.collect.ImmutableList) ViewColumn(io.prestosql.spi.connector.ConnectorViewDefinition.ViewColumn) DATE(io.prestosql.spi.type.DateType.DATE) REAL(io.prestosql.spi.type.RealType.REAL) InMemoryTransactionManager.createTestTransactionManager(io.prestosql.transaction.InMemoryTransactionManager.createTestTransactionManager) DUPLICATE_PROPERTY(io.prestosql.sql.analyzer.SemanticErrorCode.DUPLICATE_PROPERTY) ColumnMetadata(io.prestosql.spi.connector.ColumnMetadata) CatalogName.createInformationSchemaCatalogName(io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName) Assert.fail(org.testng.Assert.fail) APPLY_FUNCTION(io.prestosql.operator.scalar.ApplyFunction.APPLY_FUNCTION) INVALID_LITERAL(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_LITERAL) MISSING_TABLE(io.prestosql.sql.analyzer.SemanticErrorCode.MISSING_TABLE) VIEW_ANALYSIS_ERROR(io.prestosql.sql.analyzer.SemanticErrorCode.VIEW_ANALYSIS_ERROR) STANDALONE_LAMBDA(io.prestosql.sql.analyzer.SemanticErrorCode.STANDALONE_LAMBDA) Consumer(java.util.function.Consumer) SCHEMA_NOT_SPECIFIED(io.prestosql.sql.analyzer.SemanticErrorCode.SCHEMA_NOT_SPECIFIED) INVALID_ORDINAL(io.prestosql.sql.analyzer.SemanticErrorCode.INVALID_ORDINAL) SMALLINT(io.prestosql.spi.type.SmallintType.SMALLINT) IsolationLevel(io.prestosql.spi.transaction.IsolationLevel) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) SystemConnector(io.prestosql.connector.system.SystemConnector) Connector(io.prestosql.spi.connector.Connector) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) InternalNodeManager(io.prestosql.metadata.InternalNodeManager) CatalogName.createSystemTablesCatalogName(io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName) CatalogName(io.prestosql.spi.connector.CatalogName) CatalogName.createInformationSchemaCatalogName(io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName) Catalog(io.prestosql.metadata.Catalog) InMemoryNodeManager(io.prestosql.metadata.InMemoryNodeManager)

Example 4 with InformationSchemaConnector

use of io.prestosql.connector.informationschema.InformationSchemaConnector in project hetu-core by openlookeng.

the class ConnectorManager method addCatalogConnector.

public synchronized void addCatalogConnector(CatalogName catalogName, Connector catalogConnector) {
    MaterializedConnector connector = new MaterializedConnector(catalogName, catalogConnector);
    MaterializedConnector informationSchemaConnector = new MaterializedConnector(createInformationSchemaCatalogName(catalogName), new InformationSchemaConnector(catalogName.getCatalogName(), nodeManager, metadataManager, accessControlManager));
    CatalogName systemId = createSystemTablesCatalogName(catalogName);
    SystemTablesProvider systemTablesProvider;
    if (nodeManager.getCurrentNode().isCoordinator()) {
        systemTablesProvider = new DelegatingSystemTablesProvider(new StaticSystemTablesProvider(connector.getSystemTables()), new MetadataBasedSystemTablesProvider(metadataManager, catalogName.getCatalogName()));
    } else {
        systemTablesProvider = new StaticSystemTablesProvider(connector.getSystemTables());
    }
    MaterializedConnector systemConnector = new MaterializedConnector(systemId, new SystemConnector(nodeManager, systemTablesProvider, transactionId -> transactionManager.getConnectorTransaction(transactionId, catalogName)));
    Catalog catalog = new Catalog(catalogName.getCatalogName(), connector.getCatalogName(), connector.getConnector(), informationSchemaConnector.getCatalogName(), informationSchemaConnector.getConnector(), systemConnector.getCatalogName(), systemConnector.getConnector());
    try {
        addConnectorInternal(connector);
        addConnectorInternal(informationSchemaConnector);
        addConnectorInternal(systemConnector);
        catalogManager.registerCatalog(catalog);
    } catch (Throwable e) {
        catalogManager.removeCatalog(catalog.getCatalogName());
        removeConnectorInternal(systemConnector.getCatalogName());
        removeConnectorInternal(informationSchemaConnector.getCatalogName());
        removeConnectorInternal(connector.getCatalogName());
        throw e;
    }
}
Also used : SystemConnector(io.prestosql.connector.system.SystemConnector) ConnectorPlanOptimizerProvider(io.prestosql.spi.connector.ConnectorPlanOptimizerProvider) CONNECTION_USER(io.prestosql.spi.HetuConstant.CONNECTION_USER) VersionEmbedder(io.prestosql.spi.VersionEmbedder) ConnectorAccessControl(io.prestosql.spi.connector.ConnectorAccessControl) ConnectorSplitManager(io.prestosql.spi.connector.ConnectorSplitManager) NodeInfo(io.airlift.node.NodeInfo) FilterStatsCalculator(io.prestosql.cost.FilterStatsCalculator) ConnectorFilterStatsCalculatorService(io.prestosql.cost.ConnectorFilterStatsCalculatorService) DeterminismEvaluator(io.prestosql.spi.relation.DeterminismEvaluator) ServerConfig(io.prestosql.server.ServerConfig) RecordPageSourceProvider(io.prestosql.split.RecordPageSourceProvider) PreDestroy(javax.annotation.PreDestroy) ConnectorPlanOptimizerManager(io.prestosql.sql.planner.ConnectorPlanOptimizerManager) Preconditions.checkArgument(com.google.common.base.Preconditions.checkArgument) PrestoTransportException(io.prestosql.spi.PrestoTransportException) Procedure(io.prestosql.spi.procedure.Procedure) ConnectorNodePartitioningProvider(io.prestosql.spi.connector.ConnectorNodePartitioningProvider) Map(java.util.Map) PropertyMetadata(io.prestosql.spi.session.PropertyMetadata) ConnectorPageSinkProvider(io.prestosql.spi.connector.ConnectorPageSinkProvider) Announcer(io.airlift.discovery.client.Announcer) HeuristicIndexerManager(io.prestosql.heuristicindex.HeuristicIndexerManager) PageIndexerFactory(io.prestosql.spi.PageIndexerFactory) PrestoException(io.prestosql.spi.PrestoException) ImmutableSet(com.google.common.collect.ImmutableSet) SystemTable(io.prestosql.spi.connector.SystemTable) DomainTranslator(io.prestosql.spi.relation.DomainTranslator) DATA_CENTER_CONNECTOR_NAME(io.prestosql.spi.HetuConstant.DATA_CENTER_CONNECTOR_NAME) CatalogName(io.prestosql.spi.connector.CatalogName) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) Set(java.util.Set) ThreadSafe(javax.annotation.concurrent.ThreadSafe) NodeSchedulerConfig(io.prestosql.execution.scheduler.NodeSchedulerConfig) GuardedBy(javax.annotation.concurrent.GuardedBy) ExternalFunctionHub(io.prestosql.spi.function.ExternalFunctionHub) MetadataManager(io.prestosql.metadata.MetadataManager) String.format(java.lang.String.format) Preconditions.checkState(com.google.common.base.Preconditions.checkState) List(java.util.List) FunctionResolution(io.prestosql.sql.relational.FunctionResolution) ConnectorRecordSetProvider(io.prestosql.spi.connector.ConnectorRecordSetProvider) PageSinkManager(io.prestosql.split.PageSinkManager) Optional(java.util.Optional) FunctionAndTypeManager(io.prestosql.metadata.FunctionAndTypeManager) Joiner(com.google.common.base.Joiner) Connector(io.prestosql.spi.connector.Connector) NodePartitioningManager(io.prestosql.sql.planner.NodePartitioningManager) REMOTE_TASK_ERROR(io.prestosql.spi.StandardErrorCode.REMOTE_TASK_ERROR) Logger(io.airlift.log.Logger) EmbedVersion(io.prestosql.version.EmbedVersion) TransactionManager(io.prestosql.transaction.TransactionManager) ConnectorContext(io.prestosql.spi.connector.ConnectorContext) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) HashMap(java.util.HashMap) AccessControlManager(io.prestosql.security.AccessControlManager) SqlInvokedFunction(io.prestosql.spi.function.SqlInvokedFunction) FunctionExtractor.extractExternalFunctions(io.prestosql.metadata.FunctionExtractor.extractExternalFunctions) StaticSystemTablesProvider(io.prestosql.connector.system.StaticSystemTablesProvider) ConcurrentMap(java.util.concurrent.ConcurrentMap) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) Inject(javax.inject.Inject) ConnectorIndexProvider(io.prestosql.spi.connector.ConnectorIndexProvider) MetadataBasedSystemTablesProvider(io.prestosql.connector.system.MetadataBasedSystemTablesProvider) ImmutableList(com.google.common.collect.ImmutableList) SystemTablesProvider(io.prestosql.connector.system.SystemTablesProvider) Verify.verify(com.google.common.base.Verify.verify) CatalogName.createSystemTablesCatalogName(io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName) Objects.requireNonNull(java.util.Objects.requireNonNull) PageSourceManager(io.prestosql.split.PageSourceManager) SystemConnector(io.prestosql.connector.system.SystemConnector) LinkedHashSet(java.util.LinkedHashSet) InternalNodeManager(io.prestosql.metadata.InternalNodeManager) InternalTypeManager(io.prestosql.type.InternalTypeManager) IndexManager(io.prestosql.index.IndexManager) CatalogName.createInformationSchemaCatalogName(io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName) ThreadContextClassLoader(io.prestosql.spi.classloader.ThreadContextClassLoader) PageSorter(io.prestosql.spi.PageSorter) Field(java.lang.reflect.Field) ServiceAnnouncement(io.airlift.discovery.client.ServiceAnnouncement) DelegatingSystemTablesProvider(io.prestosql.connector.system.DelegatingSystemTablesProvider) Catalog(io.prestosql.metadata.Catalog) HandleResolver(io.prestosql.metadata.HandleResolver) HetuMetaStoreManager(io.prestosql.metastore.HetuMetaStoreManager) ConnectorFactory(io.prestosql.spi.connector.ConnectorFactory) SplitManager(io.prestosql.split.SplitManager) CatalogManager(io.prestosql.metadata.CatalogManager) ConnectorRowExpressionService(io.prestosql.sql.relational.ConnectorRowExpressionService) ConnectorPageSourceProvider(io.prestosql.spi.connector.ConnectorPageSourceProvider) StaticSystemTablesProvider(io.prestosql.connector.system.StaticSystemTablesProvider) InformationSchemaConnector(io.prestosql.connector.informationschema.InformationSchemaConnector) DelegatingSystemTablesProvider(io.prestosql.connector.system.DelegatingSystemTablesProvider) MetadataBasedSystemTablesProvider(io.prestosql.connector.system.MetadataBasedSystemTablesProvider) CatalogName(io.prestosql.spi.connector.CatalogName) CatalogName.createSystemTablesCatalogName(io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName) CatalogName.createInformationSchemaCatalogName(io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName) StaticSystemTablesProvider(io.prestosql.connector.system.StaticSystemTablesProvider) MetadataBasedSystemTablesProvider(io.prestosql.connector.system.MetadataBasedSystemTablesProvider) SystemTablesProvider(io.prestosql.connector.system.SystemTablesProvider) DelegatingSystemTablesProvider(io.prestosql.connector.system.DelegatingSystemTablesProvider) Catalog(io.prestosql.metadata.Catalog)

Aggregations

InformationSchemaConnector (io.prestosql.connector.informationschema.InformationSchemaConnector)4 SystemConnector (io.prestosql.connector.system.SystemConnector)4 Catalog (io.prestosql.metadata.Catalog)4 InMemoryNodeManager (io.prestosql.metadata.InMemoryNodeManager)3 InternalNodeManager (io.prestosql.metadata.InternalNodeManager)3 Metadata (io.prestosql.metadata.Metadata)3 CatalogName (io.prestosql.spi.connector.CatalogName)3 CatalogName.createInformationSchemaCatalogName (io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName)3 CatalogName.createSystemTablesCatalogName (io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName)3 Joiner (com.google.common.base.Joiner)2 ImmutableList (com.google.common.collect.ImmutableList)2 CatalogManager (io.prestosql.metadata.CatalogManager)2 AccessControlManager (io.prestosql.security.AccessControlManager)2 AllowAllAccessControl (io.prestosql.security.AllowAllAccessControl)2 Connector (io.prestosql.spi.connector.Connector)2 ConnectorMetadata (io.prestosql.spi.connector.ConnectorMetadata)2 Preconditions.checkArgument (com.google.common.base.Preconditions.checkArgument)1 Preconditions.checkState (com.google.common.base.Preconditions.checkState)1 Verify.verify (com.google.common.base.Verify.verify)1 ImmutableSet (com.google.common.collect.ImmutableSet)1