Modifier and Type | Method and Description |
---|---|
OperatorMetricGroup |
RuntimeContext.getMetricGroup()
Returns the metric group for this parallel subtask.
|
Modifier and Type | Method and Description |
---|---|
OperatorMetricGroup |
AbstractRuntimeUDFContext.getMetricGroup() |
Constructor and Description |
---|
AbstractRuntimeUDFContext(TaskInfo taskInfo,
UserCodeClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulators,
Map<String,Future<Path>> cpTasks,
OperatorMetricGroup metrics) |
RuntimeUDFContext(TaskInfo taskInfo,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics) |
RuntimeUDFContext(TaskInfo taskInfo,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics,
JobID jobID) |
Modifier and Type | Interface and Description |
---|---|
interface |
SinkWriterMetricGroup
Pre-defined metrics for sinks.
|
interface |
SourceReaderMetricGroup
Pre-defined metrics for
SourceReader . |
Modifier and Type | Method and Description |
---|---|
static OperatorMetricGroup |
UnregisteredMetricsGroup.createOperatorMetricGroup() |
Modifier and Type | Method and Description |
---|---|
DistributedRuntimeUDFContext |
AbstractIterativeTask.createRuntimeContext(OperatorMetricGroup metrics) |
Modifier and Type | Class and Description |
---|---|
class |
InternalOperatorMetricGroup
Special
MetricGroup representing an Operator. |
class |
InternalSinkWriterMetricGroup
Special
MetricGroup representing an Operator. |
class |
InternalSourceReaderMetricGroup
Special
MetricGroup representing an Operator. |
static class |
UnregisteredMetricGroups.UnregisteredOperatorMetricGroup
A safe drop-in replacement for
InternalOperatorMetricGroup s. |
Modifier and Type | Method and Description |
---|---|
static InternalSinkWriterMetricGroup |
InternalSinkWriterMetricGroup.wrap(OperatorMetricGroup operatorMetricGroup) |
static InternalSourceReaderMetricGroup |
InternalSourceReaderMetricGroup.wrap(OperatorMetricGroup operatorMetricGroup) |
Modifier and Type | Method and Description |
---|---|
OperatorMetricGroup |
BatchTask.getMetricGroup() |
OperatorMetricGroup |
TaskContext.getMetricGroup() |
Modifier and Type | Method and Description |
---|---|
DistributedRuntimeUDFContext |
BatchTask.createRuntimeContext(OperatorMetricGroup metrics) |
Constructor and Description |
---|
DistributedRuntimeUDFContext(TaskInfo taskInfo,
UserCodeClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Future<Path>> cpTasks,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup metrics,
ExternalResourceInfoProvider externalResourceInfoProvider,
JobID jobID) |
Modifier and Type | Method and Description |
---|---|
OperatorMetricGroup |
StateBootstrapWrapperOperator.getMetricGroup() |
Modifier and Type | Method and Description |
---|---|
OperatorMetricGroup |
SavepointRuntimeContext.getMetricGroup() |
Modifier and Type | Method and Description |
---|---|
OperatorMetricGroup |
AbstractStreamOperatorV2.getMetricGroup() |
OperatorMetricGroup |
AbstractStreamOperator.getMetricGroup() |
OperatorMetricGroup |
StreamOperator.getMetricGroup() |
Modifier and Type | Method and Description |
---|---|
protected Output<StreamRecord<OUT>> |
AbstractStreamOperator.registerCounterOnOutput(Output<StreamRecord<OUT>> output,
OperatorMetricGroup operatorMetricGroup) |
Constructor and Description |
---|
StreamingRuntimeContext(Environment env,
Map<String,Accumulator<?,?>> accumulators,
OperatorMetricGroup operatorMetricGroup,
OperatorID operatorID,
ProcessingTimeService processingTimeService,
KeyedStateStore keyedStateStore,
ExternalResourceInfoProvider externalResourceInfoProvider) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.