Modifier and Type | Method and Description |
---|---|
Collection<TaskManagerLocation> |
SlotProfile.getPreferredLocations()
Returns the preferred locations for the slot.
|
Modifier and Type | Method and Description |
---|---|
static SlotProfile |
SlotProfile.preferredLocality(ResourceProfile resourceProfile,
Collection<TaskManagerLocation> preferredLocations)
Returns a slot profile for the given resource profile and the preferred locations.
|
static SlotProfile |
SlotProfile.priorAllocation(ResourceProfile taskResourceProfile,
ResourceProfile physicalSlotResourceProfile,
Collection<TaskManagerLocation> preferredLocations,
Collection<AllocationID> priorAllocations,
Set<AllocationID> previousExecutionGraphAllocations)
Returns a slot profile for the given resource profile, prior allocations and
all prior allocation ids from the whole execution graph.
|
Modifier and Type | Method and Description |
---|---|
TaskManagerLocation |
ArchivedExecution.getAssignedResourceLocation() |
TaskManagerLocation |
Execution.getAssignedResourceLocation() |
TaskManagerLocation |
AccessExecution.getAssignedResourceLocation()
Returns the
TaskManagerLocation for this execution. |
TaskManagerLocation |
AccessExecutionVertex.getCurrentAssignedResourceLocation()
Returns the
TaskManagerLocation for this execution vertex. |
TaskManagerLocation |
ExecutionVertex.getCurrentAssignedResourceLocation() |
TaskManagerLocation |
ArchivedExecutionVertex.getCurrentAssignedResourceLocation() |
TaskManagerLocation |
ExecutionVertex.getLatestPriorLocation()
Gets the location where the latest completed/canceled/failed execution of the vertex's
task happened.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<TaskManagerLocation>> |
Execution.calculatePreferredLocations(LocationPreferenceConstraint locationPreferenceConstraint)
Calculates the preferred locations based on the location preference constraint.
|
CompletableFuture<TaskManagerLocation> |
ExecutionVertex.getCurrentTaskManagerLocationFuture() |
Optional<TaskManagerLocation> |
ExecutionVertex.getPreferredLocationBasedOnState()
Gets the preferred location to execute the current task execution attempt, based on the state
that the execution attempt will resume.
|
Collection<CompletableFuture<TaskManagerLocation>> |
ExecutionVertex.getPreferredLocations()
Gets the overall preferred execution location for this vertex's current execution.
|
Collection<CompletableFuture<TaskManagerLocation>> |
ExecutionVertex.getPreferredLocationsBasedOnInputs()
Gets the location preferences of the vertex's current task execution, as determined by the locations
of the predecessors from which it receives input data.
|
Collection<CompletableFuture<TaskManagerLocation>> |
ExecutionVertex.getPreferredLocationsBasedOnState()
Gets the preferred location to execute the current task execution attempt, based on the state
that the execution attempt will resume.
|
CompletableFuture<TaskManagerLocation> |
Execution.getTaskManagerLocationFuture() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Execution> |
Execution.registerProducedPartitions(TaskManagerLocation location) |
CompletableFuture<Execution> |
Execution.registerProducedPartitions(TaskManagerLocation location,
boolean sendScheduleOrUpdateConsumersMessage) |
Constructor and Description |
---|
ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators,
IOMetrics ioMetrics,
ExecutionAttemptID attemptId,
int attemptNumber,
ExecutionState state,
String failureCause,
TaskManagerLocation assignedResourceLocation,
AllocationID assignedAllocationID,
int parallelSubtaskIndex,
long[] stateTimestamps) |
Constructor and Description |
---|
ConnectionID(TaskManagerLocation connectionInfo,
int connectionIndex) |
Modifier and Type | Method and Description |
---|---|
TaskManagerLocation |
CoLocationConstraint.getLocation()
Gets the location assigned to this slot.
|
Modifier and Type | Method and Description |
---|---|
void |
CoLocationConstraint.lockLocation(TaskManagerLocation taskManagerLocation)
Locks the location of this slot.
|
Modifier and Type | Method and Description |
---|---|
TaskManagerLocation |
SlotInfo.getTaskManagerLocation()
Gets the location info of the TaskManager that offers this slot.
|
TaskManagerLocation |
LogicalSlot.getTaskManagerLocation()
Return the TaskManager location of this slot.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<RegistrationResponse> |
JobMaster.registerTaskManager(String taskManagerRpcAddress,
TaskManagerLocation taskManagerLocation,
Time timeout) |
CompletableFuture<RegistrationResponse> |
JobMasterGateway.registerTaskManager(String taskManagerRpcAddress,
TaskManagerLocation taskManagerLocation,
Time timeout)
Registers the task manager at the job manager.
|
Modifier and Type | Method and Description |
---|---|
TaskManagerLocation |
SingleLogicalSlot.getTaskManagerLocation() |
TaskManagerLocation |
SlotInfoWithUtilization.getTaskManagerLocation() |
Modifier and Type | Method and Description |
---|---|
Collection<SlotOffer> |
SlotPoolImpl.offerSlots(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection<SlotOffer> offers) |
Collection<SlotOffer> |
SlotPool.offerSlots(TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection<SlotOffer> offers)
Offers multiple slots to the
SlotPool . |
Modifier and Type | Method and Description |
---|---|
Collection<TaskManagerLocation> |
ExecutionVertexSchedulingRequirements.getPreferredLocations() |
Optional<CompletableFuture<TaskManagerLocation>> |
ExecutionGraphToInputsLocationsRetrieverAdapter.getTaskManagerLocation(ExecutionVertexID executionVertexId) |
Optional<CompletableFuture<TaskManagerLocation>> |
InputsLocationsRetriever.getTaskManagerLocation(ExecutionVertexID executionVertexId)
Get the task manager location future for an execution.
|
Modifier and Type | Method and Description |
---|---|
ExecutionVertexSchedulingRequirements.Builder |
ExecutionVertexSchedulingRequirements.Builder.withPreferredLocations(Collection<TaskManagerLocation> preferredLocations) |
Modifier and Type | Method and Description |
---|---|
static ProducerDescriptor |
ProducerDescriptor.create(TaskManagerLocation producerLocation,
ExecutionAttemptID attemptId) |
Modifier and Type | Method and Description |
---|---|
TaskManagerLocation |
TaskManagerServices.getTaskManagerLocation() |
Constructor and Description |
---|
JobLeaderService(TaskManagerLocation location,
RetryingRegistrationConfiguration retryingRegistrationConfiguration) |
Modifier and Type | Method and Description |
---|---|
int |
TaskManagerLocation.compareTo(TaskManagerLocation o) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.