Search in sources :

Example 1 with InternalNodeManager

use of io.prestosql.metadata.InternalNodeManager 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 InternalNodeManager

use of io.prestosql.metadata.InternalNodeManager 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 3 with InternalNodeManager

use of io.prestosql.metadata.InternalNodeManager in project hetu-core by openlookeng.

the class TestDistributedResourceGroup method setup.

@BeforeClass
public void setup() {
    statestore = Mockito.mock(StateStore.class);
    when(statestore.getLock(anyString())).then(new Returns(new ReentrantLock()));
    internalNodeManager = Mockito.mock(InternalNodeManager.class);
}
Also used : ReentrantLock(java.util.concurrent.locks.ReentrantLock) Returns(org.mockito.internal.stubbing.answers.Returns) InternalNodeManager(io.prestosql.metadata.InternalNodeManager) StateStore(io.prestosql.spi.statestore.StateStore) BeforeClass(org.testng.annotations.BeforeClass)

Aggregations

InternalNodeManager (io.prestosql.metadata.InternalNodeManager)3 InformationSchemaConnector (io.prestosql.connector.informationschema.InformationSchemaConnector)2 SystemConnector (io.prestosql.connector.system.SystemConnector)2 Catalog (io.prestosql.metadata.Catalog)2 InMemoryNodeManager (io.prestosql.metadata.InMemoryNodeManager)2 Metadata (io.prestosql.metadata.Metadata)2 AllowAllAccessControl (io.prestosql.security.AllowAllAccessControl)2 CatalogName (io.prestosql.spi.connector.CatalogName)2 CatalogName.createInformationSchemaCatalogName (io.prestosql.spi.connector.CatalogName.createInformationSchemaCatalogName)2 CatalogName.createSystemTablesCatalogName (io.prestosql.spi.connector.CatalogName.createSystemTablesCatalogName)2 ConnectorMetadata (io.prestosql.spi.connector.ConnectorMetadata)2 Joiner (com.google.common.base.Joiner)1 ImmutableList (com.google.common.collect.ImmutableList)1 Session (io.prestosql.Session)1 SystemSessionProperties (io.prestosql.SystemSessionProperties)1 CubeManager (io.prestosql.cube.CubeManager)1 QueryManagerConfig (io.prestosql.execution.QueryManagerConfig)1 TaskManagerConfig (io.prestosql.execution.TaskManagerConfig)1 WarningCollector (io.prestosql.execution.warnings.WarningCollector)1 MemoryManagerConfig (io.prestosql.memory.MemoryManagerConfig)1