Uses of Interface
org.apache.flink.metrics.Counter
-
-
Uses of Counter in org.apache.flink.changelog.fs
Methods in org.apache.flink.changelog.fs that return Counter Modifier and Type Method Description Counter
ChangelogStorageMetricGroup. getUploadFailuresCounter()
Counter
ChangelogStorageMetricGroup. getUploadsCounter()
-
Uses of Counter in org.apache.flink.dropwizard.metrics
Constructors in org.apache.flink.dropwizard.metrics with parameters of type Counter Constructor Description FlinkCounterWrapper(Counter counter)
-
Uses of Counter in org.apache.flink.metrics
Classes in org.apache.flink.metrics that implement Counter Modifier and Type Class Description class
SimpleCounter
A simple low-overheadCounter
that is not thread-safe.class
ThreadSafeSimpleCounter
A simple low-overheadCounter
that is thread-safe.Methods in org.apache.flink.metrics with type parameters of type Counter Modifier and Type Method Description default <C extends Counter>
CMetricGroup. counter(int name, C counter)
Registers aCounter
with Flink.<C extends Counter>
CMetricGroup. counter(String name, C counter)
Registers aCounter
with Flink.Methods in org.apache.flink.metrics that return Counter Modifier and Type Method Description default Counter
MetricGroup. counter(int name)
Creates and registers a newCounter
with Flink.Counter
MetricGroup. counter(String name)
Creates and registers a newCounter
with Flink.Constructors in org.apache.flink.metrics with parameters of type Counter Constructor Description MeterView(Counter counter)
MeterView(Counter counter, int timeSpanInSeconds)
-
Uses of Counter in org.apache.flink.metrics.datadog
Constructors in org.apache.flink.metrics.datadog with parameters of type Counter Constructor Description DCounter(Counter c, String metricName, String host, List<String> tags, Clock clock)
-
Uses of Counter in org.apache.flink.metrics.groups
Methods in org.apache.flink.metrics.groups with type parameters of type Counter Modifier and Type Method Description <C extends Counter>
CUnregisteredMetricsGroup. counter(String name, C counter)
Methods in org.apache.flink.metrics.groups that return Counter Modifier and Type Method Description Counter
UnregisteredMetricsGroup. counter(String name)
Counter
OperatorIOMetricGroup. getNumBytesInCounter()
The total number of input bytes since the task started.Counter
OperatorIOMetricGroup. getNumBytesOutCounter()
The total number of output bytes since the task started.Counter
SinkWriterMetricGroup. getNumBytesSendCounter()
The total number of output send bytes since the task started.Counter
SinkCommitterMetricGroup. getNumCommittablesAlreadyCommittedCounter()
The total number of already committed committables.Counter
SinkCommitterMetricGroup. getNumCommittablesFailureCounter()
The total number of committable failures.Counter
SinkCommitterMetricGroup. getNumCommittablesRetryCounter()
The total number of committable retry.Counter
SinkCommitterMetricGroup. getNumCommittablesSuccessCounter()
The total number of successful committables.Counter
SinkCommitterMetricGroup. getNumCommittablesTotalCounter()
The total number of committables arrived.Counter
OperatorIOMetricGroup. getNumRecordsInCounter()
The total number of input records since the operator started.Counter
SourceReaderMetricGroup. getNumRecordsInErrorsCounter()
The total number of record that failed to consume, process, or emit.Counter
OperatorIOMetricGroup. getNumRecordsOutCounter()
The total number of output records since the operator started.Counter
SinkWriterMetricGroup. getNumRecordsOutErrorsCounter()
The total number of records failed to send.Counter
SinkWriterMetricGroup. getNumRecordsSendCounter()
The total number of records have been sent to the downstream system.Counter
SinkWriterMetricGroup. getNumRecordsSendErrorsCounter()
The total number of records failed to send.Methods in org.apache.flink.metrics.groups with parameters of type Counter Modifier and Type Method Description void
CacheMetricGroup. hitCounter(Counter hitCounter)
The number of cache hits.void
CacheMetricGroup. loadCounter(Counter loadCounter)
The number of times to load data into cache from external system.void
CacheMetricGroup. missCounter(Counter missCounter)
The number of cache misses.void
CacheMetricGroup. numLoadFailuresCounter(Counter numLoadFailuresCounter)
The number of load failures. -
Uses of Counter in org.apache.flink.metrics.influxdb
Fields in org.apache.flink.metrics.influxdb with type parameters of type Counter Modifier and Type Field Description protected Map<Counter,MetricInfo>
AbstractReporter. counters
-
Uses of Counter in org.apache.flink.metrics.reporter
Fields in org.apache.flink.metrics.reporter with type parameters of type Counter Modifier and Type Field Description protected Map<Counter,String>
AbstractReporter. counters
-
Uses of Counter in org.apache.flink.metrics.testutils
Methods in org.apache.flink.metrics.testutils that return types with arguments of type Counter Modifier and Type Method Description Optional<Counter>
MetricListener. getCounter(String... identifier)
Get registeredCounter
with identifier relative to the root metric group. -
Uses of Counter in org.apache.flink.runtime.io.network.metrics
Methods in org.apache.flink.runtime.io.network.metrics that return Counter Modifier and Type Method Description Counter
InputChannelMetrics. getNumBuffersInLocalCounter()
Counter
InputChannelMetrics. getNumBuffersInRemoteCounter()
Counter
InputChannelMetrics. getNumBytesInLocalCounter()
Counter
InputChannelMetrics. getNumBytesInRemoteCounter()
-
Uses of Counter in org.apache.flink.runtime.io.network.partition
Fields in org.apache.flink.runtime.io.network.partition declared as Counter Modifier and Type Field Description protected Counter
ResultPartition. numBuffersOut
protected Counter
ResultPartition. numBytesOut
-
Uses of Counter in org.apache.flink.runtime.io.network.partition.consumer
Fields in org.apache.flink.runtime.io.network.partition.consumer declared as Counter Modifier and Type Field Description protected Counter
InputChannel. numBuffersIn
protected Counter
InputChannel. numBytesIn
Constructors in org.apache.flink.runtime.io.network.partition.consumer with parameters of type Counter Constructor Description InputChannel(SingleInputGate inputGate, int channelIndex, ResultPartitionID partitionId, ResultSubpartitionIndexSet consumedSubpartitionIndexSet, int initialBackoff, int maxBackoff, Counter numBytesIn, Counter numBuffersIn)
LocalInputChannel(SingleInputGate inputGate, int channelIndex, ResultPartitionID partitionId, ResultSubpartitionIndexSet consumedSubpartitionIndexSet, ResultPartitionManager partitionManager, TaskEventPublisher taskEventPublisher, int initialBackoff, int maxBackoff, Counter numBytesIn, Counter numBuffersIn, ChannelStateWriter stateWriter)
RemoteInputChannel(SingleInputGate inputGate, int channelIndex, ResultPartitionID partitionId, ResultSubpartitionIndexSet consumedSubpartitionIndexSet, ConnectionID connectionId, ConnectionManager connectionManager, int initialBackOff, int maxBackoff, int partitionRequestListenerTimeout, int networkBuffersPerChannel, Counter numBytesIn, Counter numBuffersIn, ChannelStateWriter stateWriter)
-
Uses of Counter in org.apache.flink.runtime.metrics.dump
Method parameters in org.apache.flink.runtime.metrics.dump with type arguments of type Counter Modifier and Type Method 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. -
Uses of Counter in org.apache.flink.runtime.metrics.groups
Methods in org.apache.flink.runtime.metrics.groups with type parameters of type Counter Modifier and Type Method Description <C extends Counter>
CAbstractMetricGroup. counter(String name, C counter)
<C extends Counter>
CProxyMetricGroup. counter(String name, C counter)
Methods in org.apache.flink.runtime.metrics.groups with parameters of type Counter Modifier and Type Method Description void
InternalCacheMetricGroup. hitCounter(Counter hitCounter)
void
InternalCacheMetricGroup. loadCounter(Counter loadCounter)
void
InternalCacheMetricGroup. missCounter(Counter missCounter)
void
InternalCacheMetricGroup. numLoadFailuresCounter(Counter numLoadFailuresCounter)
void
TaskIOMetricGroup. reuseBytesInputCounter(Counter numBytesInCounter)
void
TaskIOMetricGroup. reuseBytesOutputCounter(Counter numBytesOutCounter)
void
TaskIOMetricGroup. reuseRecordsInputCounter(Counter numRecordsInCounter)
void
TaskIOMetricGroup. reuseRecordsOutputCounter(Counter numRecordsOutCounter)
-
Uses of Counter in org.apache.flink.runtime.operators.chaining
Fields in org.apache.flink.runtime.operators.chaining declared as Counter Modifier and Type Field Description protected Counter
ChainedDriver. numRecordsIn
protected Counter
ChainedDriver. numRecordsOut
-
Uses of Counter in org.apache.flink.runtime.operators.util.metrics
Constructors in org.apache.flink.runtime.operators.util.metrics with parameters of type Counter Constructor 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)
-
Uses of Counter in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type Counter Constructor Description InputGateWithMetrics(IndexedInputGate inputGate, Counter numBytesIn)
-
Uses of Counter in org.apache.flink.streaming.api.operators
Constructors in org.apache.flink.streaming.api.operators with parameters of type Counter Constructor Description CountingOutput(WatermarkGaugeExposingOutput<StreamRecord<OUT>> output, Counter numRecordsOut)
-
Uses of Counter in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type Counter Modifier and Type Method Description static StreamMultipleInputProcessor
StreamMultipleInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, StreamConfig.InputConfig[] configuredInputs, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup ioMetricGroup, Counter mainOperatorRecordsIn, MultipleInputStreamOperator<?> mainOperator, WatermarkGauge[] inputWatermarkGauges, StreamConfig streamConfig, Configuration taskManagerConfig, Configuration jobConfig, ExecutionConfig executionConfig, ClassLoader userClassloader, OperatorChain<?,?> operatorChain, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
static <IN1,IN2>
StreamMultipleInputProcessorStreamTwoInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup taskIOMetricGroup, TwoInputStreamOperator<IN1,IN2,?> streamOperator, WatermarkGauge input1WatermarkGauge, WatermarkGauge input2WatermarkGauge, OperatorChain<?,?> operatorChain, StreamConfig streamConfig, Configuration taskManagerConfig, Configuration jobConfig, ExecutionConfig executionConfig, ClassLoader userClassloader, Counter numRecordsIn, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
void
RecordWriterOutput. setNumRecordsOut(Counter numRecordsOut)
-
Uses of Counter in org.apache.flink.streaming.runtime.operators.windowing
Fields in org.apache.flink.streaming.runtime.operators.windowing declared as Counter Modifier and Type Field Description protected Counter
WindowOperator. numLateRecordsDropped
-
Uses of Counter in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks that return Counter Modifier and Type Method Description protected Counter
StreamTask. setupNumRecordsInCounter(StreamOperator streamOperator)
-
Uses of Counter in org.apache.flink.streaming.runtime.tasks.mailbox
Methods in org.apache.flink.streaming.runtime.tasks.mailbox that return Counter Modifier and Type Method Description Counter
MailboxMetricsController. getMailCounter()
GetsCounter
for number of mails processed.Constructors in org.apache.flink.streaming.runtime.tasks.mailbox with parameters of type Counter Constructor Description MailboxMetricsController(Histogram latencyHistogram, Counter mailCounter)
Creates instance ofMailboxMetricsController
with references to metrics provided as parameters. -
Uses of Counter in org.apache.flink.table.runtime.operators.over
Methods in org.apache.flink.table.runtime.operators.over that return Counter Modifier and Type Method Description protected Counter
AbstractRowTimeUnboundedPrecedingOver. getCounter()
protected Counter
RowTimeRangeBoundedPrecedingFunction. getCounter()
protected Counter
RowTimeRowsBoundedPrecedingFunction. getCounter()
-
Uses of Counter in org.apache.flink.table.runtime.operators.window.groupwindow.operator
Methods in org.apache.flink.table.runtime.operators.window.groupwindow.operator that return Counter Modifier and Type Method Description protected Counter
WindowOperator. getNumLateRecordsDropped()
-
Uses of Counter in org.apache.flink.table.runtime.operators.window.tvf.common
Methods in org.apache.flink.table.runtime.operators.window.tvf.common that return Counter Modifier and Type Method Description Counter
WindowAggOperator. getNumLateRecordsDropped()
-
Uses of Counter in org.apache.flink.table.runtime.operators.window.tvf.operator
Fields in org.apache.flink.table.runtime.operators.window.tvf.operator declared as Counter Modifier and Type Field Description protected Counter
WindowTableFunctionOperatorBase. numNullRowTimeRecordsDropped
Methods in org.apache.flink.table.runtime.operators.window.tvf.operator that return Counter Modifier and Type Method Description Counter
UnalignedWindowTableFunctionOperator. getNumLateRecordsDropped()
Counter
WindowTableFunctionOperatorBase. getNumNullRowTimeRecordsDropped()
-