Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyedCEPPatternOperator<IN,KEY,OUT,F extends Function>
Abstract CEP pattern operator for a keyed input stream.
|
class |
FlatSelectCepOperator<IN,KEY,OUT>
Version of
AbstractKeyedCEPPatternOperator that applies given PatternFlatSelectFunction to fully matched event patterns. |
class |
FlatSelectTimeoutCepOperator<IN,OUT1,OUT2,KEY>
Version of
AbstractKeyedCEPPatternOperator that applies given PatternFlatSelectFunction to fully
matched event patterns and PatternFlatTimeoutFunction to timed out ones. |
class |
SelectCepOperator<IN,KEY,OUT>
Version of
AbstractKeyedCEPPatternOperator that applies given PatternSelectFunction to fully matched event patterns. |
class |
SelectTimeoutCepOperator<IN,OUT1,OUT2,KEY>
Version of
AbstractKeyedCEPPatternOperator that applies given PatternSelectFunction to fully
matched event patterns and PatternTimeoutFunction to timed out ones. |
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 |
TaskStateManager
This interface provides methods to report and retrieve state for a task.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.
|
class |
TaskStateManagerImpl
This class is the default implementation of
TaskStateManager and collaborates with the job manager
through CheckpointResponder ) as well as a task-manager-local state store. |
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 |
Task
The Task represents one execution of a parallel subtask on a TaskManager.
|
Modifier and Type | Class and Description |
---|---|
class |
BoltWrapper<IN,OUT>
A
BoltWrapper wraps an IRichBolt in order to execute the Storm bolt within a Flink Streaming program. |
class |
MergedInputsBoltWrapper<IN,OUT>
|
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 |
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT>
This is a recommended base class for all of the
SinkFunction that intend to implement exactly-once semantic. |
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileReaderOperator<OUT>
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
class |
MessageAcknowledgingSourceBase<Type,UId>
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
|
class |
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId>
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
|
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 |
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 |
RollingSink<T>
Deprecated.
use
BucketingSink instead. |
Modifier and Type | Class and Description |
---|---|
class |
BucketingSink<T>
Sink that emits its input elements to
FileSystem files within
buckets. |
Modifier and Type | Class and Description |
---|---|
class |
FlinkKafkaConsumer010<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.10.x.
|
class |
FlinkKafkaConsumer011<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.11.x.
|
class |
FlinkKafkaConsumer08<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.8.x.
|
class |
FlinkKafkaConsumer081<T>
Deprecated.
|
class |
FlinkKafkaConsumer082<T>
Deprecated.
|
class |
FlinkKafkaConsumer09<T>
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.9.x.
|
class |
FlinkKafkaConsumerBase<T>
Base class of all Flink Kafka Consumer data sources.
|
class |
FlinkKafkaProducer011<IN>
Flink Sink to produce data into a Kafka topic.
|
Modifier and Type | Class and Description |
---|---|
class |
RMQSource<OUT>
RabbitMQ source (consumer) which reads from a queue and acknowledges messages on checkpoints.
|
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 . |
Modifier and Type | Class and Description |
---|---|
class |
FailureMapper<T>
This mapper simulates failure by throwing exceptions.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.