Uses of Class
org.apache.flink.runtime.executiongraph.ExecutionAttemptID
-
-
Uses of ExecutionAttemptID in org.apache.flink.runtime.accumulators
Fields in org.apache.flink.runtime.accumulators declared as ExecutionAttemptID Modifier and Type Field Description protected ExecutionAttemptIDAccumulatorRegistry. taskIDMethods in org.apache.flink.runtime.accumulators that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDAccumulatorSnapshot. getExecutionAttemptID()Constructors in org.apache.flink.runtime.accumulators with parameters of type ExecutionAttemptID Constructor Description AccumulatorRegistry(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID taskID)AccumulatorSnapshot(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint with parameters of type ExecutionAttemptID Modifier and Type Method Description voidCheckpointCoordinatorGateway. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, org.apache.flink.util.SerializedValue<TaskStateSnapshot> subtaskState)PendingCheckpoint.TaskAcknowledgeResultPendingCheckpoint. acknowledgeTask(ExecutionAttemptID executionAttemptId, TaskStateSnapshot operatorSubtaskStates, CheckpointMetrics metrics)Acknowledges the task with the given execution attempt id and the given subtask state.voidCheckpointFailureManager.FailJobCallback. failJobDueToTaskFailure(Throwable cause, ExecutionAttemptID failingTask)Fails the whole job graph due to task failure.voidCheckpointFailureManager. handleCheckpointException(PendingCheckpoint pendingCheckpoint, CheckpointProperties checkpointProperties, CheckpointException exception, ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID job, PendingCheckpointStats pendingCheckpointStats, CheckpointStatsTracker statsTracker)Failures on JM: all checkpoints - go against failure counter.booleanPendingCheckpoint. isAcknowledgedBy(ExecutionAttemptID executionAttemptId)voidCheckpointCoordinator. reportCheckpointMetrics(long id, ExecutionAttemptID attemptId, CheckpointMetrics metrics)voidCheckpointCoordinatorGateway. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)voidCheckpointStatsTracker. reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)voidDefaultCheckpointStatsTracker. reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)voidNoOpCheckpointStatsTracker. reportIncompleteStats(long checkpointId, ExecutionAttemptID attemptId, CheckpointMetrics metrics)voidCheckpointCoordinator. reportInitializationMetrics(ExecutionAttemptID executionAttemptID, SubTaskInitializationMetrics initializationMetrics)voidCheckpointCoordinatorGateway. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)voidCheckpointStatsTracker. reportInitializationMetrics(ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)voidDefaultCheckpointStatsTracker. reportInitializationMetrics(ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)voidNoOpCheckpointStatsTracker. reportInitializationMetrics(ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type ExecutionAttemptID Modifier and Type Method Description voidCheckpointStatsTracker. reportInitializationStarted(Set<ExecutionAttemptID> toInitialize, long initializationStartTs)voidDefaultCheckpointStatsTracker. reportInitializationStarted(Set<ExecutionAttemptID> toInitialize, long initializationStartTs)voidNoOpCheckpointStatsTracker. reportInitializationStarted(Set<ExecutionAttemptID> toInitialize, long initializationStartTs) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDTaskDeploymentDescriptor. getExecutionAttemptId()Constructors in org.apache.flink.runtime.deployment with parameters of type ExecutionAttemptID Constructor Description TaskDeploymentDescriptor(org.apache.flink.api.common.JobID jobId, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation, ExecutionAttemptID executionAttemptId, AllocationID allocationId, JobManagerTaskRestore taskRestore, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDEnvironment. getExecutionId()Gets the ID of the task execution attempt. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ExecutionAttemptID Modifier and Type Method Description static ExecutionAttemptIDExecutionAttemptID. fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)ExecutionAttemptIDAccessExecution. getAttemptId()Returns theExecutionAttemptIDfor this Execution.ExecutionAttemptIDArchivedExecution. getAttemptId()ExecutionAttemptIDExecution. getAttemptId()ExecutionAttemptIDTaskExecutionStateTransition. getID()static ExecutionAttemptIDExecutionAttemptID. randomId()Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ExecutionAttemptID Modifier and Type Method Description Map<ExecutionAttemptID,Execution>DefaultExecutionGraph. getRegisteredExecutions()Map<ExecutionAttemptID,Execution>ExecutionGraph. getRegisteredExecutions()Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionAttemptID Modifier and Type Method Description voidSpeculativeExecutionVertex. archiveFailedExecution(ExecutionAttemptID executionAttemptId)Remove execution from currentExecutions if it is failed.Optional<AccessExecution>DefaultExecutionGraph. findExecution(ExecutionAttemptID attemptId)Optional<AccessExecution>ExecutionGraph. findExecution(ExecutionAttemptID attemptId)Optional<String>DefaultExecutionGraph. findVertexWithAttempt(ExecutionAttemptID attemptId)Optional<String>ExecutionGraph. findVertexWithAttempt(ExecutionAttemptID attemptId)voidDefaultExecutionGraph. notifySchedulerNgAboutInternalTaskFailure(ExecutionAttemptID attemptId, Throwable t, boolean cancelTask, boolean releasePartitions)voidInternalExecutionGraphAccessor. notifySchedulerNgAboutInternalTaskFailure(ExecutionAttemptID attemptId, Throwable t, boolean cancelTask, boolean releasePartitions)voidExecutionDeploymentListener. onCompletedDeployment(ExecutionAttemptID execution)voidNoOpExecutionDeploymentListener. onCompletedDeployment(ExecutionAttemptID execution)voidExecutionDeploymentListener. onStartedDeployment(ExecutionAttemptID execution, ResourceID host)voidNoOpExecutionDeploymentListener. onStartedDeployment(ExecutionAttemptID execution, ResourceID host)voidExecutionStateUpdateListener. onStateUpdate(ExecutionAttemptID execution, ExecutionState previousState, ExecutionState newState)voidExecution. 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.Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionAttemptID Constructor Description ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.filecache
Methods in org.apache.flink.runtime.filecache with parameters of type ExecutionAttemptID Modifier and Type Method Description Future<org.apache.flink.core.fs.Path>FileCache. createTmpFile(String name, org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry entry, org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionId)If the file doesn't exists locally, retrieve the file from the blob-service.voidFileCache. releaseJob(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionId) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.io.network
Methods in org.apache.flink.runtime.io.network with parameters of type ExecutionAttemptID Modifier and Type Method Description ShuffleIOOwnerContextNettyShuffleEnvironment. createShuffleIOOwnerContext(String ownerName, ExecutionAttemptID executionAttemptID, org.apache.flink.metrics.MetricGroup parentGroup)booleanNettyShuffleEnvironment. updatePartitionInfo(ExecutionAttemptID consumerID, PartitionInfo partitionInfo) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDResultPartitionID. getProducerId()Constructors in org.apache.flink.runtime.io.network.partition with parameters of type ExecutionAttemptID Constructor Description ResultPartitionID(IntermediateResultPartitionID partitionId, ExecutionAttemptID producerId) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.io.network.partition.consumer
Methods in org.apache.flink.runtime.io.network.partition.consumer that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDInputGateID. getConsumerID()Constructors in org.apache.flink.runtime.io.network.partition.consumer with parameters of type ExecutionAttemptID Constructor Description InputGateID(IntermediateDataSetID consumedResultID, ExecutionAttemptID consumerID) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.jobmanager.slots
Methods in org.apache.flink.runtime.jobmanager.slots with parameters of type ExecutionAttemptID Modifier and Type Method Description CompletableFuture<Acknowledge>TaskManagerGateway. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)Cancel the given task.voidTaskManagerGateway. notifyCheckpointAborted(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long latestCompletedCheckpointId, long timestamp)Notify the given task about a aborted checkpoint.voidTaskManagerGateway. notifyCheckpointOnComplete(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long completedCheckpointId, long completedTimestamp, long lastSubsumedCheckpointId)Notify the given task about a completed checkpoint and the last subsumed checkpoint id if possible.CompletableFuture<Acknowledge>TaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskManagerGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)Trigger for the given task a checkpoint.CompletableFuture<Acknowledge>TaskManagerGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)Update the task where the given partitions can be found. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type ExecutionAttemptID Modifier and Type Method Description Map<ExecutionAttemptID,ExecutionDeploymentState>DefaultExecutionDeploymentTracker. getExecutionsOn(ResourceID host)Map<ExecutionAttemptID,ExecutionDeploymentState>ExecutionDeploymentTracker. getExecutionsOn(ResourceID host)Returns all tracked executions for the given host.Methods in org.apache.flink.runtime.jobmaster with parameters of type ExecutionAttemptID Modifier and Type Method Description voidJobMaster. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, org.apache.flink.util.SerializedValue<TaskStateSnapshot> checkpointState)CompletableFuture<Acknowledge>RpcTaskManagerGateway. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)voidDefaultExecutionDeploymentTracker. completeDeploymentOf(ExecutionAttemptID executionAttemptId)voidExecutionDeploymentTracker. completeDeploymentOf(ExecutionAttemptID executionAttemptId)Marks the deployment of the given execution as complete.voidRpcTaskManagerGateway. notifyCheckpointAborted(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long latestCompletedCheckpointId, long timestamp)voidRpcTaskManagerGateway. notifyCheckpointOnComplete(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long completedCheckpointId, long completedTimestamp, long lastSubsumedCheckpointId)voidJobMaster. notifyEndOfData(ExecutionAttemptID executionAttempt)voidJobMasterGateway. notifyEndOfData(ExecutionAttemptID executionAttempt)Notifies that the task has reached the end of data.voidExecutionDeploymentTrackerDeploymentListenerAdapter. onCompletedDeployment(ExecutionAttemptID execution)voidExecutionDeploymentTrackerDeploymentListenerAdapter. onStartedDeployment(ExecutionAttemptID execution, ResourceID host)voidJobMaster. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)voidJobMaster. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)CompletableFuture<SerializedInputSplit>JobMaster. requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt)CompletableFuture<SerializedInputSplit>JobMasterGateway. requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt)Requests the next input split for theExecutionJobVertex.CompletableFuture<Acknowledge>JobMaster. sendOperatorEventToCoordinator(ExecutionAttemptID task, OperatorID operatorID, org.apache.flink.util.SerializedValue<OperatorEvent> serializedEvent)CompletableFuture<Acknowledge>JobMasterOperatorEventGateway. sendOperatorEventToCoordinator(ExecutionAttemptID task, OperatorID operatorID, org.apache.flink.util.SerializedValue<OperatorEvent> event)CompletableFuture<Acknowledge>RpcTaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)voidDefaultExecutionDeploymentTracker. startTrackingPendingDeploymentOf(ExecutionAttemptID executionAttemptId, ResourceID host)voidExecutionDeploymentTracker. startTrackingPendingDeploymentOf(ExecutionAttemptID executionAttemptId, ResourceID host)Starts tracking the given execution that is being deployed on the given host.voidDefaultExecutionDeploymentTracker. stopTrackingDeploymentOf(ExecutionAttemptID executionAttemptId)voidExecutionDeploymentTracker. stopTrackingDeploymentOf(ExecutionAttemptID executionAttemptId)Stops tracking the given execution.CompletableFuture<Acknowledge>RpcTaskManagerGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)CompletableFuture<Acknowledge>RpcTaskManagerGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)Method parameters in org.apache.flink.runtime.jobmaster with type arguments of type ExecutionAttemptID Modifier and Type Method Description voidExecutionDeploymentReconciliationHandler. onMissingDeploymentsOf(Collection<ExecutionAttemptID> executionAttemptIds, ResourceID hostingTaskExecutor)Called if some executions are expected to be hosted on a task executor, but aren't.voidExecutionDeploymentReconciliationHandler. onUnknownDeploymentsOf(Collection<ExecutionAttemptID> executionAttemptIds, ResourceID hostingTaskExecutor)Called if some executions are hosted on a task executor, but we don't expect them.voidDefaultExecutionDeploymentReconciler. reconcileExecutionDeployments(ResourceID taskExecutorHost, ExecutionDeploymentReport executionDeploymentReport, Map<ExecutionAttemptID,ExecutionDeploymentState> expectedDeployedExecutions)voidExecutionDeploymentReconciler. reconcileExecutionDeployments(ResourceID taskExecutorHost, ExecutionDeploymentReport executionDeploymentReport, Map<ExecutionAttemptID,ExecutionDeploymentState> expectedDeployedExecutionIds)Reconciles the deployment states between all reported/expected executions for the given task executor. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.jobmaster.event
Methods in org.apache.flink.runtime.jobmaster.event that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDExecutionVertexFinishedEvent. getExecutionAttemptId()Constructors in org.apache.flink.runtime.jobmaster.event with parameters of type ExecutionAttemptID 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 ExecutionAttemptID in org.apache.flink.runtime.messages
Methods in org.apache.flink.runtime.messages that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDTaskBackPressureResponse. getExecutionAttemptID()Methods in org.apache.flink.runtime.messages that return types with arguments of type ExecutionAttemptID Modifier and Type Method Description Map<ExecutionAttemptID,Collection<ThreadInfoSample>>TaskThreadInfoResponse. getSamples()Returns a collection of ThreadInfoSample.Constructors in org.apache.flink.runtime.messages with parameters of type ExecutionAttemptID Constructor Description TaskBackPressureResponse(int requestId, ExecutionAttemptID executionAttemptID, double backPressureRatio)Constructor parameters in org.apache.flink.runtime.messages with type arguments of type ExecutionAttemptID Constructor Description TaskThreadInfoResponse(Map<ExecutionAttemptID,Collection<ThreadInfoSample>> samples)Creates a response to the request to collect thread details samples. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.messages.checkpoint
Methods in org.apache.flink.runtime.messages.checkpoint that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDAbstractCheckpointMessage. getTaskExecutionId()Constructors in org.apache.flink.runtime.messages.checkpoint with parameters of type ExecutionAttemptID Constructor Description AbstractCheckpointMessage(org.apache.flink.api.common.JobID job, ExecutionAttemptID taskExecutionId, long checkpointId)AcknowledgeCheckpoint(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID taskExecutionId, long checkpointId)AcknowledgeCheckpoint(org.apache.flink.api.common.JobID job, ExecutionAttemptID taskExecutionId, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)DeclineCheckpoint(org.apache.flink.api.common.JobID job, ExecutionAttemptID taskExecutionId, long checkpointId, CheckpointException checkpointException) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.metrics.groups
Methods in org.apache.flink.runtime.metrics.groups that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDTaskMetricGroup. executionId()Methods in org.apache.flink.runtime.metrics.groups with parameters of type ExecutionAttemptID Modifier and Type Method Description TaskMetricGroupTaskManagerJobMetricGroup. addTask(ExecutionAttemptID executionAttemptID, String taskName)TaskMetricGroupUnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup. addTask(ExecutionAttemptID executionAttemptID, String taskName)voidTaskManagerJobMetricGroup. removeTaskMetricGroup(ExecutionAttemptID executionId) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.metrics.scope
Methods in org.apache.flink.runtime.metrics.scope with parameters of type ExecutionAttemptID Modifier and Type Method Description String[]TaskScopeFormat. formatScope(TaskManagerJobMetricGroup parent, org.apache.flink.util.AbstractID vertexId, ExecutionAttemptID attemptId, String taskName, int subtask, int attemptNumber) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDOperatorCoordinator.SubtaskGateway. getExecution()Gets the execution attempt for the subtask execution attempt that this gateway communicates with. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return types with arguments of type ExecutionAttemptID Modifier and Type Method Description Map<ExecutionAttemptID,org.apache.flink.runtime.scheduler.ExecutionSlotAssignment>ExecutionSlotAllocator. allocateSlotsFor(List<ExecutionAttemptID> executionAttemptIds)Allocate slots for the given executions.Map<ExecutionAttemptID,org.apache.flink.runtime.scheduler.ExecutionSlotAssignment>SimpleExecutionSlotAllocator. allocateSlotsFor(List<ExecutionAttemptID> executionAttemptIds)Methods in org.apache.flink.runtime.scheduler with parameters of type ExecutionAttemptID Modifier and Type Method Description voidExecutionGraphHandler. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)voidSchedulerBase. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)voidSchedulerNG. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)voidExecutionSlotAllocator. cancel(ExecutionAttemptID executionAttemptId)Cancel the ongoing slot request of the givenExecution.voidSimpleExecutionSlotAllocator. cancel(ExecutionAttemptID executionAttemptId)voidDefaultOperatorCoordinatorHandler. deliverOperatorEventToCoordinator(ExecutionAttemptID taskExecutionId, OperatorID operatorId, OperatorEvent evt)voidOperatorCoordinatorHandler. deliverOperatorEventToCoordinator(ExecutionAttemptID taskExecutionId, OperatorID operatorId, OperatorEvent event)Delivers an OperatorEvent to aOperatorCoordinator.voidSchedulerBase. deliverOperatorEventToCoordinator(ExecutionAttemptID taskExecutionId, OperatorID operatorId, OperatorEvent evt)voidSchedulerNG. deliverOperatorEventToCoordinator(ExecutionAttemptID taskExecution, OperatorID operator, OperatorEvent evt)Delivers the given OperatorEvent to theOperatorCoordinatorwith the givenOperatorID.voidSchedulerBase. notifyEndOfData(ExecutionAttemptID executionAttemptID)voidSchedulerNG. notifyEndOfData(ExecutionAttemptID executionAttemptID)Notifies that the task has reached the end of data.voidInternalFailuresListener. notifyTaskFailure(ExecutionAttemptID attemptId, Throwable t, boolean cancelTask, boolean releasePartitions)voidUpdateSchedulerNgOnInternalFailuresListener. notifyTaskFailure(ExecutionAttemptID attemptId, Throwable t, boolean cancelTask, boolean releasePartitions)voidVertexEndOfDataListener. recordTaskEndOfData(ExecutionAttemptID executionAttemptID)voidExecutionGraphHandler. reportCheckpointMetrics(ExecutionAttemptID attemptId, long id, CheckpointMetrics metrics)voidSchedulerBase. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID attemptId, long id, CheckpointMetrics metrics)voidSchedulerNG. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)voidExecutionGraphHandler. reportInitializationMetrics(ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)voidSchedulerBase. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)voidSchedulerNG. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)SerializedInputSplitExecutionGraphHandler. requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt)SerializedInputSplitSchedulerBase. requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt)SerializedInputSplitSchedulerNG. requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt)Method parameters in org.apache.flink.runtime.scheduler with type arguments of type ExecutionAttemptID Modifier and Type Method Description Map<ExecutionAttemptID,org.apache.flink.runtime.scheduler.ExecutionSlotAssignment>ExecutionSlotAllocator. allocateSlotsFor(List<ExecutionAttemptID> executionAttemptIds)Allocate slots for the given executions.Map<ExecutionAttemptID,org.apache.flink.runtime.scheduler.ExecutionSlotAssignment>SimpleExecutionSlotAllocator. allocateSlotsFor(List<ExecutionAttemptID> executionAttemptIds) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type ExecutionAttemptID Modifier and Type Method Description voidAdaptiveScheduler. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot checkpointState)voidAdaptiveScheduler. deliverOperatorEventToCoordinator(ExecutionAttemptID taskExecution, OperatorID operator, OperatorEvent evt)voidAdaptiveScheduler. notifyEndOfData(ExecutionAttemptID executionAttemptID)voidAdaptiveScheduler. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)voidAdaptiveScheduler. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)SerializedInputSplitAdaptiveScheduler. requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.scheduler.adaptivebatch
Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ExecutionAttemptID Modifier and Type Method Description voidDefaultSpeculativeExecutionHandler. notifySlowTasks(Map<ExecutionVertexID,Collection<ExecutionAttemptID>> slowTasks)Constructor parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type ExecutionAttemptID 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) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.scheduler.metrics
Methods in org.apache.flink.runtime.scheduler.metrics with parameters of type ExecutionAttemptID Modifier and Type Method Description voidDeploymentStateTimeMetrics. onStateUpdate(ExecutionAttemptID execution, ExecutionState previousState, ExecutionState newState) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.scheduler.slowtaskdetector
Method parameters in org.apache.flink.runtime.scheduler.slowtaskdetector with type arguments of type ExecutionAttemptID Modifier and Type Method Description voidSlowTaskDetectorListener. notifySlowTasks(Map<ExecutionVertexID,Collection<ExecutionAttemptID>> slowTasks)Notify detected slow tasks. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDShuffleIOOwnerContext. getExecutionAttemptID()ExecutionAttemptIDProducerDescriptor. getProducerExecutionId()Methods in org.apache.flink.runtime.shuffle with parameters of type ExecutionAttemptID Modifier and Type Method Description static ProducerDescriptorProducerDescriptor. create(TaskManagerLocation producerLocation, ExecutionAttemptID attemptId)ShuffleIOOwnerContextShuffleEnvironment. createShuffleIOOwnerContext(String ownerName, ExecutionAttemptID executionAttemptID, org.apache.flink.metrics.MetricGroup parentGroup)Create a context of the shuffle input/output owner used to create partitions or gates belonging to the owner.booleanShuffleEnvironment. updatePartitionInfo(ExecutionAttemptID consumerID, PartitionInfo partitionInfo)Update a gate with the newly available partition information, previously unknown.Constructors in org.apache.flink.runtime.shuffle with parameters of type ExecutionAttemptID Constructor Description ProducerDescriptor(ResourceID producerLocation, ExecutionAttemptID producerExecutionId, InetAddress address, int dataPort)ShuffleIOOwnerContext(String ownerName, ExecutionAttemptID executionAttemptID, org.apache.flink.metrics.MetricGroup parentGroup, org.apache.flink.metrics.MetricGroup outputGroup, org.apache.flink.metrics.MetricGroup inputGroup) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type ExecutionAttemptID Modifier and Type Method Description FileMergingSnapshotManagerTaskExecutorFileMergingManager. fileMergingSnapshotManagerForTask(org.apache.flink.api.common.JobID jobId, ResourceID tmResourceId, ExecutionAttemptID executionAttemptID, org.apache.flink.configuration.Configuration clusterConfiguration, org.apache.flink.configuration.Configuration jobConfiguration, TaskManagerJobMetricGroup metricGroup)Initialize file merging snapshot manager for each job according configurations whenTaskExecutor.submitTask(org.apache.flink.runtime.deployment.TaskDeploymentDescriptor, org.apache.flink.runtime.jobmaster.JobMasterId, java.time.Duration).voidTaskExecutorFileMergingManager. releaseMergingSnapshotManagerForTask(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptID)Constructors in org.apache.flink.runtime.state with parameters of type ExecutionAttemptID Constructor Description TaskStateManagerImpl(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptID, TaskLocalStateStore localStateStore, FileMergingSnapshotManagerClosableWrapper fileMergingSnapshotManager, StateChangelogStorage<?> stateChangelogStorage, TaskExecutorStateChangelogStoragesManager changelogStoragesManager, JobManagerTaskRestore jobManagerTaskRestore, CheckpointResponder checkpointResponder)TaskStateManagerImpl(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptID, TaskLocalStateStore localStateStore, FileMergingSnapshotManagerClosableWrapper fileMergingSnapshotManager, StateChangelogStorage<?> stateChangelogStorage, TaskExecutorStateChangelogStoragesManager changelogStoragesManager, JobManagerTaskRestore jobManagerTaskRestore, CheckpointResponder checkpointResponder, SequentialChannelStateReaderImpl sequentialChannelStateReader) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type ExecutionAttemptID Modifier and Type Method Description Set<ExecutionAttemptID>ExecutionDeploymentReport. getExecutions()Methods in org.apache.flink.runtime.taskexecutor with parameters of type ExecutionAttemptID Modifier and Type Method Description CompletableFuture<Acknowledge>TaskExecutor. abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)CompletableFuture<Acknowledge>TaskExecutorGateway. abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)Abort a checkpoint for the given task.CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)CompletableFuture<Acknowledge>TaskExecutor. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)CompletableFuture<Acknowledge>TaskExecutorGateway. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)Cancel the given task.CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. cancelTask(ExecutionAttemptID executionAttemptID, Duration timeout)CompletableFuture<Acknowledge>TaskExecutor. confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)CompletableFuture<Acknowledge>TaskExecutorGateway. confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)Confirm a checkpoint for the given task.CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)CompletableFuture<Acknowledge>TaskExecutor. sendOperatorEventToTask(ExecutionAttemptID executionAttemptID, OperatorID operatorId, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskExecutorGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)CompletableFuture<Acknowledge>TaskExecutorOperatorEventGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, org.apache.flink.util.SerializedValue<OperatorEvent> evt)Sends an operator event to an operator in a task executed by the Task Manager (Task Executor).CompletableFuture<Acknowledge>TaskExecutor. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long checkpointTimestamp, CheckpointOptions checkpointOptions)CompletableFuture<Acknowledge>TaskExecutorGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)Trigger the checkpoint for the given task.CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)CompletableFuture<Acknowledge>TaskExecutor. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)CompletableFuture<Acknowledge>TaskExecutorGateway. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)Update the task where the given partitions can be found.CompletableFuture<Acknowledge>TaskExecutorGatewayDecoratorBase. updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Duration timeout)Method parameters in org.apache.flink.runtime.taskexecutor with type arguments of type ExecutionAttemptID Modifier and Type Method Description CompletableFuture<TaskThreadInfoResponse>TaskExecutor. requestThreadInfoSamples(Collection<ExecutionAttemptID> taskExecutionAttemptIds, ThreadInfoSamplesRequest requestParams, Duration timeout)CompletableFuture<TaskThreadInfoResponse>TaskExecutorGatewayDecoratorBase. requestThreadInfoSamples(Collection<ExecutionAttemptID> taskExecutionAttemptIds, ThreadInfoSamplesRequest requestParams, Duration timeout)CompletableFuture<TaskThreadInfoResponse>TaskExecutorThreadInfoGateway. requestThreadInfoSamples(Collection<ExecutionAttemptID> taskExecutionAttemptIds, ThreadInfoSamplesRequest requestParams, Duration timeout)Request a thread info sample from the given tasks.Constructor parameters in org.apache.flink.runtime.taskexecutor with type arguments of type ExecutionAttemptID Constructor Description ExecutionDeploymentReport(Set<ExecutionAttemptID> executions) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type ExecutionAttemptID Modifier and Type Method Description voidRpcCheckpointResponder. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)voidRpcCheckpointResponder. declineCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointException checkpointException)voidRpcCheckpointResponder. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)voidRpcCheckpointResponder. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)Constructors in org.apache.flink.runtime.taskexecutor.rpc with parameters of type ExecutionAttemptID Constructor Description RpcInputSplitProvider(JobMasterGateway jobMasterGateway, JobVertexID jobVertexID, ExecutionAttemptID executionAttemptID, Duration timeout)RpcTaskOperatorEventGateway(JobMasterOperatorEventGateway rpcGateway, ExecutionAttemptID taskExecutionId, Consumer<Throwable> errorHandler) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.taskexecutor.slot
Methods in org.apache.flink.runtime.taskexecutor.slot that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDTaskSlotPayload. getExecutionId()Methods in org.apache.flink.runtime.taskexecutor.slot with parameters of type ExecutionAttemptID Modifier and Type Method Description TTaskSlotTable. getTask(ExecutionAttemptID executionAttemptID)Get the task for the given execution attempt id.TTaskSlotTableImpl. getTask(ExecutionAttemptID executionAttemptID)TTaskSlot. remove(ExecutionAttemptID executionAttemptId)Remove the task identified by the given execution attempt id.TTaskSlotTable. removeTask(ExecutionAttemptID executionAttemptID)Remove the task with the given execution attempt id from its task slot.TTaskSlotTableImpl. removeTask(ExecutionAttemptID executionAttemptID) -
Uses of ExecutionAttemptID in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return ExecutionAttemptID Modifier and Type Method Description ExecutionAttemptIDRuntimeEnvironment. getExecutionId()ExecutionAttemptIDTask. getExecutionId()ExecutionAttemptIDTaskExecutionState. getID()Returns the ID of the task this result belongs toMethods in org.apache.flink.runtime.taskmanager with parameters of type ExecutionAttemptID Modifier and Type Method Description voidCheckpointResponder. acknowledgeCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, TaskStateSnapshot subtaskState)Acknowledges the given checkpoint.voidCheckpointResponder. declineCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointException checkpointException)Declines the given checkpoint.voidTaskManagerActions. failTask(ExecutionAttemptID executionAttemptID, Throwable cause)Tells the task manager to fail the given task.voidTaskManagerActions. notifyEndOfData(ExecutionAttemptID executionAttemptID)Notifies that the task has reached the end of data.voidCheckpointResponder. reportCheckpointMetrics(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics)Report metrics for the given checkpoint.voidCheckpointResponder. reportInitializationMetrics(org.apache.flink.api.common.JobID jobId, ExecutionAttemptID executionAttemptId, SubTaskInitializationMetrics initializationMetrics)Constructors in org.apache.flink.runtime.taskmanager with parameters of type ExecutionAttemptID Constructor Description RuntimeEnvironment(org.apache.flink.api.common.JobID jobId, JobType jobType, JobVertexID jobVertexId, ExecutionAttemptID executionId, org.apache.flink.api.common.ExecutionConfig executionConfig, org.apache.flink.api.common.JobInfo jobInfo, org.apache.flink.api.common.TaskInfo taskInfo, org.apache.flink.configuration.Configuration jobConfiguration, org.apache.flink.configuration.Configuration taskConfiguration, org.apache.flink.util.UserCodeClassLoader userCodeClassLoader, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, BroadcastVariableManager bcVarManager, TaskStateManager taskStateManager, GlobalAggregateManager aggregateManager, AccumulatorRegistry accumulatorRegistry, TaskKvStateRegistry kvStateRegistry, InputSplitProvider splitProvider, Map<String,Future<org.apache.flink.core.fs.Path>> distCacheEntries, ResultPartitionWriter[] writers, IndexedInputGate[] inputGates, TaskEventDispatcher taskEventDispatcher, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorEventGateway, TaskManagerRuntimeInfo taskManagerInfo, TaskMetricGroup metrics, Task containingTask, ExternalResourceInfoProvider externalResourceInfoProvider, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory, TaskManagerActions taskManagerActions)Task(JobInformation jobInformation, TaskInformation taskInformation, ExecutionAttemptID executionAttemptID, AllocationID slotAllocationId, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, ShuffleEnvironment<?,?> shuffleEnvironment, KvStateService kvStateService, BroadcastVariableManager bcVarManager, TaskEventDispatcher taskEventDispatcher, ExternalResourceInfoProvider externalResourceInfoProvider, TaskStateManager taskStateManager, TaskManagerActions taskManagerActions, InputSplitProvider inputSplitProvider, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorCoordinatorEventGateway, GlobalAggregateManager aggregateManager, LibraryCacheManager.ClassLoaderHandle classLoaderHandle, FileCache fileCache, TaskManagerRuntimeInfo taskManagerConfig, TaskMetricGroup metricGroup, PartitionProducerStateChecker partitionProducerStateChecker, Executor executor, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory)IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState)Creates a new task execution state update, with no attached exception and no accumulators.TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState, Throwable error)Creates a new task execution state update, with an attached exception but no accumulators.TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState, Throwable error, AccumulatorSnapshot accumulators, IOMetrics ioMetrics)Creates a new task execution state update, with an attached exception. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.webmonitor.stats
Fields in org.apache.flink.runtime.webmonitor.stats with type parameters of type ExecutionAttemptID Modifier and Type Field Description protected Set<Set<ExecutionAttemptID>>TaskStatsRequestCoordinator.PendingStatsRequest. pendingTasksAll tasks what did not yet return a result.protected Map<org.apache.flink.shaded.guava33.com.google.common.collect.ImmutableSet<ExecutionAttemptID>,T>TaskStatsRequestCoordinator.PendingStatsRequest. statsResultByTaskGroupResults returned by individual tasks and stored by the tasks'ExecutionAttemptID.Method parameters in org.apache.flink.runtime.webmonitor.stats with type arguments of type ExecutionAttemptID Modifier and Type Method Description protected voidTaskStatsRequestCoordinator.PendingStatsRequest. collectTaskStats(org.apache.flink.shaded.guava33.com.google.common.collect.ImmutableSet<ExecutionAttemptID> executionId, T taskStatsResult)Collects result from one of the tasks.voidTaskStatsRequestCoordinator. handleSuccessfulResponse(int requestId, org.apache.flink.shaded.guava33.com.google.common.collect.ImmutableSet<ExecutionAttemptID> executionIds, T result)Handles the successfully returned tasks stats response by collecting the corresponding subtask samples.Constructor parameters in org.apache.flink.runtime.webmonitor.stats with type arguments of type ExecutionAttemptID Constructor Description PendingStatsRequest(int requestId, Collection<? extends Set<ExecutionAttemptID>> tasksToCollect)Creates newTaskStatsRequestCoordinator.PendingStatsRequest. -
Uses of ExecutionAttemptID in org.apache.flink.runtime.webmonitor.threadinfo
Methods in org.apache.flink.runtime.webmonitor.threadinfo that return types with arguments of type ExecutionAttemptID Modifier and Type Method Description Map<ExecutionAttemptID,Collection<ThreadInfoSample>>VertexThreadInfoStats. getSamplesBySubtask()Returns the a map of thread info samples by subtask (execution ID).Method parameters in org.apache.flink.runtime.webmonitor.threadinfo with type arguments of type ExecutionAttemptID Modifier and Type Method Description CompletableFuture<VertexThreadInfoStats>ThreadInfoRequestCoordinator. triggerThreadInfoRequest(Map<org.apache.flink.shaded.guava33.com.google.common.collect.ImmutableSet<ExecutionAttemptID>,CompletableFuture<TaskExecutorThreadInfoGateway>> executionsWithGateways, int numSamples, Duration delayBetweenSamples, int maxStackTraceDepth)Triggers collection of thread info stats of a job vertex by combining thread info responses from given subtasks.Constructor parameters in org.apache.flink.runtime.webmonitor.threadinfo with type arguments of type ExecutionAttemptID Constructor Description VertexThreadInfoStats(int requestId, long startTime, long endTime, Map<ExecutionAttemptID,Collection<ThreadInfoSample>> samplesBySubtask)Creates a thread details sample.
-