Package | Description |
---|---|
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.metrics.groups | |
org.apache.flink.runtime.taskexecutor.slot | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
void |
NetworkEnvironment.registerTask(Task task) |
void |
NetworkEnvironment.unregisterTask(Task task) |
Modifier and Type | Method and Description |
---|---|
void |
TaskIOMetricGroup.initializeBufferMetrics(Task task)
Initialize Buffer Metrics for a task.
|
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 |
---|---|
Iterator<Task> |
TaskSlot.getTasks()
Get all tasks running in this task slot.
|
Iterator<Task> |
TaskSlotTable.getTasks(JobID jobId)
Return an iterator over all tasks for a given job.
|
Modifier and Type | Method and Description |
---|---|
boolean |
TaskSlot.add(Task task)
Add the given task to the task slot.
|
boolean |
TaskSlotTable.addTask(Task task)
Add the given task to the slot identified by the task's allocation id.
|
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,
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) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.