Search in sources :

Example 1 with HiveTypeTranslator

use of io.prestosql.plugin.hive.HiveTypeTranslator in project carbondata by apache.

the class CarbondataModule method configure.

@Override
public void configure(Binder binder) {
    binder.install(new HiveHdfsModule());
    binder.bind(TypeTranslator.class).toInstance(new HiveTypeTranslator());
    binder.bind(CoercionPolicy.class).to(HiveCoercionPolicy.class).in(Scopes.SINGLETON);
    binder.bind(DirectoryLister.class).to(CachingDirectoryLister.class).in(Scopes.SINGLETON);
    configBinder(binder).bindConfig(HiveConfig.class);
    binder.bind(HiveSessionProperties.class).in(Scopes.SINGLETON);
    binder.bind(HiveTableProperties.class).in(Scopes.SINGLETON);
    binder.bind(HiveAnalyzeProperties.class).in(Scopes.SINGLETON);
    binder.bind(PrestoS3ClientFactory.class).in(Scopes.SINGLETON);
    binder.bind(CachingDirectoryLister.class).in(Scopes.SINGLETON);
    newExporter(binder).export(CachingDirectoryLister.class).withGeneratedName();
    binder.bind(HiveWriterStats.class).in(Scopes.SINGLETON);
    newExporter(binder).export(HiveWriterStats.class).withGeneratedName();
    newSetBinder(binder, EventClient.class).addBinding().to(HiveEventClient.class).in(Scopes.SINGLETON);
    binder.bind(HivePartitionManager.class).in(Scopes.SINGLETON);
    binder.bind(LocationService.class).to(HiveLocationService.class).in(Scopes.SINGLETON);
    binder.bind(HiveLocationService.class).to(CarbonDataLocationService.class).in(Scopes.SINGLETON);
    binder.bind(HiveMetadataFactory.class).to(CarbonMetadataFactory.class).in(Scopes.SINGLETON);
    binder.bind(TransactionalMetadataFactory.class).to(HiveMetadataFactory.class).in(Scopes.SINGLETON);
    binder.bind(HiveTransactionManager.class).in(Scopes.SINGLETON);
    binder.bind(ConnectorSplitManager.class).to(CarbondataSplitManager.class).in(Scopes.SINGLETON);
    newExporter(binder).export(ConnectorSplitManager.class).as(generator -> generator.generatedNameOf(CarbondataSplitManager.class));
    binder.bind(ConnectorPageSourceProvider.class).to(CarbondataPageSourceProvider.class).in(Scopes.SINGLETON);
    binder.bind(ConnectorPageSinkProvider.class).to(CarbonDataPageSinkProvider.class).in(Scopes.SINGLETON);
    binder.bind(ConnectorNodePartitioningProvider.class).to(HiveNodePartitioningProvider.class).in(Scopes.SINGLETON);
    jsonCodecBinder(binder).bindJsonCodec(PartitionUpdate.class);
    binder.bind(FileFormatDataSourceStats.class).in(Scopes.SINGLETON);
    newExporter(binder).export(FileFormatDataSourceStats.class).withGeneratedName();
    Multibinder<HivePageSourceFactory> pageSourceFactoryBinder = newSetBinder(binder, HivePageSourceFactory.class);
    pageSourceFactoryBinder.addBinding().to(OrcPageSourceFactory.class).in(Scopes.SINGLETON);
    pageSourceFactoryBinder.addBinding().to(ParquetPageSourceFactory.class).in(Scopes.SINGLETON);
    pageSourceFactoryBinder.addBinding().to(RcFilePageSourceFactory.class).in(Scopes.SINGLETON);
    Multibinder<HiveRecordCursorProvider> recordCursorProviderBinder = newSetBinder(binder, HiveRecordCursorProvider.class);
    recordCursorProviderBinder.addBinding().to(S3SelectRecordCursorProvider.class).in(Scopes.SINGLETON);
    binder.bind(GenericHiveRecordCursorProvider.class).in(Scopes.SINGLETON);
    Multibinder<HiveFileWriterFactory> fileWriterFactoryBinder = newSetBinder(binder, HiveFileWriterFactory.class);
    binder.bind(OrcFileWriterFactory.class).in(Scopes.SINGLETON);
    newExporter(binder).export(OrcFileWriterFactory.class).withGeneratedName();
    configBinder(binder).bindConfig(OrcReaderConfig.class);
    configBinder(binder).bindConfig(OrcWriterConfig.class);
    fileWriterFactoryBinder.addBinding().to(OrcFileWriterFactory.class).in(Scopes.SINGLETON);
    fileWriterFactoryBinder.addBinding().to(RcFileFileWriterFactory.class).in(Scopes.SINGLETON);
    configBinder(binder).bindConfig(ParquetReaderConfig.class);
    configBinder(binder).bindConfig(ParquetWriterConfig.class);
    fileWriterFactoryBinder.addBinding().to(CarbonDataFileWriterFactory.class).in(Scopes.SINGLETON);
    binder.bind(CarbonTableReader.class).in(Scopes.SINGLETON);
    jsonBinder(binder).addDeserializerBinding(Type.class).to(TypeDeserializer.class);
    newSetBinder(binder, SystemTable.class);
    // configure carbon properties
    CarbonProperties.getInstance().addProperty(CarbonCommonConstants.IS_QUERY_FROM_PRESTO, "true");
}
Also used : TypeTranslator(io.prestosql.plugin.hive.TypeTranslator) HiveTypeTranslator(io.prestosql.plugin.hive.HiveTypeTranslator) HiveMetadataFactory(io.prestosql.plugin.hive.HiveMetadataFactory) HivePartitionManager(io.prestosql.plugin.hive.HivePartitionManager) HiveCoercionPolicy(io.prestosql.plugin.hive.HiveCoercionPolicy) S3SelectRecordCursorProvider(io.prestosql.plugin.hive.s3select.S3SelectRecordCursorProvider) OrcPageSourceFactory(io.prestosql.plugin.hive.orc.OrcPageSourceFactory) HiveSessionProperties(io.prestosql.plugin.hive.HiveSessionProperties) HiveLocationService(io.prestosql.plugin.hive.HiveLocationService) HiveAnalyzeProperties(io.prestosql.plugin.hive.HiveAnalyzeProperties) ParquetPageSourceFactory(io.prestosql.plugin.hive.parquet.ParquetPageSourceFactory) CachingDirectoryLister(io.prestosql.plugin.hive.CachingDirectoryLister) HiveTableProperties(io.prestosql.plugin.hive.HiveTableProperties) HiveEventClient(io.prestosql.plugin.hive.HiveEventClient) HiveWriterStats(io.prestosql.plugin.hive.HiveWriterStats) FileFormatDataSourceStats(io.prestosql.plugin.hive.FileFormatDataSourceStats) GenericHiveRecordCursorProvider(io.prestosql.plugin.hive.GenericHiveRecordCursorProvider) HiveRecordCursorProvider(io.prestosql.plugin.hive.HiveRecordCursorProvider) EventClient(io.airlift.event.client.EventClient) HiveEventClient(io.prestosql.plugin.hive.HiveEventClient) OrcFileWriterFactory(io.prestosql.plugin.hive.orc.OrcFileWriterFactory) CarbonTableReader(org.apache.carbondata.presto.impl.CarbonTableReader) Type(io.prestosql.spi.type.Type) HiveTypeTranslator(io.prestosql.plugin.hive.HiveTypeTranslator) PrestoS3ClientFactory(io.prestosql.plugin.hive.s3select.PrestoS3ClientFactory) ConnectorSplitManager(io.prestosql.spi.connector.ConnectorSplitManager) GenericHiveRecordCursorProvider(io.prestosql.plugin.hive.GenericHiveRecordCursorProvider) HiveHdfsModule(io.prestosql.plugin.hive.HiveHdfsModule) RcFileFileWriterFactory(io.prestosql.plugin.hive.RcFileFileWriterFactory) HiveTransactionManager(io.prestosql.plugin.hive.HiveTransactionManager) HiveNodePartitioningProvider(io.prestosql.plugin.hive.HiveNodePartitioningProvider) HivePageSourceFactory(io.prestosql.plugin.hive.HivePageSourceFactory) HiveFileWriterFactory(io.prestosql.plugin.hive.HiveFileWriterFactory) RcFilePageSourceFactory(io.prestosql.plugin.hive.rcfile.RcFilePageSourceFactory)

Example 2 with HiveTypeTranslator

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

the class HiveProjectPushdown method tryProjectPushdown.

protected static Optional<TableScanNode> tryProjectPushdown(ProjectNode plan, Map<String, Type> types) {
    if (!(plan.getSource() instanceof TableScanNode)) {
        return Optional.empty();
    }
    TableScanNode tableScanNode = (TableScanNode) plan.getSource();
    ConnectorTableHandle tableHandle = tableScanNode.getTable().getConnectorHandle();
    if (!(tableHandle instanceof HiveTableHandle) || !(((HiveTableHandle) tableHandle).getOffloadExpression().getProjections().isEmpty())) {
        return Optional.empty();
    }
    Map<Symbol, ColumnHandle> assignments = new HashMap<>();
    HiveTypeTranslator hiveTypeTranslator = new HiveTypeTranslator();
    for (Map.Entry<Symbol, RowExpression> entry : plan.getAssignments().entrySet()) {
        String name = entry.getKey().getName();
        HiveType hiveType = HiveType.toHiveType(hiveTypeTranslator, entry.getValue().getType());
        TypeSignature typeSignature = entry.getValue().getType().getTypeSignature();
        HiveColumnHandle columnHandle = new HiveColumnHandle(name, hiveType, typeSignature, DUMMY_OFFLOADED_COLUMN_INDEX, DUMMY_OFFLOADED, Optional.of("projections pushed down " + name));
        assignments.put(entry.getKey(), columnHandle);
    }
    BiMap<VariableReferenceExpression, VariableReferenceExpression> variableToColumnMapping = tableScanNode.getAssignments().entrySet().stream().collect(toImmutableBiMap(entry -> new VariableReferenceExpression(entry.getKey().getName(), types.get(entry.getKey().getName())), entry -> new VariableReferenceExpression(entry.getValue().getColumnName(), types.get(entry.getKey().getName()))));
    ImmutableMap.Builder<Symbol, RowExpression> projections = new ImmutableMap.Builder<>();
    for (Map.Entry<Symbol, RowExpression> entry : plan.getAssignments().getMap().entrySet()) {
        RowExpression expression = replaceExpression(entry.getValue(), variableToColumnMapping);
        if (!OmniExpressionChecker.checkExpression(expression)) {
            return Optional.empty();
        }
        projections.put(entry.getKey(), expression);
    }
    HiveTableHandle hiveTableHandle = (HiveTableHandle) tableHandle;
    HiveOffloadExpression offloadExpression = hiveTableHandle.getOffloadExpression().updateProjections(projections.build(), getDataSourceColumns(tableScanNode));
    HiveTableHandle newHiveTableHandle = hiveTableHandle.withOffloadExpression(offloadExpression);
    TableHandle newTableHandle = new TableHandle(tableScanNode.getTable().getCatalogName(), newHiveTableHandle, tableScanNode.getTable().getTransaction(), tableScanNode.getTable().getLayout());
    return Optional.of(new TableScanNode(tableScanNode.getId(), newTableHandle, ImmutableList.copyOf(assignments.keySet()), assignments, tableScanNode.getEnforcedConstraint(), tableScanNode.getPredicate(), tableScanNode.getStrategy(), tableScanNode.getReuseTableScanMappingId(), tableScanNode.getConsumerTableScanNodeCount(), tableScanNode.isForDelete()));
}
Also used : HiveTableHandle(io.prestosql.plugin.hive.HiveTableHandle) HivePushdownUtil.getDataSourceColumns(io.prestosql.plugin.hive.rule.HivePushdownUtil.getDataSourceColumns) HiveTypeTranslator(io.prestosql.plugin.hive.HiveTypeTranslator) HashMap(java.util.HashMap) HiveColumnHandle(io.prestosql.plugin.hive.HiveColumnHandle) TableHandle(io.prestosql.spi.metadata.TableHandle) ImmutableList(com.google.common.collect.ImmutableList) OmniExpressionChecker(com.huawei.boostkit.omnidata.expression.OmniExpressionChecker) Map(java.util.Map) Type(io.prestosql.spi.type.Type) RowExpressionNodeInliner.replaceExpression(io.prestosql.expressions.RowExpressionNodeInliner.replaceExpression) Symbol(io.prestosql.spi.plan.Symbol) BiMap(com.google.common.collect.BiMap) DUMMY_OFFLOADED_COLUMN_INDEX(io.prestosql.plugin.hive.HiveColumnHandle.DUMMY_OFFLOADED_COLUMN_INDEX) ImmutableMap(com.google.common.collect.ImmutableMap) ConnectorTableHandle(io.prestosql.spi.connector.ConnectorTableHandle) TableScanNode(io.prestosql.spi.plan.TableScanNode) VariableReferenceExpression(io.prestosql.spi.relation.VariableReferenceExpression) HiveType(io.prestosql.plugin.hive.HiveType) ProjectNode(io.prestosql.spi.plan.ProjectNode) HiveOffloadExpression(io.prestosql.plugin.hive.HiveOffloadExpression) ColumnHandle(io.prestosql.spi.connector.ColumnHandle) DUMMY_OFFLOADED(io.prestosql.plugin.hive.HiveColumnHandle.ColumnType.DUMMY_OFFLOADED) RowExpression(io.prestosql.spi.relation.RowExpression) Optional(java.util.Optional) ImmutableBiMap.toImmutableBiMap(com.google.common.collect.ImmutableBiMap.toImmutableBiMap) TypeSignature(io.prestosql.spi.type.TypeSignature) HiveColumnHandle(io.prestosql.plugin.hive.HiveColumnHandle) ColumnHandle(io.prestosql.spi.connector.ColumnHandle) HashMap(java.util.HashMap) Symbol(io.prestosql.spi.plan.Symbol) RowExpression(io.prestosql.spi.relation.RowExpression) ImmutableMap(com.google.common.collect.ImmutableMap) ConnectorTableHandle(io.prestosql.spi.connector.ConnectorTableHandle) TypeSignature(io.prestosql.spi.type.TypeSignature) HiveTableHandle(io.prestosql.plugin.hive.HiveTableHandle) HiveTypeTranslator(io.prestosql.plugin.hive.HiveTypeTranslator) TableScanNode(io.prestosql.spi.plan.TableScanNode) VariableReferenceExpression(io.prestosql.spi.relation.VariableReferenceExpression) HiveOffloadExpression(io.prestosql.plugin.hive.HiveOffloadExpression) HiveTableHandle(io.prestosql.plugin.hive.HiveTableHandle) TableHandle(io.prestosql.spi.metadata.TableHandle) ConnectorTableHandle(io.prestosql.spi.connector.ConnectorTableHandle) HiveType(io.prestosql.plugin.hive.HiveType) HashMap(java.util.HashMap) Map(java.util.Map) BiMap(com.google.common.collect.BiMap) ImmutableMap(com.google.common.collect.ImmutableMap) ImmutableBiMap.toImmutableBiMap(com.google.common.collect.ImmutableBiMap.toImmutableBiMap) HiveColumnHandle(io.prestosql.plugin.hive.HiveColumnHandle)

Example 3 with HiveTypeTranslator

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

the class CarbondataModule method configure.

@Override
public void configure(Binder binder) {
    binder.bind(TypeTranslator.class).toInstance(new HiveTypeTranslator());
    binder.bind(CoercionPolicy.class).to(HiveCoercionPolicy.class).in(Scopes.SINGLETON);
    binder.bind(HdfsConfigurationInitializer.class).in(Scopes.SINGLETON);
    newSetBinder(binder, DynamicConfigurationProvider.class);
    binder.bind(HdfsConfiguration.class).to(HiveHdfsConfiguration.class).in(Scopes.SINGLETON);
    binder.bind(HdfsEnvironment.class).in(Scopes.SINGLETON);
    binder.bind(DirectoryLister.class).to(CachingDirectoryLister.class).in(Scopes.SINGLETON);
    configBinder(binder).bindConfig(CarbondataConfig.class);
    binder.bind(HiveSessionProperties.class).in(Scopes.SINGLETON);
    binder.bind(CarbondataTableProperties.class).in(Scopes.SINGLETON);
    binder.bind(HiveAnalyzeProperties.class).in(Scopes.SINGLETON);
    binder.bind(NamenodeStats.class).in(Scopes.SINGLETON);
    newExporter(binder).export(NamenodeStats.class).as(generatedNameOf(NamenodeStats.class, connectorId));
    Multibinder<HiveRecordCursorProvider> recordCursorProviderBinder = newSetBinder(binder, HiveRecordCursorProvider.class);
    recordCursorProviderBinder.addBinding().to(GenericHiveRecordCursorProvider.class).in(Scopes.SINGLETON);
    binder.bind(HiveWriterStats.class).in(Scopes.SINGLETON);
    newExporter(binder).export(HiveWriterStats.class).as(generatedNameOf(HiveWriterStats.class, connectorId));
    newSetBinder(binder, EventClient.class).addBinding().to(HiveEventClient.class).in(Scopes.SINGLETON);
    binder.bind(HivePartitionManager.class).in(Scopes.SINGLETON);
    binder.bind(LocationService.class).to(CarbondataLocationService.class).in(Scopes.SINGLETON);
    binder.bind(HiveMetadataFactory.class).to(CarbondataMetadataFactory.class).in(Scopes.SINGLETON);
    binder.bind(new TypeLiteral<Supplier<TransactionalMetadata>>() {
    }).to(HiveMetadataFactory.class).in(Scopes.SINGLETON);
    binder.bind(HiveTransactionManager.class).in(Scopes.SINGLETON);
    binder.bind(ConnectorSplitManager.class).to(CarbondataSplitManager.class).in(Scopes.SINGLETON);
    newExporter(binder).export(ConnectorSplitManager.class).as(generatedNameOf(HiveSplitManager.class, connectorId));
    binder.bind(ConnectorPageSourceProvider.class).to(CarbondataPageSourceProvider.class).in(Scopes.SINGLETON);
    binder.bind(ConnectorPageSinkProvider.class).to(CarbondataPageSinkProvider.class).in(Scopes.SINGLETON);
    binder.bind(ConnectorNodePartitioningProvider.class).to(HiveNodePartitioningProvider.class).in(Scopes.SINGLETON);
    jsonCodecBinder(binder).bindJsonCodec(PartitionUpdate.class);
    jsonCodecBinder(binder).bindJsonCodec(CarbondataSegmentInfoUtil.class);
    binder.bind(FileFormatDataSourceStats.class).in(Scopes.SINGLETON);
    newExporter(binder).export(FileFormatDataSourceStats.class).as(generatedNameOf(FileFormatDataSourceStats.class, connectorId));
    Multibinder<HivePageSourceFactory> pageSourceFactoryBinder = newSetBinder(binder, HivePageSourceFactory.class);
    pageSourceFactoryBinder.addBinding().to(OrcPageSourceFactory.class).in(Scopes.SINGLETON);
    pageSourceFactoryBinder.addBinding().to(ParquetPageSourceFactory.class).in(Scopes.SINGLETON);
    pageSourceFactoryBinder.addBinding().to(RcFilePageSourceFactory.class).in(Scopes.SINGLETON);
    Multibinder<HiveFileWriterFactory> fileWriterFactoryBinder = newSetBinder(binder, HiveFileWriterFactory.class);
    binder.bind(OrcFileWriterFactory.class).in(Scopes.SINGLETON);
    newExporter(binder).export(OrcFileWriterFactory.class).as(generatedNameOf(OrcFileWriterFactory.class, connectorId));
    configBinder(binder).bindConfig(OrcFileWriterConfig.class);
    fileWriterFactoryBinder.addBinding().to(OrcFileWriterFactory.class).in(Scopes.SINGLETON);
    fileWriterFactoryBinder.addBinding().to(RcFileFileWriterFactory.class).in(Scopes.SINGLETON);
    fileWriterFactoryBinder.addBinding().to(CarbondataFileWriterFactory.class).in(Scopes.SINGLETON);
    binder.bind(CarbondataTableReader.class).in(Scopes.SINGLETON);
    configBinder(binder).bindConfig(ParquetFileWriterConfig.class);
}
Also used : HdfsConfigurationInitializer(io.prestosql.plugin.hive.HdfsConfigurationInitializer) TypeTranslator(io.prestosql.plugin.hive.TypeTranslator) HiveTypeTranslator(io.prestosql.plugin.hive.HiveTypeTranslator) HiveMetadataFactory(io.prestosql.plugin.hive.HiveMetadataFactory) HivePartitionManager(io.prestosql.plugin.hive.HivePartitionManager) HiveCoercionPolicy(io.prestosql.plugin.hive.HiveCoercionPolicy) OrcPageSourceFactory(io.prestosql.plugin.hive.orc.OrcPageSourceFactory) HiveSplitManager(io.prestosql.plugin.hive.HiveSplitManager) HiveSessionProperties(io.prestosql.plugin.hive.HiveSessionProperties) HdfsEnvironment(io.prestosql.plugin.hive.HdfsEnvironment) Supplier(java.util.function.Supplier) NamenodeStats(io.prestosql.plugin.hive.NamenodeStats) HiveAnalyzeProperties(io.prestosql.plugin.hive.HiveAnalyzeProperties) CarbondataTableReader(io.hetu.core.plugin.carbondata.impl.CarbondataTableReader) ParquetPageSourceFactory(io.prestosql.plugin.hive.parquet.ParquetPageSourceFactory) HiveHdfsConfiguration(io.prestosql.plugin.hive.HiveHdfsConfiguration) CachingDirectoryLister(io.prestosql.plugin.hive.CachingDirectoryLister) HiveEventClient(io.prestosql.plugin.hive.HiveEventClient) HiveWriterStats(io.prestosql.plugin.hive.HiveWriterStats) FileFormatDataSourceStats(io.prestosql.plugin.hive.FileFormatDataSourceStats) GenericHiveRecordCursorProvider(io.prestosql.plugin.hive.GenericHiveRecordCursorProvider) HiveRecordCursorProvider(io.prestosql.plugin.hive.HiveRecordCursorProvider) EventClient(io.airlift.event.client.EventClient) HiveEventClient(io.prestosql.plugin.hive.HiveEventClient) OrcFileWriterFactory(io.prestosql.plugin.hive.OrcFileWriterFactory) HiveTypeTranslator(io.prestosql.plugin.hive.HiveTypeTranslator) GenericHiveRecordCursorProvider(io.prestosql.plugin.hive.GenericHiveRecordCursorProvider) ConnectorSplitManager(io.prestosql.spi.connector.ConnectorSplitManager) RcFileFileWriterFactory(io.prestosql.plugin.hive.RcFileFileWriterFactory) HiveTransactionManager(io.prestosql.plugin.hive.HiveTransactionManager) HiveNodePartitioningProvider(io.prestosql.plugin.hive.HiveNodePartitioningProvider) HivePageSourceFactory(io.prestosql.plugin.hive.HivePageSourceFactory) HiveFileWriterFactory(io.prestosql.plugin.hive.HiveFileWriterFactory) RcFilePageSourceFactory(io.prestosql.plugin.hive.rcfile.RcFilePageSourceFactory)

Aggregations

HiveTypeTranslator (io.prestosql.plugin.hive.HiveTypeTranslator)3 EventClient (io.airlift.event.client.EventClient)2 CachingDirectoryLister (io.prestosql.plugin.hive.CachingDirectoryLister)2 FileFormatDataSourceStats (io.prestosql.plugin.hive.FileFormatDataSourceStats)2 GenericHiveRecordCursorProvider (io.prestosql.plugin.hive.GenericHiveRecordCursorProvider)2 HiveAnalyzeProperties (io.prestosql.plugin.hive.HiveAnalyzeProperties)2 HiveCoercionPolicy (io.prestosql.plugin.hive.HiveCoercionPolicy)2 HiveEventClient (io.prestosql.plugin.hive.HiveEventClient)2 HiveFileWriterFactory (io.prestosql.plugin.hive.HiveFileWriterFactory)2 HiveMetadataFactory (io.prestosql.plugin.hive.HiveMetadataFactory)2 HiveNodePartitioningProvider (io.prestosql.plugin.hive.HiveNodePartitioningProvider)2 HivePageSourceFactory (io.prestosql.plugin.hive.HivePageSourceFactory)2 HivePartitionManager (io.prestosql.plugin.hive.HivePartitionManager)2 HiveRecordCursorProvider (io.prestosql.plugin.hive.HiveRecordCursorProvider)2 HiveSessionProperties (io.prestosql.plugin.hive.HiveSessionProperties)2 HiveTransactionManager (io.prestosql.plugin.hive.HiveTransactionManager)2 HiveWriterStats (io.prestosql.plugin.hive.HiveWriterStats)2 RcFileFileWriterFactory (io.prestosql.plugin.hive.RcFileFileWriterFactory)2 TypeTranslator (io.prestosql.plugin.hive.TypeTranslator)2 OrcPageSourceFactory (io.prestosql.plugin.hive.orc.OrcPageSourceFactory)2