Uses of Package
org.apache.flink.streaming.api.operators
-
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.runtime.asyncprocessing.operators Class Description AbstractStreamOperator Base class for all stream operators.AbstractStreamOperatorV2 New base class for all stream operators, intended to eventually replaceAbstractStreamOperator
.Input Input
interface used inMultipleInputStreamOperator
.InternalTimer Internal interface for in-flight timers.InternalTimerService Interface for working with time and timers.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<?>)
.OneInputStreamOperator Interface for stream operators with one input.Output 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.StreamOperator Basic interface for stream operators.StreamOperatorParameters Helper class to constructAbstractStreamOperatorV2
.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.Triggerable Interface for things that can be called byInternalTimerService
.TwoInputStreamOperator Interface for stream operators with two inputs.UserFunctionProvider The interface with user function.YieldingOperator A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.runtime.asyncprocessing.operators.windowing Class Description AbstractStreamOperator Base class for all stream operators.Input Input
interface used inMultipleInputStreamOperator
.InternalTimer Internal interface for in-flight timers.InternalTimerService Interface for working with time and timers.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<?>)
.OneInputStreamOperator Interface for stream operators with one input.OperatorAttributes OperatorAttributes element provides Job Manager with information that can be used to optimize job performance.Output 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.StreamOperator Basic interface for stream operators.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.Triggerable Interface for things that can be called byInternalTimerService
.UserFunctionProvider The interface with user function.YieldingOperator A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api Class Description InternalTimerService Interface for working with time and timers. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.datastream Class Description OneInputStreamOperator Interface for stream operators with one input.OneInputStreamOperatorFactory A factory to createOneInputStreamOperator
.StreamOperatorFactory A factory to createStreamOperator
.StreamSource Deprecated.This class is based on theSourceFunction
API, which is due to be removed.TwoInputStreamOperator Interface for stream operators with two inputs.TwoInputStreamOperatorFactory A factory to createTwoInputStreamOperator
. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.graph Class Description InternalTimeServiceManager.Provider A provider pattern for creating an instance of aInternalTimeServiceManager
.SourceOperatorFactory The Factory class forSourceOperator
.StreamOperator Basic interface for stream operators.StreamOperatorFactory A factory to createStreamOperator
. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.graph.util Class Description StreamOperatorFactory A factory to createStreamOperator
. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.operators Class Description AbstractStreamOperator Base class for all stream operators.AbstractStreamOperatorFactory Base class for all stream operator factories.AbstractUdfStreamOperator This is used as the base class for operators that have a user-defined function.BoundedOneInput Interface for one-input operators that need to be notified about the logical/semantical end of input.ChainingStrategy Defines the chaining scheme for the operator.CoordinatedOperatorFactory A factory class for theStreamOperator
s implementingOperatorEventHandler
.Input Input
interface used inMultipleInputStreamOperator
.InputFormatOperatorFactory Input format source operator factory.InputSelection Describe the input selection that stream operators want to read records.InputSelection.Builder Utility class for creatingInputSelection
.InternalTimer Internal interface for in-flight timers.InternalTimerService Interface for working with time and timers.InternalTimerServiceImpl InternalTimerService
that stores timers on the Java heap.InternalTimersSnapshot A snapshot of internal timers, containing event and processing timers and the serializers to use to write / read them.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader A reader for aInternalTimersSnapshot
.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter A writer for aInternalTimersSnapshot
.InternalTimeServiceManager 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.InternalTimeServiceManagerImpl An entity keeping all the time-related services.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<?>)
.OneInputStreamOperator Interface for stream operators with one input.OperatorAttributes OperatorAttributes element provides Job Manager with information that can be used to optimize job performance.OperatorAttributesBuilder The builder class forOperatorAttributes
.OperatorSnapshotFutures Output 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 Interface for operator factories which create the sink operator containing anOutputFormat
.SimpleOperatorFactory Simple factory which just wrap existedStreamOperator
.StreamingRuntimeContext Implementation of theRuntimeContext
, for streaming operators.StreamOperator Basic interface for stream operators.StreamOperatorFactory A factory to createStreamOperator
.StreamOperatorParameters Helper class to constructAbstractStreamOperatorV2
.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 Class encapsulating various state backend handling logic forStreamOperator
implementations.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.StreamSource Deprecated.This class is based on theSourceFunction
API, which is due to be removed.StreamTaskStateInitializer This is the interface through which stream task expose aStreamOperatorStateContext
to their operators.StreamTaskStateInitializerImpl.KeyedStateBackendCreator Functional interface to create the keyed state backend.TimerHeapInternalTimer Implementation ofInternalTimer
to use with aHeapPriorityQueueSet
.TimerSerializer A serializer forTimerHeapInternalTimer
objects that produces a serialization format that is lexicographically aligned the priority of the timers.TimerSerializerSnapshot Snapshot class for theTimerSerializer
.Triggerable Interface for things that can be called byInternalTimerService
.UdfStreamOperatorFactory Udf stream operator factory.UserFunctionProvider The interface with user function.YieldingOperator A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.operators.co Class Description AbstractStreamOperator Base class for all stream operators.AbstractUdfStreamOperator This is used as the base class for operators that have a user-defined function.BoundedMultiInput Interface for multi-input operators that need to be notified about the logical/semantical end of input.InputSelectable Interface for stream operators that can select the input to getStreamRecord
.InputSelection Describe the input selection that stream operators want to read records.InternalTimer Internal interface for in-flight timers.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<?>)
.StreamOperator Basic interface for stream operators.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.TimestampedCollector Triggerable Interface for things that can be called byInternalTimerService
.TwoInputStreamOperator Interface for stream operators with two inputs.UserFunctionProvider The interface with user function.YieldingOperator A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.operators.legacy Class Description StreamOperatorFactory A factory to createStreamOperator
. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.operators.sort Class Description InputSelectable Interface for stream operators that can select the input to getStreamRecord
. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.operators.sorted.state Class Description InternalTimerService Interface for working with time and timers.InternalTimeServiceManager An entity keeping all the time-related services.InternalTimeServiceManager.ShouldStopAdvancingFn Signals whether the watermark should continue advancing.KeyContext Interface for setting and querying the current key of keyed operations.Triggerable Interface for things that can be called byInternalTimerService
. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.operators.sortpartition Class Description AbstractStreamOperator Base class for all stream operators.BoundedOneInput Interface for one-input operators that need to be notified about the logical/semantical end of input.Input Input
interface used inMultipleInputStreamOperator
.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<?>)
.OneInputStreamOperator Interface for stream operators with one input.OperatorAttributes OperatorAttributes element provides Job Manager with information that can be used to optimize job performance.Output 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.StreamOperator Basic interface for stream operators.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.YieldingOperator A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.api.transformations Class Description ChainingStrategy Defines the chaining scheme for the operator.OneInputStreamOperator Interface for stream operators with one input.StreamOperatorFactory A factory to createStreamOperator
.StreamSink AStreamOperator
for executingSinkFunctions
.StreamSource Deprecated.This class is based on theSourceFunction
API, which is due to be removed.TwoInputStreamOperator Interface for stream operators with two inputs. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.runtime.io Class Description BoundedMultiInput Interface for multi-input operators that need to be notified about the logical/semantical end of input.Input Input
interface used inMultipleInputStreamOperator
.InputSelectable Interface for stream operators that can select the input to getStreamRecord
.MultipleInputStreamOperator Interface for stream operators with multipleInput
s.Output 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.SourceOperator Base source operator only used for integrating the source reader which is proposed by FLIP-27.TwoInputStreamOperator Interface for stream operators with two inputs. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.runtime.operators.windowing Class Description AbstractStreamOperator Base class for all stream operators.AbstractStreamOperatorFactory Base class for all stream operator factories.AbstractUdfStreamOperator This is used as the base class for operators that have a user-defined function.Input Input
interface used inMultipleInputStreamOperator
.InternalTimer Internal interface for in-flight timers.InternalTimerService Interface for working with time and timers.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<?>)
.OneInputStreamOperator Interface for stream operators with one input.OneInputStreamOperatorFactory A factory to createOneInputStreamOperator
.OperatorAttributes OperatorAttributes element provides Job Manager with information that can be used to optimize job performance.Output 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.StreamOperator Basic interface for stream operators.StreamOperatorFactory A factory to createStreamOperator
.StreamOperatorParameters Helper class to constructAbstractStreamOperatorV2
.StreamOperatorStateHandler.CheckpointedStreamOperator Custom state handling hooks to be invoked byStreamOperatorStateHandler
.TimestampedCollector Triggerable Interface for things that can be called byInternalTimerService
.UserFunctionProvider The interface with user function.YieldingOperator A V1 operator that needs access to theMailboxExecutor
should implement this interface. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.runtime.tasks Class Description BoundedMultiInput Interface for multi-input operators that need to be notified about the logical/semantical end of input.Input Input
interface used inMultipleInputStreamOperator
.OperatorSnapshotFutures Output 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.SourceOperator Base source operator only used for integrating the source reader which is proposed by FLIP-27.StreamOperator Basic interface for stream operators.StreamSource Deprecated.This class is based on theSourceFunction
API, which is due to be removed.StreamTaskStateInitializer This is the interface through which stream task expose aStreamOperatorStateContext
to their operators. -
Classes in org.apache.flink.streaming.api.operators used by org.apache.flink.streaming.runtime.watermark.extension.eventtime Class Description InternalTimeServiceManager An entity keeping all the time-related services.Output 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.