Package | Description |
---|---|
org.apache.flink.cep.operator | |
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.checkpoint.savepoint | |
org.apache.flink.runtime.operators.sort | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state
on the JVM heap as objects.
|
org.apache.flink.streaming.api.functions.query | |
org.apache.flink.streaming.api.functions.source | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.async | |
org.apache.flink.streaming.api.operators.co | |
org.apache.flink.streaming.connectors.cassandra | |
org.apache.flink.streaming.runtime.operators |
This package contains the operators that perform the stream transformations.
|
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations
on data streams.
|
Modifier and Type | Class and Description |
---|---|
class |
CepOperator<IN,KEY,OUT>
CEP pattern operator for a keyed input stream.
|
Modifier and Type | Class and Description |
---|---|
class |
RocksDBKeyedStateBackend<K>
An
AbstractKeyedStateBackend that stores its state in RocksDB and serializes state to
streams provided by a CheckpointStreamFactory upon
checkpointing. |
Modifier and Type | Interface and Description |
---|---|
interface |
Savepoint
Savepoints are manually-triggered snapshots from which a program can be
resumed on submission.
|
Modifier and Type | Class and Description |
---|---|
class |
SavepointV1
Savepoint version 0.
|
class |
SavepointV2
The persistent checkpoint metadata, format version 2.
|
Modifier and Type | Interface and Description |
---|---|
interface |
InMemorySorter<T> |
Modifier and Type | Class and Description |
---|---|
class |
FixedLengthRecordSorter<T> |
class |
NormalizedKeySorter<T> |
Modifier and Type | Interface and Description |
---|---|
interface |
KeyedStateBackend<K>
A keyed state backend provides methods for managing keyed state.
|
interface |
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system interface
SnapshotStrategy |
Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.
|
class |
DefaultOperatorStateBackend
Default implementation of OperatorStateStore that provides the ability to make snapshots.
|
Modifier and Type | Class and Description |
---|---|
class |
HeapKeyedStateBackend<K>
A
AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to
streams provided by a CheckpointStreamFactory upon checkpointing. |
Modifier and Type | Class and Description |
---|---|
class |
QueryableAppendingStateOperator<IN>
Internal operator handling queryable AppendingState instances.
|
class |
QueryableValueStateOperator<IN>
Internal operator handling queryable ValueState instances.
|
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileReaderOperator<OUT>
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
Modifier and Type | Class and Description |
---|---|
class |
BackendRestorerProcedure<T extends Closeable & Disposable,S extends StateObject>
This class implements the logic that creates (and potentially restores) a state backend.
|
Modifier and Type | Interface and Description |
---|---|
interface |
OneInputStreamOperator<IN,OUT>
Interface for stream operators with one input.
|
interface |
StreamOperator<OUT>
Basic interface for stream operators.
|
interface |
TwoInputStreamOperator<IN1,IN2,OUT>
Interface for stream operators with two inputs.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamOperator<OUT>
Base class for all stream operators.
|
class |
AbstractUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined
function.
|
class |
KeyedProcessOperator<K,IN,OUT>
A
StreamOperator for executing KeyedProcessFunctions . |
class |
LegacyKeyedProcessOperator<K,IN,OUT>
Deprecated.
Replaced by
KeyedProcessOperator which takes KeyedProcessFunction |
class |
ProcessOperator<IN,OUT>
A
StreamOperator for executing
ProcessFunctions . |
class |
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction>
|
class |
StreamFilter<IN>
A
StreamOperator for executing FilterFunctions . |
class |
StreamFlatMap<IN,OUT>
A
StreamOperator for executing FlatMapFunctions . |
class |
StreamGroupedFold<IN,OUT,KEY>
Deprecated.
will be removed in a future version
|
class |
StreamGroupedReduce<IN>
|
class |
StreamMap<IN,OUT>
A
StreamOperator for executing MapFunctions . |
class |
StreamProject<IN,OUT extends Tuple>
A
StreamOperator for executing projections on streams. |
class |
StreamSink<IN>
A
StreamOperator for executing SinkFunctions . |
class |
StreamSource<OUT,SRC extends SourceFunction<OUT>>
StreamOperator for streaming sources. |
Modifier and Type | Class and Description |
---|---|
class |
AsyncWaitOperator<IN,OUT>
The
AsyncWaitOperator allows to asynchronously process incoming stream records. |
Modifier and Type | Class and Description |
---|---|
class |
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT>
A
TwoInputStreamOperator for executing KeyedBroadcastProcessFunctions . |
class |
CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT>
A
TwoInputStreamOperator for executing BroadcastProcessFunctions . |
class |
CoProcessOperator<IN1,IN2,OUT>
A
StreamOperator for executing
CoProcessFunctions . |
class |
CoStreamFlatMap<IN1,IN2,OUT>
StreamOperator for processing
CoFlatMapFunctions . |
class |
CoStreamMap<IN1,IN2,OUT>
StreamOperator for processing
CoMapFunctions . |
class |
IntervalJoinOperator<K,T1,T2,OUT>
An
operator to execute time-bounded stream inner joins. |
class |
KeyedCoProcessOperator<K,IN1,IN2,OUT>
A
StreamOperator for executing keyed
CoProcessFunctions . |
Modifier and Type | Class and Description |
---|---|
class |
CassandraRowWriteAheadSink
Sink that emits its input elements into a Cassandra table.
|
class |
CassandraTupleWriteAheadSink<IN extends Tuple>
Sink that emits its input elements into a Cassandra database.
|
Modifier and Type | Class and Description |
---|---|
class |
ExtractTimestampsOperator<T>
Deprecated.
|
class |
GenericWriteAheadSink<IN>
Generic Sink that emits its input elements into an arbitrary backend.
|
class |
TimestampsAndPeriodicWatermarksOperator<T>
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
|
class |
TimestampsAndPunctuatedWatermarksOperator<T>
A stream operator that extracts timestamps from stream elements and
generates watermarks based on punctuation elements.
|
Modifier and Type | Class and Description |
---|---|
class |
EvictingWindowOperator<K,IN,OUT,W extends Window>
A
WindowOperator that also allows an Evictor to be used. |
class |
WindowOperator<K,IN,ACC,OUT,W extends Window>
An operator that implements the logic for windowing based on a
WindowAssigner and
Trigger . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.