Modifier and Type | Field and Description |
---|---|
protected ExecutionAttemptID |
AccumulatorRegistry.taskID |
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
AccumulatorSnapshot.getExecutionAttemptID() |
Constructor and Description |
---|
AccumulatorRegistry(JobID jobID,
ExecutionAttemptID taskID) |
AccumulatorSnapshot(JobID jobID,
ExecutionAttemptID executionAttemptID,
Map<String,Accumulator<?,?>> userAccumulators) |
Modifier and Type | Method and Description |
---|---|
void |
CheckpointCoordinatorGateway.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState) |
PendingCheckpoint.TaskAcknowledgeResult |
PendingCheckpoint.acknowledgeTask(ExecutionAttemptID executionAttemptId,
TaskStateSnapshot operatorSubtaskStates,
CheckpointMetrics metrics)
Acknowledges the task with the given execution attempt id and the given subtask state.
|
void |
CheckpointCoordinator.failUnacknowledgedPendingCheckpointsFor(ExecutionAttemptID executionAttemptId,
Throwable cause)
Fails all pending checkpoints which have not been acknowledged by the given execution
attempt id.
|
boolean |
PendingCheckpoint.isAcknowledgedBy(ExecutionAttemptID executionAttemptId) |
Constructor and Description |
---|
PendingCheckpoint(JobID jobId,
long checkpointId,
long checkpointTimestamp,
Map<ExecutionAttemptID,ExecutionVertex> verticesToConfirm,
CheckpointProperties props,
CheckpointStorageLocation targetLocation,
Executor executor) |
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
TaskDeploymentDescriptor.getExecutionAttemptId() |
Constructor and Description |
---|
TaskDeploymentDescriptor(JobID jobId,
TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation,
TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation,
ExecutionAttemptID executionAttemptId,
AllocationID allocationId,
int subtaskIndex,
int attemptNumber,
int targetSlotNumber,
JobManagerTaskRestore taskRestore,
Collection<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
Collection<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors) |
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
Environment.getExecutionId()
Gets the ID of the task execution attempt.
|
Modifier and Type | Method and Description |
---|---|
void |
BlobLibraryCacheManager.registerTask(JobID jobId,
ExecutionAttemptID task,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths) |
void |
LibraryCacheManager.registerTask(JobID id,
ExecutionAttemptID execution,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths)
Registers a job task execution with its required jar files and classpaths.
|
void |
BlobLibraryCacheManager.unregisterTask(JobID jobId,
ExecutionAttemptID task) |
void |
LibraryCacheManager.unregisterTask(JobID id,
ExecutionAttemptID execution)
Unregisters a job task execution from the library cache manager.
|
Modifier and Type | Method and Description |
---|---|
static ExecutionAttemptID |
ExecutionAttemptID.fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf) |
ExecutionAttemptID |
ArchivedExecution.getAttemptId() |
ExecutionAttemptID |
Execution.getAttemptId() |
ExecutionAttemptID |
AccessExecution.getAttemptId()
Returns the
ExecutionAttemptID for this Execution. |
Modifier and Type | Method and Description |
---|---|
Map<ExecutionAttemptID,Execution> |
ExecutionGraph.getRegisteredExecutions() |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionStatusListener.executionStatusChanged(JobID jobID,
JobVertexID vertexID,
String taskName,
int totalNumberOfSubTasks,
int subtaskIndex,
ExecutionAttemptID executionID,
ExecutionState newExecutionState,
long timestamp,
String optionalMessage)
Called whenever the execution status of a task changes.
|
void |
StatusListenerMessenger.executionStatusChanged(JobID jobID,
JobVertexID vertexID,
String taskName,
int taskParallelism,
int subtaskIndex,
ExecutionAttemptID executionID,
ExecutionState newExecutionState,
long timestamp,
String optionalMessage) |
Constructor and Description |
---|
ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators,
IOMetrics ioMetrics,
ExecutionAttemptID attemptId,
int attemptNumber,
ExecutionState state,
String failureCause,
TaskManagerLocation assignedResourceLocation,
AllocationID assignedAllocationID,
int parallelSubtaskIndex,
long[] stateTimestamps) |
Modifier and Type | Method and Description |
---|---|
Future<Path> |
FileCache.createTmpFile(String name,
DistributedCache.DistributedCacheEntry entry,
JobID jobID,
ExecutionAttemptID executionId)
If the file doesn't exists locally, retrieve the file from the blob-service.
|
void |
FileCache.releaseJob(JobID jobId,
ExecutionAttemptID executionId) |
Modifier and Type | Field and Description |
---|---|
org.apache.flink.shaded.guava18.com.google.common.collect.Table<ExecutionAttemptID,IntermediateResultPartitionID,ResultPartition> |
ResultPartitionManager.registeredPartitions |
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
ResultPartitionID.getProducerId() |
Modifier and Type | Method and Description |
---|---|
void |
ResultPartitionManager.releasePartitionsProducedBy(ExecutionAttemptID executionId) |
void |
ResultPartitionManager.releasePartitionsProducedBy(ExecutionAttemptID executionId,
Throwable cause) |
Constructor and Description |
---|
ResultPartitionID(IntermediateResultPartitionID partitionId,
ExecutionAttemptID producerId) |
Modifier and Type | Method and Description |
---|---|
static SingleInputGate |
SingleInputGate.create(String owningTaskName,
JobID jobId,
ExecutionAttemptID executionId,
InputGateDeploymentDescriptor igdd,
NetworkEnvironment networkEnvironment,
TaskActions taskActions,
TaskIOMetricGroup metrics)
Creates an input gate and all of its input channels.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
void |
ActorTaskManagerGateway.failPartition(ExecutionAttemptID executionAttemptID) |
void |
TaskManagerGateway.failPartition(ExecutionAttemptID executionAttemptID)
Fail all intermediate result partitions of the given task.
|
void |
ActorTaskManagerGateway.notifyCheckpointComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp) |
void |
TaskManagerGateway.notifyCheckpointComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp)
Notify the given task about a completed checkpoint.
|
CompletableFuture<StackTraceSampleResponse> |
ActorTaskManagerGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<StackTraceSampleResponse> |
TaskManagerGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout)
Request a stack trace sample from the given task.
|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Stop the given task.
|
void |
ActorTaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
void |
TaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint.
|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
Modifier and Type | Method and Description |
---|---|
void |
JobMaster.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot checkpointState) |
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
void |
RpcTaskManagerGateway.failPartition(ExecutionAttemptID executionAttemptID) |
void |
RpcTaskManagerGateway.notifyCheckpointComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp) |
CompletableFuture<SerializedInputSplit> |
JobMaster.requestNextInputSplit(JobVertexID vertexID,
ExecutionAttemptID executionAttempt) |
CompletableFuture<SerializedInputSplit> |
JobMasterGateway.requestNextInputSplit(JobVertexID vertexID,
ExecutionAttemptID executionAttempt)
Requests the next input split for the
ExecutionJobVertex . |
CompletableFuture<StackTraceSampleResponse> |
RpcTaskManagerGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
void |
RpcTaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
StackTraceSampleResponse.getExecutionAttemptID() |
Constructor and Description |
---|
StackTraceSampleResponse(int sampleId,
ExecutionAttemptID executionAttemptID,
List<StackTraceElement[]> samples) |
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
AbstractCheckpointMessage.getTaskExecutionId() |
Constructor and Description |
---|
AbstractCheckpointMessage(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
AcknowledgeCheckpoint(JobID jobId,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
AcknowledgeCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState) |
DeclineCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId) |
DeclineCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
Throwable reason) |
NotifyCheckpointComplete(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
long timestamp) |
TriggerCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
TaskMetricGroup |
UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup.addTask(JobVertexID jobVertexId,
ExecutionAttemptID executionAttemptID,
String taskName,
int subtaskIndex,
int attemptNumber) |
TaskMetricGroup |
TaskManagerJobMetricGroup.addTask(JobVertexID jobVertexId,
ExecutionAttemptID executionAttemptID,
String taskName,
int subtaskIndex,
int attemptNumber) |
TaskMetricGroup |
UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup.addTaskForJob(JobID jobId,
String jobName,
JobVertexID jobVertexId,
ExecutionAttemptID executionAttemptId,
String taskName,
int subtaskIndex,
int attemptNumber) |
TaskMetricGroup |
TaskManagerMetricGroup.addTaskForJob(JobID jobId,
String jobName,
JobVertexID jobVertexId,
ExecutionAttemptID executionAttemptId,
String taskName,
int subtaskIndex,
int attemptNumber) |
Modifier and Type | Method and Description |
---|---|
Map<ExecutionAttemptID,List<StackTraceElement[]>> |
StackTraceSample.getStackTraces()
Returns the a map of stack traces by execution ID.
|
Modifier and Type | Method and Description |
---|---|
void |
StackTraceSampleCoordinator.collectStackTraces(int sampleId,
ExecutionAttemptID executionId,
List<StackTraceElement[]> stackTraces)
Collects stack traces of a task.
|
Constructor and Description |
---|
StackTraceSample(int sampleId,
long startTime,
long endTime,
Map<ExecutionAttemptID,List<StackTraceElement[]>> stackTracesByTask)
Creates a stack trace sample.
|
Constructor and Description |
---|
TaskStateManagerImpl(JobID jobId,
ExecutionAttemptID executionAttemptID,
TaskLocalStateStore localStateStore,
JobManagerTaskRestore jobManagerTaskRestore,
CheckpointResponder checkpointResponder) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
TaskExecutorGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.confirmCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long checkpointTimestamp)
Confirm a checkpoint for the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.confirmCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long checkpointTimestamp) |
void |
TaskExecutorGateway.failPartition(ExecutionAttemptID executionAttemptID)
Fail all intermediate result partitions of the given task.
|
void |
TaskExecutor.failPartition(ExecutionAttemptID executionAttemptID) |
CompletableFuture<StackTraceSampleResponse> |
TaskExecutorGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptId,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<StackTraceSampleResponse> |
TaskExecutor.requestStackTraceSample(ExecutionAttemptID executionAttemptId,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Stop the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointID,
long checkpointTimestamp,
CheckpointOptions checkpointOptions)
Trigger the checkpoint for the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long checkpointTimestamp,
CheckpointOptions checkpointOptions) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
CompletableFuture<Acknowledge> |
TaskExecutor.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
void |
RpcCheckpointResponder.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState) |
void |
RpcCheckpointResponder.declineCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
Throwable cause) |
Constructor and Description |
---|
RpcInputSplitProvider(JobMasterGateway jobMasterGateway,
JobVertexID jobVertexID,
ExecutionAttemptID executionAttemptID,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
Task |
TaskSlotTable.getTask(ExecutionAttemptID executionAttemptID)
Get the task for the given execution attempt id.
|
Task |
TaskSlot.remove(ExecutionAttemptID executionAttemptId)
Remove the task identified by the given execution attempt id.
|
Task |
TaskSlotTable.removeTask(ExecutionAttemptID executionAttemptID)
Remove the task with the given execution attempt id from its task slot.
|
Modifier and Type | Method and Description |
---|---|
ExecutionAttemptID |
RuntimeEnvironment.getExecutionId() |
ExecutionAttemptID |
Task.getExecutionId() |
ExecutionAttemptID |
TaskExecutionState.getID()
Returns the ID of the task this result belongs to
|
Modifier and Type | Method and Description |
---|---|
void |
CheckpointResponder.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot subtaskState)
Acknowledges the given checkpoint.
|
void |
ActorGatewayCheckpointResponder.acknowledgeCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
CheckpointMetrics checkpointMetrics,
TaskStateSnapshot checkpointStateHandles) |
void |
CheckpointResponder.declineCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
Throwable cause)
Declines the given checkpoint.
|
void |
ActorGatewayCheckpointResponder.declineCheckpoint(JobID jobID,
ExecutionAttemptID executionAttemptID,
long checkpointId,
Throwable reason) |
void |
TaskManagerActions.failTask(ExecutionAttemptID executionAttemptID,
Throwable cause)
Tells the task manager to fail the given task.
|
void |
ActorGatewayTaskManagerActions.failTask(ExecutionAttemptID executionAttemptID,
Throwable cause) |
Constructor and Description |
---|
RuntimeEnvironment(JobID jobId,
JobVertexID jobVertexId,
ExecutionAttemptID executionId,
ExecutionConfig executionConfig,
TaskInfo taskInfo,
Configuration jobConfiguration,
Configuration taskConfiguration,
ClassLoader userCodeClassLoader,
MemoryManager memManager,
IOManager ioManager,
BroadcastVariableManager bcVarManager,
TaskStateManager taskStateManager,
GlobalAggregateManager aggregateManager,
AccumulatorRegistry accumulatorRegistry,
TaskKvStateRegistry kvStateRegistry,
InputSplitProvider splitProvider,
Map<String,Future<Path>> distCacheEntries,
ResultPartitionWriter[] writers,
InputGate[] inputGates,
TaskEventDispatcher taskEventDispatcher,
CheckpointResponder checkpointResponder,
TaskManagerRuntimeInfo taskManagerInfo,
TaskMetricGroup metrics,
Task containingTask) |
Task(JobInformation jobInformation,
TaskInformation taskInformation,
ExecutionAttemptID executionAttemptID,
AllocationID slotAllocationId,
int subtaskIndex,
int attemptNumber,
Collection<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors,
Collection<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors,
int targetSlotNumber,
MemoryManager memManager,
IOManager ioManager,
NetworkEnvironment networkEnvironment,
BroadcastVariableManager bcVarManager,
TaskStateManager taskStateManager,
TaskManagerActions taskManagerActions,
InputSplitProvider inputSplitProvider,
CheckpointResponder checkpointResponder,
GlobalAggregateManager aggregateManager,
BlobCacheService blobService,
LibraryCacheManager libraryCache,
FileCache fileCache,
TaskManagerRuntimeInfo taskManagerConfig,
TaskMetricGroup metricGroup,
ResultPartitionConsumableNotifier resultPartitionConsumableNotifier,
PartitionProducerStateChecker partitionProducerStateChecker,
Executor executor)
IMPORTANT: This constructor may not start any work that would need to
be undone in the case of a failing task deployment.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState)
Creates a new task execution state update, with no attached exception and no accumulators.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState,
Throwable error)
Creates a new task execution state update, with an attached exception but no accumulators.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState,
Throwable error,
AccumulatorSnapshot accumulators,
IOMetrics ioMetrics)
Creates a new task execution state update, with an attached exception.
|
TaskInputSplitProvider(ActorGateway jobManager,
JobID jobID,
JobVertexID vertexID,
ExecutionAttemptID executionID,
scala.concurrent.duration.FiniteDuration timeout) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.