Package | Description |
---|---|
com.facebook.presto.execution | |
com.facebook.presto.execution.scheduler | |
com.facebook.presto.execution.scheduler.nodeSelection | |
com.facebook.presto.server.remotetask |
Modifier and Type | Method and Description |
---|---|
RemoteTask |
TrackingRemoteTaskFactory.createRemoteTask(Session session,
TaskId taskId,
InternalNode node,
PlanFragment fragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OutputBuffers outputBuffers,
NodeTaskMap.NodeStatsTracker nodeStatsTracker,
boolean summarizeTaskInfo,
TableWriteInfo tableWriteInfo) |
RemoteTask |
RemoteTaskFactory.createRemoteTask(Session session,
TaskId taskId,
InternalNode node,
PlanFragment fragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OutputBuffers outputBuffers,
NodeTaskMap.NodeStatsTracker nodeStatsTracker,
boolean summarizeTaskInfo,
TableWriteInfo tableWriteInfo) |
Modifier and Type | Method and Description |
---|---|
List<RemoteTask> |
SqlStageExecution.getAllTasks() |
Set<RemoteTask> |
SqlStageExecution.scheduleSplits(InternalNode node,
com.google.common.collect.Multimap<PlanNodeId,Split> splits,
com.google.common.collect.Multimap<PlanNodeId,Lifespan> noMoreSplitsNotification) |
Optional<RemoteTask> |
SqlStageExecution.scheduleTask(InternalNode node,
int partition) |
Modifier and Type | Method and Description |
---|---|
void |
NodeTaskMap.addTask(InternalNode node,
RemoteTask task) |
Modifier and Type | Method and Description |
---|---|
void |
SqlStageExecution.addExchangeLocations(PlanFragmentId fragmentId,
Set<RemoteTask> sourceTasks,
boolean noMoreExchangeLocations) |
Modifier and Type | Method and Description |
---|---|
Set<RemoteTask> |
ScheduleResult.getNewTasks() |
Optional<RemoteTask> |
FixedCountScheduler.TaskScheduler.scheduleTask(InternalNode node,
int partition) |
Modifier and Type | Method and Description |
---|---|
void |
PartialResultQueryTaskTracker.trackTask(RemoteTask task) |
Modifier and Type | Method and Description |
---|---|
void |
ExchangeLocationsConsumer.addExchangeLocations(PlanFragmentId fragmentId,
Set<RemoteTask> tasks,
boolean noMoreExchangeLocations) |
static ScheduleResult |
ScheduleResult.blocked(boolean finished,
Iterable<? extends RemoteTask> newTasks,
com.google.common.util.concurrent.ListenableFuture<?> blocked,
ScheduleResult.BlockedReason blockedReason,
int splitsScheduled) |
static ScheduleResult |
ScheduleResult.nonBlocked(boolean finished,
Iterable<? extends RemoteTask> newTasks,
int splitsScheduled) |
void |
StageLinkage.processScheduleResults(StageExecutionState newState,
Set<RemoteTask> newTasks) |
static SplitPlacementResult |
NodeScheduler.selectDistributionNodes(NodeMap nodeMap,
NodeTaskMap nodeTaskMap,
long maxSplitsWeightPerNode,
long maxPendingSplitsWeightPerTask,
int maxUnacknowledgedSplitsPerTask,
Set<Split> splits,
List<RemoteTask> existingTasks,
BucketNodeMap bucketNodeMap,
NodeSelectionStats nodeSelectionStats) |
static com.google.common.util.concurrent.ListenableFuture<?> |
NodeScheduler.toWhenHasSplitQueueSpaceFuture(List<RemoteTask> existingTasks,
long weightSpaceThreshold) |
static com.google.common.util.concurrent.ListenableFuture<?> |
NodeScheduler.toWhenHasSplitQueueSpaceFuture(Set<InternalNode> blockedNodes,
List<RemoteTask> existingTasks,
long weightSpaceThreshold) |
Constructor and Description |
---|
BucketedSplitPlacementPolicy(NodeSelector nodeSelector,
List<InternalNode> activeNodes,
BucketNodeMap bucketNodeMap,
Supplier<? extends List<RemoteTask>> remoteTasks) |
DynamicSplitPlacementPolicy(NodeSelector nodeSelector,
Supplier<? extends List<RemoteTask>> remoteTasks) |
NodeAssignmentStats(NodeTaskMap nodeTaskMap,
NodeMap nodeMap,
List<RemoteTask> existingTasks) |
Modifier and Type | Method and Description |
---|---|
SplitPlacementResult |
TopologyAwareNodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks) |
SplitPlacementResult |
SimpleTtlNodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks) |
SplitPlacementResult |
SimpleNodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks) |
SplitPlacementResult |
NodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks)
Identifies the nodes for running the specified splits.
|
SplitPlacementResult |
TopologyAwareNodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks,
BucketNodeMap bucketNodeMap) |
SplitPlacementResult |
SimpleTtlNodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks,
BucketNodeMap bucketNodeMap) |
SplitPlacementResult |
SimpleNodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks,
BucketNodeMap bucketNodeMap) |
SplitPlacementResult |
NodeSelector.computeAssignments(Set<Split> splits,
List<RemoteTask> existingTasks,
BucketNodeMap bucketNodeMap)
Identifies the nodes for running the specified splits based on a precomputed fixed partitioning.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpRemoteTask |
Modifier and Type | Method and Description |
---|---|
RemoteTask |
HttpRemoteTaskFactory.createRemoteTask(Session session,
TaskId taskId,
InternalNode node,
PlanFragment fragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OutputBuffers outputBuffers,
NodeTaskMap.NodeStatsTracker nodeStatsTracker,
boolean summarizeTaskInfo,
TableWriteInfo tableWriteInfo) |
Copyright © 2012–2022. All rights reserved.