Interface | Description |
---|---|
InternalTimerService<N> |
Interface for working with time and timers.
|
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> |
A reader for a
InternalTimersSnapshot . |
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter |
A writer for a
InternalTimersSnapshot . |
KeyContext |
Inteface for setting and querying the current key of keyed operations.
|
OneInputStreamOperator<IN,OUT> |
Interface for stream operators with one input.
|
OnWatermarkCallback<KEY> |
A callback registered with the
InternalWatermarkCallbackService service. |
Output<T> |
A
StreamOperator is supplied with an object
of this interface that can be used to emit elements and other messages, such as barriers
and watermarks, from an operator. |
OutputTypeConfigurable<OUT> |
Stream operators can implement this interface if they need access to the output type information
at
StreamGraph generation. |
StreamOperator<OUT> |
Basic interface for stream operators.
|
Triggerable<K,N> |
Interface for things that can be called by
InternalTimerService . |
TwoInputStreamOperator<IN1,IN2,OUT> |
Interface for stream operators with two inputs.
|
Class | Description |
---|---|
AbstractStreamOperator<OUT> |
Base class for all stream operators.
|
AbstractStreamOperator.LatencyGauge |
The gauge uses a HashMap internally to avoid classloading issues when accessing
the values using JMX.
|
AbstractUdfStreamOperator<OUT,F extends Function> |
This is used as the base class for operators that have a user-defined
function.
|
HeapInternalTimerService<K,N> |
InternalTimerService that stores timers on the Java heap. |
InternalTimer<K,N> |
Internal class for keeping track of in-flight timers.
|
InternalTimer.TimerSerializer<K,N> |
A
TypeSerializer used to serialize/deserialize a InternalTimer . |
InternalTimerServiceSerializationProxy<K,N> |
Serialization proxy for the timer services for a given key-group.
|
InternalTimersSnapshot<K,N> |
A snapshot of internal timers, containing event and processing timers and
the serializers to use to write / read them.
|
InternalTimersSnapshotReaderWriters |
Readers and writers for different versions of the
InternalTimersSnapshot . |
InternalTimeServiceManager<K,N> |
An entity keeping all the time-related services available to all operators extending the
AbstractStreamOperator . |
KeyedProcessOperator<K,IN,OUT> |
A
StreamOperator for executing keyed
ProcessFunctions . |
OperatorSnapshotResult | |
ProcessOperator<IN,OUT> |
A
StreamOperator for executing
ProcessFunctions . |
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> | |
StreamFilter<IN> |
A
StreamOperator for executing FilterFunctions . |
StreamFlatMap<IN,OUT> |
A
StreamOperator for executing FlatMapFunctions . |
StreamGroupedFold<IN,OUT,KEY> | Deprecated
will be removed in a future version
|
StreamGroupedReduce<IN> | |
StreamingRuntimeContext |
Implementation of the
RuntimeContext ,
for streaming operators. |
StreamMap<IN,OUT> |
A
StreamOperator for executing MapFunctions . |
StreamProject<IN,OUT extends Tuple> |
A
StreamOperator for executing projections on streams. |
StreamSink<IN> |
A
StreamOperator for executing SinkFunctions . |
StreamSource<OUT,SRC extends SourceFunction<OUT>> |
StreamOperator for streaming sources. |
StreamSourceContexts |
Source contexts for various stream time characteristics.
|
TimestampedCollector<T> |
Enum | Description |
---|---|
ChainingStrategy |
Defines the chaining scheme for the operator.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.