Package | Description |
---|---|
org.apache.flink.dropwizard.metrics | |
org.apache.flink.metrics | |
org.apache.flink.metrics.datadog | |
org.apache.flink.metrics.groups | |
org.apache.flink.metrics.reporter | |
org.apache.flink.runtime.io.network.metrics | |
org.apache.flink.runtime.io.network.partition.consumer | |
org.apache.flink.runtime.metrics.dump | |
org.apache.flink.runtime.metrics.groups | |
org.apache.flink.runtime.operators.chaining | |
org.apache.flink.runtime.operators.util.metrics | |
org.apache.flink.runtime.taskmanager | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations on data streams.
|
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
org.apache.flink.table.runtime.operators.window |
Constructor and Description |
---|
FlinkCounterWrapper(Counter counter) |
Modifier and Type | Class and Description |
---|---|
class |
SimpleCounter
A simple low-overhead
Counter that is not thread-safe. |
Modifier and Type | Method and Description |
---|---|
<C extends Counter> |
MetricGroup.counter(int name,
C counter)
Registers a
Counter with Flink. |
<C extends Counter> |
MetricGroup.counter(String name,
C counter)
Registers a
Counter with Flink. |
Modifier and Type | Method and Description |
---|---|
Counter |
MetricGroup.counter(int name)
Creates and registers a new
Counter with Flink. |
Counter |
MetricGroup.counter(String name)
Creates and registers a new
Counter with Flink. |
Constructor and Description |
---|
MeterView(Counter counter) |
MeterView(Counter counter,
int timeSpanInSeconds) |
Constructor and Description |
---|
DCounter(Counter c,
String metricName,
String host,
List<String> tags,
Clock clock) |
Modifier and Type | Method and Description |
---|---|
<C extends Counter> |
UnregisteredMetricsGroup.counter(int name,
C counter) |
<C extends Counter> |
UnregisteredMetricsGroup.counter(String name,
C counter) |
Modifier and Type | Method and Description |
---|---|
Counter |
UnregisteredMetricsGroup.counter(int name) |
Counter |
UnregisteredMetricsGroup.counter(String name) |
Modifier and Type | Field and Description |
---|---|
protected Map<Counter,String> |
AbstractReporter.counters |
Modifier and Type | Method and Description |
---|---|
Counter |
InputChannelMetrics.getNumBuffersInLocalCounter() |
Counter |
InputChannelMetrics.getNumBuffersInRemoteCounter() |
Counter |
InputChannelMetrics.getNumBytesInLocalCounter() |
Counter |
InputChannelMetrics.getNumBytesInRemoteCounter() |
Modifier and Type | Field and Description |
---|---|
protected Counter |
InputChannel.numBuffersIn |
protected Counter |
InputChannel.numBytesIn |
Constructor and Description |
---|
InputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
int initialBackoff,
int maxBackoff,
Counter numBytesIn,
Counter numBuffersIn) |
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ResultPartitionManager partitionManager,
TaskEventPublisher taskEventPublisher,
Counter numBytesIn,
Counter numBuffersIn) |
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ResultPartitionManager partitionManager,
TaskEventPublisher taskEventPublisher,
int initialBackoff,
int maxBackoff,
Counter numBytesIn,
Counter numBuffersIn) |
RemoteInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ConnectionID connectionId,
ConnectionManager connectionManager,
int initialBackOff,
int maxBackoff,
Counter numBytesIn,
Counter numBuffersIn) |
Modifier and Type | Method and Description |
---|---|
MetricDumpSerialization.MetricSerializationResult |
MetricDumpSerialization.MetricDumpSerializer.serialize(Map<Counter,Tuple2<QueryScopeInfo,String>> counters,
Map<Gauge<?>,Tuple2<QueryScopeInfo,String>> gauges,
Map<Histogram,Tuple2<QueryScopeInfo,String>> histograms,
Map<Meter,Tuple2<QueryScopeInfo,String>> meters)
Serializes the given metrics and returns the resulting byte array.
|
Modifier and Type | Method and Description |
---|---|
<C extends Counter> |
ProxyMetricGroup.counter(int name,
C counter) |
<C extends Counter> |
AbstractMetricGroup.counter(int name,
C counter) |
<C extends Counter> |
ProxyMetricGroup.counter(String name,
C counter) |
<C extends Counter> |
AbstractMetricGroup.counter(String name,
C counter) |
Modifier and Type | Method and Description |
---|---|
Counter |
ProxyMetricGroup.counter(int name) |
Counter |
AbstractMetricGroup.counter(int name) |
Counter |
ProxyMetricGroup.counter(String name) |
Counter |
AbstractMetricGroup.counter(String name) |
Counter |
TaskIOMetricGroup.getNumBuffersOutCounter() |
Counter |
TaskIOMetricGroup.getNumBytesInCounter() |
Counter |
TaskIOMetricGroup.getNumBytesOutCounter() |
Counter |
TaskIOMetricGroup.getNumRecordsInCounter() |
Counter |
OperatorIOMetricGroup.getNumRecordsInCounter() |
Counter |
TaskIOMetricGroup.getNumRecordsOutCounter() |
Counter |
OperatorIOMetricGroup.getNumRecordsOutCounter() |
Modifier and Type | Method and Description |
---|---|
void |
TaskIOMetricGroup.reuseRecordsInputCounter(Counter numRecordsInCounter) |
void |
TaskIOMetricGroup.reuseRecordsOutputCounter(Counter numRecordsOutCounter) |
Modifier and Type | Field and Description |
---|---|
protected Counter |
ChainedDriver.numRecordsIn |
protected Counter |
ChainedDriver.numRecordsOut |
Constructor and Description |
---|
CountingCollector(Collector<OUT> collector,
Counter numRecordsOut) |
CountingIterable(Iterable<IN> iterable,
Counter numRecordsIn) |
CountingIterator(Iterator<IN> iterator,
Counter numRecordsIn) |
CountingMutableObjectIterator(MutableObjectIterator<IN> iterator,
Counter numRecordsIn) |
Constructor and Description |
---|
InputGateWithMetrics(IndexedInputGate inputGate,
Counter numBytesIn) |
Constructor and Description |
---|
CountingOutput(Output<StreamRecord<OUT>> output,
Counter counter) |
Constructor and Description |
---|
StreamMultipleInputProcessor(CheckpointedInputGate[] checkpointedInputGates,
TypeSerializer<?>[] inputSerializers,
IOManager ioManager,
StreamStatusMaintainer streamStatusMaintainer,
MultipleInputStreamOperator<?> streamOperator,
MultipleInputSelectionHandler inputSelectionHandler,
WatermarkGauge[] inputWatermarkGauges,
OperatorChain<?,?> operatorChain,
Counter numRecordsIn) |
StreamTwoInputProcessor(CheckpointedInputGate[] checkpointedInputGates,
TypeSerializer<IN1> inputSerializer1,
TypeSerializer<IN2> inputSerializer2,
IOManager ioManager,
StreamStatusMaintainer streamStatusMaintainer,
TwoInputStreamOperator<IN1,IN2,?> streamOperator,
TwoInputSelectionHandler inputSelectionHandler,
WatermarkGauge input1WatermarkGauge,
WatermarkGauge input2WatermarkGauge,
OperatorChain<?,?> operatorChain,
Counter numRecordsIn) |
Modifier and Type | Field and Description |
---|---|
protected Counter |
WindowOperator.numLateRecordsDropped |
Modifier and Type | Method and Description |
---|---|
protected Counter |
StreamTask.setupNumRecordsInCounter(StreamOperator streamOperator) |
Modifier and Type | Method and Description |
---|---|
protected Counter |
WindowOperator.getNumLateRecordsDropped() |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.