Package org.apache.flink.streaming.api.operators
-
Interface Summary Interface Description BoundedMultiInput Interface for multi-input operators that need to be notified about the logical/semantical end of input.BoundedOneInput Interface for one-input operators that need to be notified about the logical/semantical end of input.CoordinatedOperatorFactory<OUT> A factory class for theStreamOperator
s implementingOperatorEventHandler
.Input<IN> Input
interface used inMultipleInputStreamOperator
.InputFormatOperatorFactory<OUT> Input format source operator factory.InputSelectable Interface for stream operators that can select the input to getStreamRecord
.InternalTimer<K,N> Internal interface for in-flight timers.InternalTimerService<N> Interface for working with time and timers.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> A reader for aInternalTimersSnapshot
.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter A writer for aInternalTimersSnapshot
.InternalTimeServiceManager<K> An entity keeping all the time-related services.InternalTimeServiceManager.Provider A provider pattern for creating an instance of aInternalTimeServiceManager
.InternalTimeServiceManager.ShouldStopAdvancingFn Signals whether the watermark should continue advancing.KeyContext Interface for setting and querying the current key of keyed operations.KeyContextHandler This interface is used to optimize the calls ofInput.setKeyContextElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IN>)
,StreamOperator.setKeyContextElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>)
andStreamOperator.setKeyContextElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>)
.MultipleInputStreamOperator<OUT> Interface for stream operators with multipleInput
s.OneInputStreamOperator<IN,OUT> Interface for stream operators with one input.OneInputStreamOperatorFactory<IN,OUT> A factory to createOneInputStreamOperator
.OnWatermarkCallback<KEY> A callback registered with theInternalWatermarkCallbackService
service.Output<T> AStreamOperator
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.OutputFormatOperatorFactory<IN,OUT> Interface for operator factories which create the sink operator containing anOutputFormat
.OutputTypeConfigurable<OUT> Stream operators can implement this interface if they need access to the output type information atorg.apache.flink.streaming.api.graph.StreamGraph
generation.StreamOperator<OUT> Basic interface for stream operators.StreamOperatorFactory<OUT> A factory to createStreamOperator
.StreamOperatorStateContext This interface represents a context from which a stream operator can initialize everything connected to state such as e.g. backends, raw state, and timer service manager.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.StreamTaskStateInitializer This is the interface through which stream task expose aStreamOperatorStateContext
to their operators.StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R extends Disposable & Closeable> Functional interface to create the keyed state backend.Triggerable<K,N> Interface for things that can be called byInternalTimerService
.TwoInputStreamOperator<IN1,IN2,OUT> Interface for stream operators with two inputs.TwoInputStreamOperatorFactory<IN1,IN2,OUT> A factory to createTwoInputStreamOperator
.UdfStreamOperatorFactory<OUT> Udf stream operator factory.UserFunctionProvider<F extends Function> The interface with user function.YieldingOperator<OUT> A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Class Summary Class Description AbstractInput<IN,OUT> Base abstract implementation ofInput
interface intended to be used when extendingAbstractStreamOperatorV2
.AbstractStreamOperator<OUT> Base class for all stream operators.AbstractStreamOperatorFactory<OUT> Base class for all stream operator factories.AbstractStreamOperatorV2<OUT> New base class for all stream operators, intended to eventually replaceAbstractStreamOperator
.AbstractUdfStreamOperator<OUT,F extends Function> This is used as the base class for operators that have a user-defined function.BackendRestorerProcedure<T extends Closeable & Disposable,S extends StateObject> This class implements the logic that creates (and potentially restores) a state backend.BatchGroupedReduceOperator<IN,KEY> AStreamOperator
for executing aReduceFunction
on aKeyedStream
in aRuntimeExecutionMode.BATCH
mode.CountingOutput<OUT> WrappingOutput
that updates metrics on the number of emitted elements.InputSelection Describe the input selection that stream operators want to read records.InputSelection.Builder Utility class for creatingInputSelection
.InternalTimerServiceAsyncImpl<K,N> An implementation ofInternalTimerService
that is used byorg.apache.flink.streaming.runtime.operators.asyncprocessing.AbstractAsyncStateStreamOperator
.InternalTimerServiceImpl<K,N> InternalTimerService
that stores timers on the Java heap.InternalTimerServiceSerializationProxy<K> 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 theInternalTimersSnapshot
.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N> ATypeSerializer
used to serialize/deserialize aTimerHeapInternalTimer
.InternalTimeServiceManagerImpl<K> An entity keeping all the time-related services.KeyedProcessOperator<K,IN,OUT> AStreamOperator
for executingKeyedProcessFunctions
.LegacyKeyedProcessOperator<K,IN,OUT> Deprecated. Replaced byKeyedProcessOperator
which takesKeyedProcessFunction
MailboxWatermarkProcessor<OUT> A helper class to let operators emit watermarks incrementally from mailbox.MapPartitionIterator<IN> TheMapPartitionIterator
is an iterator used in theMapPartitionOperator
.The task main thread will add records to it.MapPartitionOperator<IN,OUT> TheMapPartitionOperator
is used to process all records in each partition on non-keyed stream.OperatorAttributes OperatorAttributes element provides Job Manager with information that can be used to optimize job performance.OperatorAttributesBuilder The builder class forOperatorAttributes
.OperatorSnapshotFinalizer This class finalizesOperatorSnapshotFutures
.OperatorSnapshotFutures PartitionAggregateOperator<IN,ACC,OUT> ThePartitionAggregateOperator
is used to apply the aggregate transformation on all records of each partition.PartitionReduceOperator<IN> ThePartitionReduceOperator
is used to apply the reduce transformation on all records of each partition.ProcessOperator<IN,OUT> AStreamOperator
for executingProcessFunctions
.SimpleInputFormatOperatorFactory<OUT> Input format source operator factory which just wrap existedStreamSource
.SimpleOperatorFactory<OUT> Simple factory which just wrap existedStreamOperator
.SimpleOutputFormatOperatorFactory<IN,OUT> A simple operator factory which create an operator containing anOutputFormat
.SimpleUdfStreamOperatorFactory<OUT> Udf stream operator factory which just wrap existedAbstractUdfStreamOperator
.SourceOperator<OUT,SplitT extends SourceSplit> Base source operator only used for integrating the source reader which is proposed by FLIP-27.SourceOperatorFactory<OUT> The Factory class forSourceOperator
.StreamFilter<IN> AStreamOperator
for executingFilterFunctions
.StreamFlatMap<IN,OUT> AStreamOperator
for executingFlatMapFunctions
.StreamGroupedReduceOperator<IN> StreamingRuntimeContext Implementation of theRuntimeContext
, for streaming operators.StreamMap<IN,OUT> AStreamOperator
for executingMapFunctions
.StreamOperatorFactoryUtil A utility to instantiate new operators with a given factory.StreamOperatorParameters<OUT> Helper class to constructAbstractStreamOperatorV2
.StreamOperatorStateHandler Class encapsulating various state backend handling logic forStreamOperator
implementations.StreamOperatorUtils StreamProject<IN,OUT extends Tuple> AStreamOperator
for executing projections on streams.StreamSink<IN> AStreamOperator
for executingSinkFunctions
.StreamSource<OUT,SRC extends SourceFunction<OUT>> Deprecated. This class is based on theSourceFunction
API, which is due to be removed.StreamSourceContexts Deprecated. This class is based on theSourceFunction
API, which is due to be removed.StreamTaskStateInitializerImpl This class is the main implementation of aStreamTaskStateInitializer
.TimerHeapInternalTimer<K,N> Implementation ofInternalTimer
to use with aHeapPriorityQueueSet
.TimerSerializer<K,N> A serializer forTimerHeapInternalTimer
objects that produces a serialization format that is lexicographically aligned the priority of the timers.TimerSerializerSnapshot<K,N> Snapshot class for theTimerSerializer
.TimestampedCollector<T> -
Enum Summary Enum Description ChainingStrategy Defines the chaining scheme for the operator.