程序包 | 说明 |
---|---|
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.metrics.groups | |
org.apache.flink.runtime.taskexecutor.slot | |
org.apache.flink.runtime.taskmanager |
限定符和类型 | 方法和说明 |
---|---|
void |
NetworkEnvironment.registerTask(Task task) |
void |
NetworkEnvironment.unregisterTask(Task task) |
限定符和类型 | 方法和说明 |
---|---|
void |
TaskIOMetricGroup.initializeBufferMetrics(Task task)
Initialize Buffer Metrics for a task.
|
限定符和类型 | 方法和说明 |
---|---|
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.
|
限定符和类型 | 方法和说明 |
---|---|
Iterator<Task> |
TaskSlot.getTasks()
Get all tasks running in this task slot.
|
Iterator<Task> |
TaskSlotTable.getTasks(org.apache.flink.api.common.JobID jobId)
Return an iterator over all tasks for a given job.
|
限定符和类型 | 方法和说明 |
---|---|
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.
|
构造器和说明 |
---|
RuntimeEnvironment(org.apache.flink.api.common.JobID jobId,
JobVertexID jobVertexId,
ExecutionAttemptID executionId,
org.apache.flink.api.common.ExecutionConfig executionConfig,
org.apache.flink.api.common.TaskInfo taskInfo,
org.apache.flink.configuration.Configuration jobConfiguration,
org.apache.flink.configuration.Configuration taskConfiguration,
ClassLoader userCodeClassLoader,
MemoryManager memManager,
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,
InputGate[] inputGates,
TaskEventDispatcher taskEventDispatcher,
CheckpointResponder checkpointResponder,
TaskManagerRuntimeInfo taskManagerInfo,
TaskMetricGroup metrics,
Task containingTask) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.