Package | Description |
---|---|
com.facebook.presto.operator | |
com.facebook.presto.operator.repartition | |
com.facebook.presto.sql.planner | |
com.facebook.presto.testing |
Modifier and Type | Class and Description |
---|---|
static class |
TaskOutputOperator.TaskOutputFactory |
Modifier and Type | Class and Description |
---|---|
static class |
OptimizedPartitionedOutputOperator.OptimizedPartitionedOutputFactory |
static class |
PartitionedOutputOperator.PartitionedOutputFactory |
Modifier and Type | Method and Description |
---|---|
LocalExecutionPlanner.LocalExecutionPlan |
LocalExecutionPlanner.plan(TaskContext taskContext,
PlanNode plan,
PartitioningScheme partitioningScheme,
StageExecutionDescriptor stageExecutionDescriptor,
List<PlanNodeId> partitionedSourceOrder,
OutputFactory outputFactory,
RemoteSourceFactory remoteSourceFactory,
TableWriteInfo tableWriteInfo,
boolean pageSinkCommitRequired) |
LocalExecutionPlanner.LocalExecutionPlan |
LocalExecutionPlanner.plan(TaskContext taskContext,
StageExecutionDescriptor stageExecutionDescriptor,
PlanNode plan,
PartitioningScheme partitioningScheme,
List<PlanNodeId> partitionedSourceOrder,
OutputFactory outputOperatorFactory,
Optional<OutputPartitioning> outputPartitioning,
RemoteSourceFactory remoteSourceFactory,
TableWriteInfo tableWriteInfo,
boolean pageSinkCommitRequired) |
Modifier and Type | Class and Description |
---|---|
static class |
NullOutputOperator.NullOutputFactory |
static class |
PageConsumerOperator.PageConsumerOutputFactory |
Modifier and Type | Method and Description |
---|---|
List<Driver> |
LocalQueryRunner.createDrivers(Session session,
String sql,
OutputFactory outputFactory,
TaskContext taskContext) |
List<Driver> |
LocalQueryRunner.createDrivers(String sql,
OutputFactory outputFactory,
TaskContext taskContext) |
Copyright © 2012–2022. All rights reserved.