Uses of Class
org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
-
Uses of TaskManagerLocation in org.apache.flink.runtime.clusterframework.types
Methods in org.apache.flink.runtime.clusterframework.types that return types with arguments of type TaskManagerLocation Modifier and Type Method Description Collection<TaskManagerLocation>
SlotProfile. getPreferredLocations()
Returns the preferred locations for the slot.Method parameters in org.apache.flink.runtime.clusterframework.types with type arguments of type TaskManagerLocation Modifier and Type Method Description static SlotProfile
SlotProfile. priorAllocation(ResourceProfile taskResourceProfile, ResourceProfile physicalSlotResourceProfile, Collection<TaskManagerLocation> preferredLocations, Collection<AllocationID> priorAllocations, Set<AllocationID> reservedAllocations)
Returns a slot profile for the given resource profile, prior allocations and all prior allocation ids from the whole execution graph. -
Uses of TaskManagerLocation in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return TaskManagerLocation Modifier and Type Method Description TaskManagerLocation
AccessExecution. getAssignedResourceLocation()
Returns theTaskManagerLocation
for this execution.TaskManagerLocation
ArchivedExecution. getAssignedResourceLocation()
TaskManagerLocation
Execution. getAssignedResourceLocation()
TaskManagerLocation
AccessExecutionVertex. getCurrentAssignedResourceLocation()
Returns theTaskManagerLocation
for this execution vertex.TaskManagerLocation
ArchivedExecutionVertex. getCurrentAssignedResourceLocation()
TaskManagerLocation
ExecutionVertex. getCurrentAssignedResourceLocation()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type TaskManagerLocation Modifier and Type Method Description Optional<TaskManagerLocation>
ExecutionVertex. findLastLocation()
Gets the location that an execution of this vertex was assigned to.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.Optional<TaskManagerLocation>
SpeculativeExecutionVertex. getPreferredLocationBasedOnState()
CompletableFuture<TaskManagerLocation>
Execution. getTaskManagerLocationFuture()
Methods in org.apache.flink.runtime.executiongraph with parameters of type TaskManagerLocation Modifier and Type Method Description void
Execution. recoverExecution(ExecutionAttemptID attemptId, TaskManagerLocation location, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators, IOMetrics metrics)
Recover the execution attempt status after JM failover.CompletableFuture<Void>
Execution. registerProducedPartitions(TaskManagerLocation location)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type TaskManagerLocation Constructor Description ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps)
-
Uses of TaskManagerLocation in org.apache.flink.runtime.io.network
Constructors in org.apache.flink.runtime.io.network with parameters of type TaskManagerLocation Constructor Description ConnectionID(TaskManagerLocation connectionInfo, int connectionIndex)
-
Uses of TaskManagerLocation in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return TaskManagerLocation Modifier and Type Method Description TaskManagerLocation
LogicalSlot. getTaskManagerLocation()
Return the TaskManager location of this slot.TaskManagerLocation
SlotInfo. getTaskManagerLocation()
Gets the location info of the TaskManager that offers this slot. -
Uses of TaskManagerLocation in org.apache.flink.runtime.jobmaster.event
Methods in org.apache.flink.runtime.jobmaster.event that return TaskManagerLocation Modifier and Type Method Description TaskManagerLocation
ExecutionVertexFinishedEvent. getTaskManagerLocation()
Constructors in org.apache.flink.runtime.jobmaster.event with parameters of type TaskManagerLocation Constructor Description ExecutionVertexFinishedEvent(ExecutionAttemptID executionAttemptId, TaskManagerLocation location, Map<OperatorID,CompletableFuture<byte[]>> operatorCoordinatorSnapshotFutures, CompletableFuture<ShuffleMasterSnapshot> shuffleMasterSnapshotFuture, IOMetrics ioMetrics, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators)
-
Uses of TaskManagerLocation in org.apache.flink.runtime.jobmaster.slotpool
Methods in org.apache.flink.runtime.jobmaster.slotpool that return TaskManagerLocation Modifier and Type Method Description TaskManagerLocation
SingleLogicalSlot. getTaskManagerLocation()
Methods in org.apache.flink.runtime.jobmaster.slotpool with parameters of type TaskManagerLocation Modifier and Type Method Description Collection<SlotOffer>
BlocklistDeclarativeSlotPool. offerSlots(Collection<? extends SlotOffer> offers, TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, long currentTime)
Collection<SlotOffer>
DeclarativeSlotPool. offerSlots(Collection<? extends SlotOffer> offers, TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, long currentTime)
Offers slots to this slot pool.Collection<SlotOffer>
DeclarativeSlotPoolBridge. offerSlots(TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, Collection<SlotOffer> offers)
Collection<SlotOffer>
DeclarativeSlotPoolService. offerSlots(TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, Collection<SlotOffer> offers)
Collection<SlotOffer>
DefaultDeclarativeSlotPool. offerSlots(Collection<? extends SlotOffer> offers, TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, long currentTime)
Collection<SlotOffer>
SlotPool. offerSlots(TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, Collection<SlotOffer> offers)
Offers multiple slots to theSlotPool
.Collection<SlotOffer>
SlotPoolService. offerSlots(TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, Collection<SlotOffer> offers)
Offers multiple slots to theSlotPoolService
.Collection<SlotOffer>
BlocklistDeclarativeSlotPool. registerSlots(Collection<? extends SlotOffer> slots, TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, long currentTime)
Collection<SlotOffer>
DeclarativeSlotPool. registerSlots(Collection<? extends SlotOffer> slots, TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, long currentTime)
Registers the given set of slots at the slot pool.Collection<SlotOffer>
DefaultDeclarativeSlotPool. registerSlots(Collection<? extends SlotOffer> slots, TaskManagerLocation taskManagerLocation, TaskManagerGateway taskManagerGateway, long currentTime)
-
Uses of TaskManagerLocation in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return types with arguments of type TaskManagerLocation Modifier and Type Method Description CompletableFuture<Collection<TaskManagerLocation>>
DefaultPreferredLocationsRetriever. getPreferredLocations(ExecutionVertexID executionVertexId, Set<ExecutionVertexID> producersToIgnore)
CompletableFuture<Collection<TaskManagerLocation>>
PreferredLocationsRetriever. getPreferredLocations(ExecutionVertexID executionVertexId, Set<ExecutionVertexID> producersToIgnore)
Returns preferred locations of an execution vertex.Collection<TaskManagerLocation>
SyncPreferredLocationsRetriever. getPreferredLocations(ExecutionVertexID executionVertexId, Set<ExecutionVertexID> producersToIgnore)
Returns preferred locations of an execution vertex.Optional<TaskManagerLocation>
StateLocationRetriever. getStateLocation(ExecutionVertexID executionVertexId)
Returns state location of an execution vertex.Optional<CompletableFuture<TaskManagerLocation>>
ExecutionGraphToInputsLocationsRetrieverAdapter. getTaskManagerLocation(ExecutionVertexID executionVertexId)
Optional<CompletableFuture<TaskManagerLocation>>
InputsLocationsRetriever. getTaskManagerLocation(ExecutionVertexID executionVertexId)
Get the task manager location future for an execution vertex. -
Uses of TaskManagerLocation in org.apache.flink.runtime.scheduler.exceptionhistory
Constructors in org.apache.flink.runtime.scheduler.exceptionhistory with parameters of type TaskManagerLocation Constructor Description ExceptionHistoryEntry(Throwable cause, long timestamp, CompletableFuture<Map<String,String>> failureLabels, String failingTaskName, TaskManagerLocation taskManagerLocation)
Instantiates aExceptionHistoryEntry
.RootExceptionHistoryEntry(Throwable cause, long timestamp, CompletableFuture<Map<String,String>> failureLabels, String failingTaskName, TaskManagerLocation taskManagerLocation, Collection<ExceptionHistoryEntry> concurrentExceptions)
Instantiates aRootExceptionHistoryEntry
. -
Uses of TaskManagerLocation in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle with parameters of type TaskManagerLocation Modifier and Type Method Description static ProducerDescriptor
ProducerDescriptor. create(TaskManagerLocation producerLocation, ExecutionAttemptID attemptId)
-
Uses of TaskManagerLocation in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return TaskManagerLocation Modifier and Type Method Description static TaskManagerLocation
TaskManagerLocation. fromUnresolvedLocation(UnresolvedTaskManagerLocation unresolvedLocation, TaskManagerLocation.ResolutionMode resolutionMode)
Methods in org.apache.flink.runtime.taskmanager with parameters of type TaskManagerLocation Modifier and Type Method Description int
TaskManagerLocation. compareTo(TaskManagerLocation o)
-