Package | Description |
---|---|
org.apache.flink.runtime.execution | |
org.apache.flink.runtime.metrics.groups | |
org.apache.flink.runtime.metrics.scope | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
TaskMetricGroup |
Environment.getMetricGroup()
Returns the task specific metric group.
|
Modifier and Type | Class and Description |
---|---|
static class |
UnregisteredMetricGroups.UnregisteredTaskMetricGroup
A safe drop-in replacement for
TaskMetricGroup s. |
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) |
static TaskMetricGroup |
UnregisteredMetricGroups.createUnregisteredTaskMetricGroup() |
TaskMetricGroup |
OperatorMetricGroup.parent() |
Constructor and Description |
---|
OperatorMetricGroup(MetricRegistry registry,
TaskMetricGroup parent,
OperatorID operatorID,
String operatorName) |
TaskIOMetricGroup(TaskMetricGroup parent) |
Modifier and Type | Method and Description |
---|---|
String[] |
OperatorScopeFormat.formatScope(TaskMetricGroup parent,
OperatorID operatorID,
String operatorName) |
Modifier and Type | Method and Description |
---|---|
TaskMetricGroup |
RuntimeEnvironment.getMetricGroup() |
TaskMetricGroup |
Task.getMetricGroup() |
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) |
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,
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.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.