Uses of Class
org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
-
-
Uses of ExecutionVertexID in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ExecutionVertexID Modifier and Type Method Description ExecutionVertexIDExecutionAttemptID. getExecutionVertexId()ExecutionVertexIDExecutionVertex. getID()Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionVertexID Modifier and Type Method Description voidEdgeManager. connectVertexWithConsumedPartitionGroup(ExecutionVertexID executionVertexId, ConsumedPartitionGroup consumedPartitionGroup)List<ConsumedPartitionGroup>EdgeManager. getConsumedPartitionGroupsForVertex(ExecutionVertexID executionVertexId)ExecutionVertexDefaultExecutionGraph. getExecutionVertexOrThrow(ExecutionVertexID id)ExecutionVertexInternalExecutionGraphAccessor. getExecutionVertexOrThrow(ExecutionVertexID id)Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionVertexID Constructor Description ExecutionAttemptID(ExecutionGraphID executionGraphId, ExecutionVertexID executionVertexId, int attemptNumber) -
Uses of ExecutionVertexID in org.apache.flink.runtime.executiongraph.failover
Methods in org.apache.flink.runtime.executiongraph.failover that return types with arguments of type ExecutionVertexID Modifier and Type Method Description Set<ExecutionVertexID>FailoverStrategy. getTasksNeedingRestart(ExecutionVertexID executionVertexId, Throwable cause)Returns a set of IDs corresponding to the set of vertices that should be restarted.Set<ExecutionVertexID>RestartAllFailoverStrategy. getTasksNeedingRestart(ExecutionVertexID executionVertexId, Throwable cause)Returns all vertices on any task failure.Set<ExecutionVertexID>RestartPipelinedRegionFailoverStrategy. getTasksNeedingRestart(ExecutionVertexID executionVertexId, Throwable cause)Returns a set of IDs corresponding to the set of vertices that should be restarted.Set<ExecutionVertexID>FailureHandlingResult. getVerticesToRestart()Returns the tasks to restart.Methods in org.apache.flink.runtime.executiongraph.failover with parameters of type ExecutionVertexID Modifier and Type Method Description SchedulingPipelinedRegionRestartPipelinedRegionFailoverStrategy. getFailoverRegion(ExecutionVertexID vertexID)Returns the failover region that contains the given execution vertex.Set<ExecutionVertexID>FailoverStrategy. getTasksNeedingRestart(ExecutionVertexID executionVertexId, Throwable cause)Returns a set of IDs corresponding to the set of vertices that should be restarted.Set<ExecutionVertexID>RestartAllFailoverStrategy. getTasksNeedingRestart(ExecutionVertexID executionVertexId, Throwable cause)Returns all vertices on any task failure.Set<ExecutionVertexID>RestartPipelinedRegionFailoverStrategy. getTasksNeedingRestart(ExecutionVertexID executionVertexId, Throwable cause)Returns a set of IDs corresponding to the set of vertices that should be restarted.Method parameters in org.apache.flink.runtime.executiongraph.failover with type arguments of type ExecutionVertexID Modifier and Type Method Description static Set<Set<SchedulingExecutionVertex>>SchedulingPipelinedRegionComputeUtil. computePipelinedRegions(Iterable<? extends SchedulingExecutionVertex> topologicallySortedVertices, Function<ExecutionVertexID,? extends SchedulingExecutionVertex> executionVertexRetriever, Function<IntermediateResultPartitionID,? extends SchedulingResultPartition> resultPartitionRetriever)static FailureHandlingResultFailureHandlingResult. restartable(Execution failedExecution, Throwable cause, long timestamp, CompletableFuture<Map<String,String>> failureLabels, Set<ExecutionVertexID> verticesToRestart, long restartDelayMS, boolean globalFailure, boolean isRootCause)Creates a result of a set of tasks to restart to recover from the failure. -
Uses of ExecutionVertexID in org.apache.flink.runtime.executiongraph.failover.partitionrelease
Methods in org.apache.flink.runtime.executiongraph.failover.partitionrelease with parameters of type ExecutionVertexID Modifier and Type Method Description booleanRegionPartitionGroupReleaseStrategy. isRegionOfVertexFinished(ExecutionVertexID executionVertexId)List<ConsumedPartitionGroup>NotReleasingPartitionGroupReleaseStrategy. vertexFinished(ExecutionVertexID finishedVertex)List<ConsumedPartitionGroup>PartitionGroupReleaseStrategy. vertexFinished(ExecutionVertexID finishedVertex)Calling this method informs the strategy that a vertex finished.List<ConsumedPartitionGroup>RegionPartitionGroupReleaseStrategy. vertexFinished(ExecutionVertexID finishedVertex)voidNotReleasingPartitionGroupReleaseStrategy. vertexUnfinished(ExecutionVertexID executionVertexID)voidPartitionGroupReleaseStrategy. vertexUnfinished(ExecutionVertexID executionVertexID)Calling this method informs the strategy that a vertex is no longer in finished state, e.g., when a vertex is re-executed.voidRegionPartitionGroupReleaseStrategy. vertexUnfinished(ExecutionVertexID executionVertexId)Method parameters in org.apache.flink.runtime.executiongraph.failover.partitionrelease with type arguments of type ExecutionVertexID Modifier and Type Method Description voidRegionPartitionGroupReleaseStrategy. notifySchedulingTopologyUpdated(SchedulingTopology schedulingTopology, List<ExecutionVertexID> newExecutionVertices) -
Uses of ExecutionVertexID in org.apache.flink.runtime.jobmaster.event
Methods in org.apache.flink.runtime.jobmaster.event that return ExecutionVertexID Modifier and Type Method Description ExecutionVertexIDExecutionVertexFinishedEvent. getExecutionVertexId()Methods in org.apache.flink.runtime.jobmaster.event that return types with arguments of type ExecutionVertexID Modifier and Type Method Description List<ExecutionVertexID>ExecutionVertexResetEvent. getExecutionVertexIds()Constructor parameters in org.apache.flink.runtime.jobmaster.event with type arguments of type ExecutionVertexID Constructor Description ExecutionVertexResetEvent(List<ExecutionVertexID> executionVertexIds) -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ExecutionVertexID Modifier and Type Method Description ExecutionVertexIDExecutionVertexVersion. getExecutionVertexId()Methods in org.apache.flink.runtime.scheduler with parameters of type ExecutionVertexID Modifier and Type Method Description voidExecutionSlotSharingGroup. addVertex(ExecutionVertexID executionVertexId)protected voidDefaultScheduler. cancelAllPendingSlotRequestsForVertex(ExecutionVertexID executionVertexId)Collection<ConsumedPartitionGroup>ExecutionGraphToInputsLocationsRetrieverAdapter. getConsumedPartitionGroups(ExecutionVertexID executionVertexId)Collection<ConsumedPartitionGroup>InputsLocationsRetriever. getConsumedPartitionGroups(ExecutionVertexID executionVertexId)Get the consumed result partition groups of an execution vertex.ExecutionVertexSchedulerBase. getExecutionVertex(ExecutionVertexID executionVertexId)ExecutionVertexVersionExecutionVertexVersioner. getExecutionVertexVersion(ExecutionVertexID executionVertexId)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.ExecutionVertexVersionExecutionVertexVersioner. recordModification(ExecutionVertexID executionVertexId)protected voidSchedulerBase. resetForNewExecution(ExecutionVertexID executionVertexId)Method parameters in org.apache.flink.runtime.scheduler with type arguments of type ExecutionVertexID Modifier and Type Method Description voidDefaultExecutionDeployer. allocateSlotsAndDeploy(List<Execution> executionsToDeploy, Map<ExecutionVertexID,ExecutionVertexVersion> requiredVersionByVertex)voidDefaultScheduler. allocateSlotsAndDeploy(List<ExecutionVertexID> verticesToDeploy)voidExecutionDeployer. allocateSlotsAndDeploy(List<Execution> executionsToDeploy, Map<ExecutionVertexID,ExecutionVertexVersion> requiredVersionByVertex)Allocate slots and deploy executions.voidSchedulerOperations. allocateSlotsAndDeploy(List<ExecutionVertexID> verticesToDeploy)Allocate slots and deploy the vertex when slots are returned.DefaultExecutionDeployerDefaultExecutionDeployer.Factory. createInstance(org.slf4j.Logger log, ExecutionSlotAllocator executionSlotAllocator, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, Duration partitionRegistrationTimeout, BiConsumer<ExecutionVertexID,AllocationID> allocationReservationFunc, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)ExecutionDeployerExecutionDeployer.Factory. createInstance(org.slf4j.Logger log, ExecutionSlotAllocator executionSlotAllocator, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, Duration partitionRegistrationTimeout, BiConsumer<ExecutionVertexID,AllocationID> allocationReservationFunc, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)Instantiate anExecutionDeployerwith the given params.Map<ExecutionVertexID,ExecutionVertexVersion>ExecutionVertexVersioner. getExecutionVertexVersions(Collection<ExecutionVertexID> executionVertexIds)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.voidSchedulingTopologyListener. notifySchedulingTopologyUpdated(SchedulingTopology schedulingTopology, List<ExecutionVertexID> newExecutionVertices)Notifies that the scheduling topology is just updated.Map<ExecutionVertexID,ExecutionVertexVersion>ExecutionVertexVersioner. recordVertexModifications(Collection<ExecutionVertexID> vertices)protected voidSchedulerBase. resetForNewExecutions(Collection<ExecutionVertexID> vertices)protected voidSchedulerBase. restoreState(Set<ExecutionVertexID> vertices, boolean isGlobalRecovery)voidVertexEndOfDataListener. restoreVertices(Set<ExecutionVertexID> executionVertices)protected voidSchedulerBase. transitionToScheduled(List<ExecutionVertexID> verticesToDeploy)Constructor parameters in org.apache.flink.runtime.scheduler with type arguments of type ExecutionVertexID Constructor Description SharingPhysicalSlotRequestBulk(Map<ExecutionSlotSharingGroup,List<ExecutionVertexID>> executions, Map<ExecutionSlotSharingGroup,ResourceProfile> pendingRequests, BiConsumer<ExecutionVertexID,Throwable> logicalSlotRequestCanceller)SharingPhysicalSlotRequestBulk(Map<ExecutionSlotSharingGroup,List<ExecutionVertexID>> executions, Map<ExecutionSlotSharingGroup,ResourceProfile> pendingRequests, BiConsumer<ExecutionVertexID,Throwable> logicalSlotRequestCanceller) -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler.adapter
Methods in org.apache.flink.runtime.scheduler.adapter with parameters of type ExecutionVertexID Modifier and Type Method Description booleanDefaultSchedulingPipelinedRegion. contains(ExecutionVertexID vertexId)DefaultSchedulingPipelinedRegionDefaultExecutionTopology. getPipelinedRegionOfVertex(ExecutionVertexID vertexId)org.apache.flink.runtime.scheduler.adapter.DefaultExecutionVertexDefaultExecutionTopology. getVertex(ExecutionVertexID executionVertexId)org.apache.flink.runtime.scheduler.adapter.DefaultExecutionVertexDefaultSchedulingPipelinedRegion. getVertex(ExecutionVertexID vertexId) -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler.adaptive.allocator
Methods in org.apache.flink.runtime.scheduler.adaptive.allocator with parameters of type ExecutionVertexID Modifier and Type Method Description Optional<Long>StateSizeEstimates. estimate(ExecutionVertexID jobVertexId)LogicalSlotReservedSlots. getSlotFor(ExecutionVertexID executionVertexId)Method parameters in org.apache.flink.runtime.scheduler.adaptive.allocator with type arguments of type ExecutionVertexID Modifier and Type Method Description static ReservedSlotsReservedSlots. create(Map<ExecutionVertexID,LogicalSlot> assignedSlots)Constructor parameters in org.apache.flink.runtime.scheduler.adaptive.allocator with type arguments of type ExecutionVertexID Constructor Description StateSizeEstimates(Map<ExecutionVertexID,Long> stateSizes) -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return types with arguments of type ExecutionVertexID Modifier and Type Method Description Set<ExecutionVertexID>BatchJobRecoveryContext. getTasksNeedingRestart(ExecutionVertexID vertexId, boolean considerResultConsumable)Retrieves a set of vertices that need to be restarted.Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionVertexID Modifier and Type Method Description Set<ExecutionVertexID>BatchJobRecoveryContext. getTasksNeedingRestart(ExecutionVertexID vertexId, boolean considerResultConsumable)Retrieves a set of vertices that need to be restarted.voidBatchJobRecoveryHandler. onExecutionFinished(ExecutionVertexID executionVertexId)Records the execution vertex finished event for use during future batch job recovery.voidDefaultBatchJobRecoveryHandler. onExecutionFinished(ExecutionVertexID executionVertexId)voidDummyBatchJobRecoveryHandler. onExecutionFinished(ExecutionVertexID executionVertexId)protected voidAdaptiveBatchScheduler. resetForNewExecution(ExecutionVertexID executionVertexId)voidDefaultSpeculativeExecutionHandler. resetForNewExecution(ExecutionVertexID executionVertexId)voidDummySpeculativeExecutionHandler. resetForNewExecution(ExecutionVertexID executionVertexId)voidSpeculativeExecutionHandler. resetForNewExecution(ExecutionVertexID executionVertexId)Resets the state of the component for a new execution of a specific execution vertex.Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ExecutionVertexID Modifier and Type Method Description voidAdaptiveBatchScheduler. allocateSlotsAndDeploy(List<ExecutionVertexID> verticesToDeploy)voidDefaultSpeculativeExecutionHandler. notifySlowTasks(Map<ExecutionVertexID,Collection<ExecutionAttemptID>> slowTasks)voidDefaultSpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)voidDummySpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)voidSpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)Notifies that a task has finished its execution.voidBatchJobRecoveryHandler. onExecutionVertexReset(Collection<ExecutionVertexID> vertices)Handles the reset event for a collection of execution vertices and records the event for use during future batch job recovery.voidDefaultBatchJobRecoveryHandler. onExecutionVertexReset(Collection<ExecutionVertexID> vertices)voidDummyBatchJobRecoveryHandler. onExecutionVertexReset(Collection<ExecutionVertexID> vertices)protected voidAdaptiveBatchScheduler. resetForNewExecutions(Collection<ExecutionVertexID> vertices)voidBatchJobRecoveryContext. resetVerticesInRecovering(Set<ExecutionVertexID> verticesToReset)Resets vertices specified by their IDs during recovery process.Constructor parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ExecutionVertexID Constructor Description DefaultSpeculativeExecutionHandler(org.apache.flink.configuration.Configuration jobMasterConfiguration, BlocklistOperations blocklistOperations, Function<ExecutionVertexID,ExecutionVertex> executionVertexRetriever, Supplier<Map<ExecutionAttemptID,Execution>> registerExecutionsSupplier, BiConsumer<List<Execution>,Collection<ExecutionVertexID>> allocateSlotsAndDeployFunction, org.slf4j.Logger log)DefaultSpeculativeExecutionHandler(org.apache.flink.configuration.Configuration jobMasterConfiguration, BlocklistOperations blocklistOperations, Function<ExecutionVertexID,ExecutionVertex> executionVertexRetriever, Supplier<Map<ExecutionAttemptID,Execution>> registerExecutionsSupplier, BiConsumer<List<Execution>,Collection<ExecutionVertexID>> allocateSlotsAndDeployFunction, org.slf4j.Logger log) -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler.exceptionhistory
Method parameters in org.apache.flink.runtime.scheduler.exceptionhistory with type arguments of type ExecutionVertexID Modifier and Type Method Description static FailureHandlingResultSnapshotFailureHandlingResultSnapshot. create(FailureHandlingResult failureHandlingResult, Function<ExecutionVertexID,Collection<Execution>> currentExecutionsLookup)Creates aFailureHandlingResultSnapshotbased on the passedFailureHandlingResultandExecutionVertices. -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler.slowtaskdetector
Method parameters in org.apache.flink.runtime.scheduler.slowtaskdetector with type arguments of type ExecutionVertexID Modifier and Type Method Description voidSlowTaskDetectorListener. notifySlowTasks(Map<ExecutionVertexID,Collection<ExecutionAttemptID>> slowTasks)Notify detected slow tasks. -
Uses of ExecutionVertexID in org.apache.flink.runtime.scheduler.strategy
Methods in org.apache.flink.runtime.scheduler.strategy that return ExecutionVertexID Modifier and Type Method Description static ExecutionVertexIDExecutionVertexID. fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)ExecutionVertexIDConsumerVertexGroup. getFirst()Methods in org.apache.flink.runtime.scheduler.strategy that return types with arguments of type ExecutionVertexID Modifier and Type Method Description Iterator<ExecutionVertexID>ConsumerVertexGroup. iterator()Methods in org.apache.flink.runtime.scheduler.strategy with parameters of type ExecutionVertexID Modifier and Type Method Description static ConsumerVertexGroupConsumerVertexGroup. fromSingleVertex(ExecutionVertexID vertex, ResultPartitionType resultPartitionType)SchedulingExecutionVertexSchedulingTopology. getVertex(ExecutionVertexID executionVertexId)Looks up theSchedulingExecutionVertexfor the givenExecutionVertexID.voidPipelinedRegionSchedulingStrategy. onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)voidSchedulingStrategy. onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)Called whenever anExecutionchanges its state.voidVertexwiseSchedulingStrategy. onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)Method parameters in org.apache.flink.runtime.scheduler.strategy with type arguments of type ExecutionVertexID Modifier and Type Method Description InputConsumableDeciderAllFinishedInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)InputConsumableDeciderDefaultInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)InputConsumableDeciderInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)InputConsumableDeciderPartialFinishedInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)static ConsumerVertexGroupConsumerVertexGroup. fromMultipleVertices(List<ExecutionVertexID> vertices, ResultPartitionType resultPartitionType)booleanAllFinishedInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToDeploy, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)booleanDefaultInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToSchedule, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)booleanInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToSchedule, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)Determining whether the input of an execution vertex is consumable.booleanPartialFinishedInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToDeploy, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)voidVertexwiseSchedulingStrategy. notifySchedulingTopologyUpdated(SchedulingTopology schedulingTopology, List<ExecutionVertexID> newExecutionVertices)voidPipelinedRegionSchedulingStrategy. restartTasks(Set<ExecutionVertexID> verticesToRestart)voidSchedulingStrategy. restartTasks(Set<ExecutionVertexID> verticesToRestart)Called whenever vertices need to be restarted (due to task failure).voidVertexwiseSchedulingStrategy. restartTasks(Set<ExecutionVertexID> verticesToRestart)
-