Search in sources :

Example 1 with NONE

use of io.prestosql.plugin.hive.HiveCompressionCodec.NONE in project boostkit-bigdata by kunpengcompute.

the class TestHiveIntegrationSmokeTest method createAndGetSplits.

private Set<Split> createAndGetSplits(long start) {
    HiveConfig config = new HiveConfig();
    config.setHiveStorageFormat(HiveStorageFormat.ORC);
    config.setHiveCompressionCodec(NONE);
    Properties splitProperties = new Properties();
    splitProperties.setProperty(FILE_INPUT_FORMAT, config.getHiveStorageFormat().getInputFormat());
    splitProperties.setProperty(SERIALIZATION_LIB, config.getHiveStorageFormat().getSerDe());
    splitProperties.setProperty("columns", Joiner.on(',').join(TestHivePageSink.getColumnHandles().stream().map(HiveColumnHandle::getName).collect(toList())));
    splitProperties.setProperty("columns.types", Joiner.on(',').join(TestHivePageSink.getColumnHandles().stream().map(HiveColumnHandle::getHiveType).map(hiveType -> hiveType.getHiveTypeName().toString()).collect(toList())));
    List<ConnectorSplit> connectorSplits1 = new ArrayList<>();
    for (long j = start; j < start + 30; j += 10) {
        List<HiveSplit> hiveSplitList = new ArrayList<>();
        for (int i = 0; i < 3; i++) {
            HiveSplit hiveSplit = new HiveSplit(TEST_SCHEMA, TEST_TABLE, "", "file:///", i + j, 100 + i + j, 100 + i + j, 0, splitProperties, ImmutableList.of(), ImmutableList.of(), OptionalInt.empty(), false, ImmutableMap.of(), Optional.empty(), false, Optional.empty(), Optional.empty(), false, ImmutableMap.of());
            hiveSplitList.add(hiveSplit);
        }
        HiveSplitWrapper split2 = HiveSplitWrapper.wrap(hiveSplitList, OptionalInt.empty());
        connectorSplits1.add(split2);
    }
    ImmutableList.Builder<Split> result = ImmutableList.builder();
    for (ConnectorSplit connectorSplit : connectorSplits1) {
        result.add(new Split(CONNECTOR_ID, connectorSplit, Lifespan.taskWide()));
    }
    List<Split> splitList = result.build();
    Set<Split> set = splitList.stream().collect(Collectors.toSet());
    return set;
}
Also used : QueryAssertions.assertEqualsIgnoreOrder(io.prestosql.tests.QueryAssertions.assertEqualsIgnoreOrder) Arrays(java.util.Arrays) NONE(io.prestosql.plugin.hive.HiveCompressionCodec.NONE) IoPlan(io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan) JoinDistributionType(io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType) Plan(io.prestosql.sql.planner.Plan) Test(org.testng.annotations.Test) BigDecimal(java.math.BigDecimal) JOIN_REORDERING_STRATEGY(io.prestosql.SystemSessionProperties.JOIN_REORDERING_STRATEGY) Assert.assertEquals(io.prestosql.testing.assertions.Assert.assertEquals) Matcher(java.util.regex.Matcher) StageExecutionPlan(io.prestosql.sql.planner.StageExecutionPlan) Executors.newScheduledThreadPool(java.util.concurrent.Executors.newScheduledThreadPool) MockRemoteTaskFactory(io.prestosql.execution.MockRemoteTaskFactory) HetuConstant(io.prestosql.spi.HetuConstant) DistributedQueryRunner(io.prestosql.tests.DistributedQueryRunner) Files.createTempDirectory(java.nio.file.Files.createTempDirectory) Map(java.util.Map) FileAssert.assertFile(org.testng.FileAssert.assertFile) CUSTOMER(io.airlift.tpch.TpchTable.CUSTOMER) TransactionBuilder.transaction(io.prestosql.transaction.TransactionBuilder.transaction) Assert.assertFalse(org.testng.Assert.assertFalse) SERIALIZATION_LIB(org.apache.hadoop.hive.serde.serdeConstants.SERIALIZATION_LIB) PlanNodeId(io.prestosql.spi.plan.PlanNodeId) Assert.assertNotEquals(org.testng.Assert.assertNotEquals) Set(java.util.Set) Identity(io.prestosql.spi.security.Identity) NodeSchedulerConfig(io.prestosql.execution.scheduler.NodeSchedulerConfig) Metadata(io.prestosql.metadata.Metadata) ConnectorAwareSplitSource(io.prestosql.split.ConnectorAwareSplitSource) Collectors.joining(java.util.stream.Collectors.joining) VarcharType.createVarcharType(io.prestosql.spi.type.VarcharType.createVarcharType) TimestampType(io.prestosql.spi.type.TimestampType) ReuseExchangeOperator(io.prestosql.spi.operator.ReuseExchangeOperator) SplitSchedulerStats(io.prestosql.execution.scheduler.SplitSchedulerStats) Stream(java.util.stream.Stream) EXACTLY(io.prestosql.spi.predicate.Marker.Bound.EXACTLY) FormattedRange(io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange) TEST_SESSION(io.prestosql.SessionTestUtils.TEST_SESSION) JOIN_DISTRIBUTION_TYPE(io.prestosql.SystemSessionProperties.JOIN_DISTRIBUTION_TYPE) Joiner(com.google.common.base.Joiner) TPCH_SCHEMA(io.prestosql.plugin.hive.HiveQueryRunner.TPCH_SCHEMA) TestSourcePartitionedScheduler.createFixedSplitSource(io.prestosql.execution.scheduler.TestSourcePartitionedScheduler.createFixedSplitSource) FilenameFilter(java.io.FilenameFilter) TableMetadata(io.prestosql.metadata.TableMetadata) TRANSACTIONAL(io.prestosql.plugin.hive.HiveTableProperties.TRANSACTIONAL) TYPE_MANAGER(io.prestosql.plugin.hive.HiveTestUtils.TYPE_MANAGER) ConnectorSplit(io.prestosql.spi.connector.ConnectorSplit) InsertTableHandle(io.prestosql.metadata.InsertTableHandle) LocalDateTime(java.time.LocalDateTime) CharType(io.prestosql.spi.type.CharType) NodeScheduler(io.prestosql.execution.scheduler.NodeScheduler) BUCKET_COUNT_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.BUCKET_COUNT_PROPERTY) QualifiedObjectName(io.prestosql.spi.connector.QualifiedObjectName) ArrayList(java.util.ArrayList) TEST_SESSION_REUSE(io.prestosql.SessionTestUtils.TEST_SESSION_REUSE) SeedStoreManager(io.prestosql.seedstore.SeedStoreManager) ALLOW_INSECURE(com.google.common.io.RecursiveDeleteOption.ALLOW_INSECURE) VARCHAR(io.prestosql.spi.type.VarcharType.VARCHAR) InMemoryNodeManager(io.prestosql.metadata.InMemoryNodeManager) Files.asCharSink(com.google.common.io.Files.asCharSink) Session(io.prestosql.Session) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) BiConsumer(java.util.function.BiConsumer) DOUBLE(io.prestosql.spi.type.DoubleType.DOUBLE) NodeTaskMap(io.prestosql.execution.NodeTaskMap) Lifespan(io.prestosql.execution.Lifespan) Properties(java.util.Properties) LongStream(java.util.stream.LongStream) StageId(io.prestosql.execution.StageId) IntegerType(io.prestosql.spi.type.IntegerType) Language(org.intellij.lang.annotations.Language) InternalNode(io.prestosql.metadata.InternalNode) COLOCATED_JOIN(io.prestosql.SystemSessionProperties.COLOCATED_JOIN) NOOP_SNAPSHOT_UTILS(io.prestosql.testing.TestingSnapshotUtils.NOOP_SNAPSHOT_UTILS) QuerySnapshotManager(io.prestosql.snapshot.QuerySnapshotManager) Iterables.getOnlyElement(com.google.common.collect.Iterables.getOnlyElement) TinyintType(io.prestosql.spi.type.TinyintType) MaterializedRow(io.prestosql.testing.MaterializedRow) FinalizerService(io.prestosql.util.FinalizerService) File(java.io.File) JsonCodec.jsonCodec(io.airlift.json.JsonCodec.jsonCodec) PATH_COLUMN_NAME(io.prestosql.plugin.hive.HiveColumnHandle.PATH_COLUMN_NAME) TestSqlTaskManager(io.prestosql.execution.TestSqlTaskManager) SqlStageExecution.createSqlStageExecution(io.prestosql.execution.SqlStageExecution.createSqlStageExecution) SqlStageExecution(io.prestosql.execution.SqlStageExecution) BooleanType(io.prestosql.spi.type.BooleanType) VarcharType(io.prestosql.spi.type.VarcharType) DYNAMIC_SCHEDULE_FOR_GROUPED_EXECUTION(io.prestosql.SystemSessionProperties.DYNAMIC_SCHEDULE_FOR_GROUPED_EXECUTION) RemoteTask(io.prestosql.execution.RemoteTask) MoreFiles.deleteRecursively(com.google.common.io.MoreFiles.deleteRecursively) Assertions.assertThat(org.assertj.core.api.Assertions.assertThat) LINE_ITEM(io.airlift.tpch.TpchTable.LINE_ITEM) DecimalType(io.prestosql.spi.type.DecimalType) FileSystemClientManager(io.prestosql.filesystem.FileSystemClientManager) MaterializedResult(io.prestosql.testing.MaterializedResult) ExchangeNode(io.prestosql.sql.planner.plan.ExchangeNode) ConnectorSession(io.prestosql.spi.connector.ConnectorSession) ENABLE_DYNAMIC_FILTERING(io.prestosql.SystemSessionProperties.ENABLE_DYNAMIC_FILTERING) JoinReorderingStrategy(io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy) FormattedMarker(io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker) Path(org.apache.hadoop.fs.Path) BOOLEAN(io.prestosql.spi.type.BooleanType.BOOLEAN) Type(io.prestosql.spi.type.Type) URI(java.net.URI) ColumnConstraint(io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint) BIGINT(io.prestosql.spi.type.BigintType.BIGINT) DecimalType.createDecimalType(io.prestosql.spi.type.DecimalType.createDecimalType) Constraint(io.prestosql.spi.connector.Constraint) PrestoException(io.prestosql.spi.PrestoException) ImmutableSet(com.google.common.collect.ImmutableSet) ImmutableMap(com.google.common.collect.ImmutableMap) HiveUtil.columnExtraInfo(io.prestosql.plugin.hive.HiveUtil.columnExtraInfo) Collection(java.util.Collection) CharType.createCharType(io.prestosql.spi.type.CharType.createCharType) CatalogName(io.prestosql.spi.connector.CatalogName) SelectedRole(io.prestosql.spi.security.SelectedRole) PropertyService(io.prestosql.spi.service.PropertyService) AbstractTestIntegrationSmokeTest(io.prestosql.tests.AbstractTestIntegrationSmokeTest) UUID(java.util.UUID) TINYINT(io.prestosql.spi.type.TinyintType.TINYINT) Assert.assertNotNull(org.testng.Assert.assertNotNull) Collectors(java.util.stream.Collectors) String.format(java.lang.String.format) Preconditions.checkState(com.google.common.base.Preconditions.checkState) TableColumnInfo(io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo) List(java.util.List) NodeSelector(io.prestosql.execution.scheduler.NodeSelector) VarcharType.createUnboundedVarcharType(io.prestosql.spi.type.VarcharType.createUnboundedVarcharType) LocalDate(java.time.LocalDate) Optional(java.util.Optional) MaterializedResult.resultBuilder(io.prestosql.testing.MaterializedResult.resultBuilder) TypeSignature(io.prestosql.spi.type.TypeSignature) Pattern(java.util.regex.Pattern) NodeVersion(io.prestosql.client.NodeVersion) BigintType(io.prestosql.spi.type.BigintType) TestPhasedExecutionSchedule.createTableScanPlanFragment(io.prestosql.execution.scheduler.TestPhasedExecutionSchedule.createTableScanPlanFragment) BUCKET_COLUMN_NAME(io.prestosql.plugin.hive.HiveColumnHandle.BUCKET_COLUMN_NAME) Assert.assertNull(org.testng.Assert.assertNull) LegacyNetworkTopology(io.prestosql.execution.scheduler.LegacyNetworkTopology) ORDERS(io.airlift.tpch.TpchTable.ORDERS) BROADCAST(io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType.BROADCAST) StatsAndCosts(io.prestosql.cost.StatsAndCosts) HashMap(java.util.HashMap) Split(io.prestosql.metadata.Split) BUCKETED_BY_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.BUCKETED_BY_PROPERTY) Multimap(com.google.common.collect.Multimap) TableHandle(io.prestosql.spi.metadata.TableHandle) OptionalInt(java.util.OptionalInt) Function(java.util.function.Function) TestingSession.testSessionBuilder(io.prestosql.testing.TestingSession.testSessionBuilder) PlanPrinter.textLogicalPlan(io.prestosql.sql.planner.planprinter.PlanPrinter.textLogicalPlan) TestingAccessControlManager.privilege(io.prestosql.testing.TestingAccessControlManager.privilege) ImmutableList(com.google.common.collect.ImmutableList) TestingSplit(io.prestosql.testing.TestingSplit) CONCURRENT_LIFESPANS_PER_NODE(io.prestosql.SystemSessionProperties.CONCURRENT_LIFESPANS_PER_NODE) Assertions.assertThatThrownBy(org.assertj.core.api.Assertions.assertThatThrownBy) LocalStateStoreProvider(io.prestosql.statestore.LocalStateStoreProvider) Verify.verify(com.google.common.base.Verify.verify) Threads.daemonThreadsNamed(io.airlift.concurrent.Threads.daemonThreadsNamed) DoubleType(io.prestosql.spi.type.DoubleType) Objects.requireNonNull(java.util.Objects.requireNonNull) QueryId(io.prestosql.spi.QueryId) SmallintType(io.prestosql.spi.type.SmallintType) STORAGE_FORMAT_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.STORAGE_FORMAT_PROPERTY) ExecutorService(java.util.concurrent.ExecutorService) PlanFragment(io.prestosql.sql.planner.PlanFragment) GROUPED_EXECUTION(io.prestosql.SystemSessionProperties.GROUPED_EXECUTION) TableInfo(io.prestosql.execution.TableInfo) FormattedDomain(io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain) UTF_8(java.nio.charset.StandardCharsets.UTF_8) ColumnMetadata(io.prestosql.spi.connector.ColumnMetadata) TupleDomain(io.prestosql.spi.predicate.TupleDomain) Assert.fail(org.testng.Assert.fail) NoOpFailureDetector(io.prestosql.failuredetector.NoOpFailureDetector) SELECT_COLUMN(io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType.SELECT_COLUMN) DynamicFilterService(io.prestosql.dynamicfilter.DynamicFilterService) TimeUnit(java.util.concurrent.TimeUnit) Consumer(java.util.function.Consumer) PlanNodeSearcher.searchFrom(io.prestosql.sql.planner.optimizations.PlanNodeSearcher.searchFrom) ROLE(io.prestosql.spi.security.SelectedRole.Type.ROLE) PARTITIONED_BY_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.PARTITIONED_BY_PROPERTY) Collectors.toList(java.util.stream.Collectors.toList) SMALLINT(io.prestosql.spi.type.SmallintType.SMALLINT) Executors.newCachedThreadPool(java.util.concurrent.Executors.newCachedThreadPool) SplitKey(io.prestosql.execution.SplitKey) DateType(io.prestosql.spi.type.DateType) FILE_INPUT_FORMAT(org.apache.hadoop.hive.metastore.api.hive_metastoreConstants.FILE_INPUT_FORMAT) Assert.assertTrue(org.testng.Assert.assertTrue) CatalogSchemaTableName(io.prestosql.spi.connector.CatalogSchemaTableName) ImmutableList(com.google.common.collect.ImmutableList) ArrayList(java.util.ArrayList) Properties(java.util.Properties) ColumnConstraint(io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint) Constraint(io.prestosql.spi.connector.Constraint) ConnectorSplit(io.prestosql.spi.connector.ConnectorSplit) Split(io.prestosql.metadata.Split) TestingSplit(io.prestosql.testing.TestingSplit) ConnectorSplit(io.prestosql.spi.connector.ConnectorSplit)

Example 2 with NONE

use of io.prestosql.plugin.hive.HiveCompressionCodec.NONE in project hetu-core by openlookeng.

the class TestHiveIntegrationSmokeTest method createAndGetSplits.

private Set<Split> createAndGetSplits(long start) {
    HiveConfig config = new HiveConfig();
    config.setHiveStorageFormat(HiveStorageFormat.ORC);
    config.setHiveCompressionCodec(NONE);
    Properties splitProperties = new Properties();
    splitProperties.setProperty(FILE_INPUT_FORMAT, config.getHiveStorageFormat().getInputFormat());
    splitProperties.setProperty(SERIALIZATION_LIB, config.getHiveStorageFormat().getSerDe());
    splitProperties.setProperty("columns", Joiner.on(',').join(TestHivePageSink.getColumnHandles().stream().map(HiveColumnHandle::getName).collect(toList())));
    splitProperties.setProperty("columns.types", Joiner.on(',').join(TestHivePageSink.getColumnHandles().stream().map(HiveColumnHandle::getHiveType).map(hiveType -> hiveType.getHiveTypeName().toString()).collect(toList())));
    List<ConnectorSplit> connectorSplits1 = new ArrayList<>();
    for (long j = start; j < start + 30; j += 10) {
        List<HiveSplit> hiveSplitList = new ArrayList<>();
        for (int i = 0; i < 3; i++) {
            HiveSplit hiveSplit = new HiveSplit(TEST_SCHEMA, TEST_TABLE, "", "file:///", i + j, 100 + i + j, 100 + i + j, 0, splitProperties, ImmutableList.of(), ImmutableList.of(), OptionalInt.empty(), false, ImmutableMap.of(), Optional.empty(), false, Optional.empty(), Optional.empty(), false, ImmutableMap.of());
            hiveSplitList.add(hiveSplit);
        }
        HiveSplitWrapper split2 = HiveSplitWrapper.wrap(hiveSplitList, OptionalInt.empty());
        connectorSplits1.add(split2);
    }
    ImmutableList.Builder<Split> result = ImmutableList.builder();
    for (ConnectorSplit connectorSplit : connectorSplits1) {
        result.add(new Split(CONNECTOR_ID, connectorSplit, Lifespan.taskWide()));
    }
    List<Split> splitList = result.build();
    Set<Split> set = splitList.stream().collect(Collectors.toSet());
    return set;
}
Also used : QueryAssertions.assertEqualsIgnoreOrder(io.prestosql.tests.QueryAssertions.assertEqualsIgnoreOrder) Arrays(java.util.Arrays) NONE(io.prestosql.plugin.hive.HiveCompressionCodec.NONE) IoPlan(io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan) JoinDistributionType(io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType) Plan(io.prestosql.sql.planner.Plan) Test(org.testng.annotations.Test) BigDecimal(java.math.BigDecimal) JOIN_REORDERING_STRATEGY(io.prestosql.SystemSessionProperties.JOIN_REORDERING_STRATEGY) Assert.assertEquals(io.prestosql.testing.assertions.Assert.assertEquals) Matcher(java.util.regex.Matcher) StageExecutionPlan(io.prestosql.sql.planner.StageExecutionPlan) Executors.newScheduledThreadPool(java.util.concurrent.Executors.newScheduledThreadPool) MockRemoteTaskFactory(io.prestosql.execution.MockRemoteTaskFactory) HetuConstant(io.prestosql.spi.HetuConstant) DistributedQueryRunner(io.prestosql.tests.DistributedQueryRunner) Files.createTempDirectory(java.nio.file.Files.createTempDirectory) Map(java.util.Map) FileAssert.assertFile(org.testng.FileAssert.assertFile) CUSTOMER(io.airlift.tpch.TpchTable.CUSTOMER) TransactionBuilder.transaction(io.prestosql.transaction.TransactionBuilder.transaction) Assert.assertFalse(org.testng.Assert.assertFalse) SERIALIZATION_LIB(org.apache.hadoop.hive.serde.serdeConstants.SERIALIZATION_LIB) PlanNodeId(io.prestosql.spi.plan.PlanNodeId) Assert.assertNotEquals(org.testng.Assert.assertNotEquals) Set(java.util.Set) Identity(io.prestosql.spi.security.Identity) NodeSchedulerConfig(io.prestosql.execution.scheduler.NodeSchedulerConfig) Metadata(io.prestosql.metadata.Metadata) ConnectorAwareSplitSource(io.prestosql.split.ConnectorAwareSplitSource) Collectors.joining(java.util.stream.Collectors.joining) VarcharType.createVarcharType(io.prestosql.spi.type.VarcharType.createVarcharType) TimestampType(io.prestosql.spi.type.TimestampType) ReuseExchangeOperator(io.prestosql.spi.operator.ReuseExchangeOperator) SplitSchedulerStats(io.prestosql.execution.scheduler.SplitSchedulerStats) Stream(java.util.stream.Stream) EXACTLY(io.prestosql.spi.predicate.Marker.Bound.EXACTLY) FormattedRange(io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange) TEST_SESSION(io.prestosql.SessionTestUtils.TEST_SESSION) JOIN_DISTRIBUTION_TYPE(io.prestosql.SystemSessionProperties.JOIN_DISTRIBUTION_TYPE) Joiner(com.google.common.base.Joiner) TPCH_SCHEMA(io.prestosql.plugin.hive.HiveQueryRunner.TPCH_SCHEMA) TestSourcePartitionedScheduler.createFixedSplitSource(io.prestosql.execution.scheduler.TestSourcePartitionedScheduler.createFixedSplitSource) FilenameFilter(java.io.FilenameFilter) TableMetadata(io.prestosql.metadata.TableMetadata) TRANSACTIONAL(io.prestosql.plugin.hive.HiveTableProperties.TRANSACTIONAL) TYPE_MANAGER(io.prestosql.plugin.hive.HiveTestUtils.TYPE_MANAGER) ConnectorSplit(io.prestosql.spi.connector.ConnectorSplit) InsertTableHandle(io.prestosql.metadata.InsertTableHandle) LocalDateTime(java.time.LocalDateTime) CharType(io.prestosql.spi.type.CharType) NodeScheduler(io.prestosql.execution.scheduler.NodeScheduler) BUCKET_COUNT_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.BUCKET_COUNT_PROPERTY) QualifiedObjectName(io.prestosql.spi.connector.QualifiedObjectName) ArrayList(java.util.ArrayList) TEST_SESSION_REUSE(io.prestosql.SessionTestUtils.TEST_SESSION_REUSE) SeedStoreManager(io.prestosql.seedstore.SeedStoreManager) ALLOW_INSECURE(com.google.common.io.RecursiveDeleteOption.ALLOW_INSECURE) VARCHAR(io.prestosql.spi.type.VarcharType.VARCHAR) InMemoryNodeManager(io.prestosql.metadata.InMemoryNodeManager) Files.asCharSink(com.google.common.io.Files.asCharSink) Session(io.prestosql.Session) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) BiConsumer(java.util.function.BiConsumer) DOUBLE(io.prestosql.spi.type.DoubleType.DOUBLE) NodeTaskMap(io.prestosql.execution.NodeTaskMap) Lifespan(io.prestosql.execution.Lifespan) Properties(java.util.Properties) LongStream(java.util.stream.LongStream) StageId(io.prestosql.execution.StageId) IntegerType(io.prestosql.spi.type.IntegerType) Language(org.intellij.lang.annotations.Language) InternalNode(io.prestosql.metadata.InternalNode) COLOCATED_JOIN(io.prestosql.SystemSessionProperties.COLOCATED_JOIN) NOOP_SNAPSHOT_UTILS(io.prestosql.testing.TestingSnapshotUtils.NOOP_SNAPSHOT_UTILS) QuerySnapshotManager(io.prestosql.snapshot.QuerySnapshotManager) Iterables.getOnlyElement(com.google.common.collect.Iterables.getOnlyElement) TinyintType(io.prestosql.spi.type.TinyintType) MaterializedRow(io.prestosql.testing.MaterializedRow) FinalizerService(io.prestosql.util.FinalizerService) File(java.io.File) JsonCodec.jsonCodec(io.airlift.json.JsonCodec.jsonCodec) PATH_COLUMN_NAME(io.prestosql.plugin.hive.HiveColumnHandle.PATH_COLUMN_NAME) TestSqlTaskManager(io.prestosql.execution.TestSqlTaskManager) SqlStageExecution.createSqlStageExecution(io.prestosql.execution.SqlStageExecution.createSqlStageExecution) SqlStageExecution(io.prestosql.execution.SqlStageExecution) BooleanType(io.prestosql.spi.type.BooleanType) VarcharType(io.prestosql.spi.type.VarcharType) DYNAMIC_SCHEDULE_FOR_GROUPED_EXECUTION(io.prestosql.SystemSessionProperties.DYNAMIC_SCHEDULE_FOR_GROUPED_EXECUTION) RemoteTask(io.prestosql.execution.RemoteTask) MoreFiles.deleteRecursively(com.google.common.io.MoreFiles.deleteRecursively) Assertions.assertThat(org.assertj.core.api.Assertions.assertThat) LINE_ITEM(io.airlift.tpch.TpchTable.LINE_ITEM) DecimalType(io.prestosql.spi.type.DecimalType) FileSystemClientManager(io.prestosql.filesystem.FileSystemClientManager) MaterializedResult(io.prestosql.testing.MaterializedResult) ExchangeNode(io.prestosql.sql.planner.plan.ExchangeNode) ConnectorSession(io.prestosql.spi.connector.ConnectorSession) ENABLE_DYNAMIC_FILTERING(io.prestosql.SystemSessionProperties.ENABLE_DYNAMIC_FILTERING) JoinReorderingStrategy(io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy) FormattedMarker(io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker) Path(org.apache.hadoop.fs.Path) BOOLEAN(io.prestosql.spi.type.BooleanType.BOOLEAN) Type(io.prestosql.spi.type.Type) URI(java.net.URI) ColumnConstraint(io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint) BIGINT(io.prestosql.spi.type.BigintType.BIGINT) DecimalType.createDecimalType(io.prestosql.spi.type.DecimalType.createDecimalType) Constraint(io.prestosql.spi.connector.Constraint) PrestoException(io.prestosql.spi.PrestoException) ImmutableSet(com.google.common.collect.ImmutableSet) ImmutableMap(com.google.common.collect.ImmutableMap) HiveUtil.columnExtraInfo(io.prestosql.plugin.hive.HiveUtil.columnExtraInfo) Collection(java.util.Collection) CharType.createCharType(io.prestosql.spi.type.CharType.createCharType) CatalogName(io.prestosql.spi.connector.CatalogName) SelectedRole(io.prestosql.spi.security.SelectedRole) PropertyService(io.prestosql.spi.service.PropertyService) AbstractTestIntegrationSmokeTest(io.prestosql.tests.AbstractTestIntegrationSmokeTest) UUID(java.util.UUID) TINYINT(io.prestosql.spi.type.TinyintType.TINYINT) Assert.assertNotNull(org.testng.Assert.assertNotNull) Collectors(java.util.stream.Collectors) String.format(java.lang.String.format) Preconditions.checkState(com.google.common.base.Preconditions.checkState) TableColumnInfo(io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo) List(java.util.List) NodeSelector(io.prestosql.execution.scheduler.NodeSelector) VarcharType.createUnboundedVarcharType(io.prestosql.spi.type.VarcharType.createUnboundedVarcharType) LocalDate(java.time.LocalDate) Optional(java.util.Optional) MaterializedResult.resultBuilder(io.prestosql.testing.MaterializedResult.resultBuilder) TypeSignature(io.prestosql.spi.type.TypeSignature) Pattern(java.util.regex.Pattern) NodeVersion(io.prestosql.client.NodeVersion) BigintType(io.prestosql.spi.type.BigintType) TestPhasedExecutionSchedule.createTableScanPlanFragment(io.prestosql.execution.scheduler.TestPhasedExecutionSchedule.createTableScanPlanFragment) BUCKET_COLUMN_NAME(io.prestosql.plugin.hive.HiveColumnHandle.BUCKET_COLUMN_NAME) Assert.assertNull(org.testng.Assert.assertNull) LegacyNetworkTopology(io.prestosql.execution.scheduler.LegacyNetworkTopology) ORDERS(io.airlift.tpch.TpchTable.ORDERS) BROADCAST(io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType.BROADCAST) StatsAndCosts(io.prestosql.cost.StatsAndCosts) HashMap(java.util.HashMap) Split(io.prestosql.metadata.Split) BUCKETED_BY_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.BUCKETED_BY_PROPERTY) Multimap(com.google.common.collect.Multimap) TableHandle(io.prestosql.spi.metadata.TableHandle) OptionalInt(java.util.OptionalInt) Function(java.util.function.Function) TestingSession.testSessionBuilder(io.prestosql.testing.TestingSession.testSessionBuilder) PlanPrinter.textLogicalPlan(io.prestosql.sql.planner.planprinter.PlanPrinter.textLogicalPlan) TestingAccessControlManager.privilege(io.prestosql.testing.TestingAccessControlManager.privilege) ImmutableList(com.google.common.collect.ImmutableList) TestingSplit(io.prestosql.testing.TestingSplit) CONCURRENT_LIFESPANS_PER_NODE(io.prestosql.SystemSessionProperties.CONCURRENT_LIFESPANS_PER_NODE) Assertions.assertThatThrownBy(org.assertj.core.api.Assertions.assertThatThrownBy) LocalStateStoreProvider(io.prestosql.statestore.LocalStateStoreProvider) Verify.verify(com.google.common.base.Verify.verify) Threads.daemonThreadsNamed(io.airlift.concurrent.Threads.daemonThreadsNamed) DoubleType(io.prestosql.spi.type.DoubleType) Objects.requireNonNull(java.util.Objects.requireNonNull) QueryId(io.prestosql.spi.QueryId) SmallintType(io.prestosql.spi.type.SmallintType) STORAGE_FORMAT_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.STORAGE_FORMAT_PROPERTY) ExecutorService(java.util.concurrent.ExecutorService) PlanFragment(io.prestosql.sql.planner.PlanFragment) GROUPED_EXECUTION(io.prestosql.SystemSessionProperties.GROUPED_EXECUTION) TableInfo(io.prestosql.execution.TableInfo) FormattedDomain(io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain) UTF_8(java.nio.charset.StandardCharsets.UTF_8) ColumnMetadata(io.prestosql.spi.connector.ColumnMetadata) TupleDomain(io.prestosql.spi.predicate.TupleDomain) Assert.fail(org.testng.Assert.fail) NoOpFailureDetector(io.prestosql.failuredetector.NoOpFailureDetector) SELECT_COLUMN(io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType.SELECT_COLUMN) DynamicFilterService(io.prestosql.dynamicfilter.DynamicFilterService) TimeUnit(java.util.concurrent.TimeUnit) Consumer(java.util.function.Consumer) PlanNodeSearcher.searchFrom(io.prestosql.sql.planner.optimizations.PlanNodeSearcher.searchFrom) ROLE(io.prestosql.spi.security.SelectedRole.Type.ROLE) PARTITIONED_BY_PROPERTY(io.prestosql.plugin.hive.HiveTableProperties.PARTITIONED_BY_PROPERTY) Collectors.toList(java.util.stream.Collectors.toList) SMALLINT(io.prestosql.spi.type.SmallintType.SMALLINT) Executors.newCachedThreadPool(java.util.concurrent.Executors.newCachedThreadPool) SplitKey(io.prestosql.execution.SplitKey) DateType(io.prestosql.spi.type.DateType) FILE_INPUT_FORMAT(org.apache.hadoop.hive.metastore.api.hive_metastoreConstants.FILE_INPUT_FORMAT) Assert.assertTrue(org.testng.Assert.assertTrue) CatalogSchemaTableName(io.prestosql.spi.connector.CatalogSchemaTableName) ImmutableList(com.google.common.collect.ImmutableList) ArrayList(java.util.ArrayList) Properties(java.util.Properties) ColumnConstraint(io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint) Constraint(io.prestosql.spi.connector.Constraint) ConnectorSplit(io.prestosql.spi.connector.ConnectorSplit) Split(io.prestosql.metadata.Split) TestingSplit(io.prestosql.testing.TestingSplit) ConnectorSplit(io.prestosql.spi.connector.ConnectorSplit)

Aggregations

Joiner (com.google.common.base.Joiner)2 Preconditions.checkState (com.google.common.base.Preconditions.checkState)2 Verify.verify (com.google.common.base.Verify.verify)2 ImmutableList (com.google.common.collect.ImmutableList)2 ImmutableMap (com.google.common.collect.ImmutableMap)2 ImmutableSet (com.google.common.collect.ImmutableSet)2 Iterables.getOnlyElement (com.google.common.collect.Iterables.getOnlyElement)2 Multimap (com.google.common.collect.Multimap)2 Files.asCharSink (com.google.common.io.Files.asCharSink)2 MoreFiles.deleteRecursively (com.google.common.io.MoreFiles.deleteRecursively)2 ALLOW_INSECURE (com.google.common.io.RecursiveDeleteOption.ALLOW_INSECURE)2 Threads.daemonThreadsNamed (io.airlift.concurrent.Threads.daemonThreadsNamed)2 JsonCodec.jsonCodec (io.airlift.json.JsonCodec.jsonCodec)2 CUSTOMER (io.airlift.tpch.TpchTable.CUSTOMER)2 LINE_ITEM (io.airlift.tpch.TpchTable.LINE_ITEM)2 ORDERS (io.airlift.tpch.TpchTable.ORDERS)2 Session (io.prestosql.Session)2 TEST_SESSION (io.prestosql.SessionTestUtils.TEST_SESSION)2 TEST_SESSION_REUSE (io.prestosql.SessionTestUtils.TEST_SESSION_REUSE)2 COLOCATED_JOIN (io.prestosql.SystemSessionProperties.COLOCATED_JOIN)2