All Classes Interface Summary Class Summary Enum Summary
| Class |
Description |
| AbstractInput<IN,OUT> |
Base abstract implementation of Input interface intended to be used when extending AbstractStreamOperatorV2.
|
| ArrayFromTuple |
Converts a Tuple to an Object-Array.
|
| AscendingTimestampExtractor<T> |
Deprecated. |
| AscendingTimestampExtractor.FailingHandler |
Handler that fails the program when timestamp monotony is violated.
|
| AscendingTimestampExtractor.IgnoringHandler |
Handler that does nothing when timestamp monotony is violated.
|
| AscendingTimestampExtractor.LoggingHandler |
Handler that only logs violations of timestamp monotony, on WARN log level.
|
| AscendingTimestampExtractor.MonotonyViolationHandler |
Interface for handlers that handle violations of the monotonous ascending timestamps
property.
|
| AsyncDataStream |
|
| AsyncDataStream.OutputMode |
Output mode for asynchronous operations.
|
| AsyncFunction<IN,OUT> |
A function to trigger Async I/O operation.
|
| AsyncRetryPredicate<OUT> |
Interface encapsulates an asynchronous retry predicate.
|
| AsyncRetryStrategies |
|
| AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategy<OUT> |
ExponentialBackoffDelayRetryStrategy.
|
| AsyncRetryStrategies.ExponentialBackoffDelayRetryStrategyBuilder<OUT> |
ExponentialBackoffDelayRetryStrategyBuilder for building a
ExponentialBackoffDelayRetryStrategy.
|
| AsyncRetryStrategies.FixedDelayRetryStrategy<OUT> |
FixedDelayRetryStrategy.
|
| AsyncRetryStrategies.FixedDelayRetryStrategyBuilder<OUT> |
FixedDelayRetryStrategyBuilder for building a FixedDelayRetryStrategy.
|
| AsyncRetryStrategy<OUT> |
Interface encapsulates an asynchronous retry strategy.
|
| AsyncWaitOperator<IN,OUT> |
|
| AsyncWaitOperatorFactory<IN,OUT> |
|
| BoundedOutOfOrdernessTimestampExtractor<T> |
This is a WatermarkStrategyWithPeriodicWatermarks used to emit Watermarks that lag behind
the element with the maximum timestamp (in event time) seen so far by a fixed amount of time,
t_late.
|
| Bucket<IN,BucketID> |
|
| BucketFactory<IN,BucketID> |
|
| BucketLifeCycleListener<IN,BucketID> |
Listener about the status of Bucket.
|
| Buckets<IN,BucketID> |
|
| CheckpointCommitter |
This class is used to save information about which sink operator instance has committed
checkpoints to a backend.
|
| CollectionInputFormat<T> |
An input format that returns objects from a collection.
|
| CollectionSupplier<OUT> |
Supplies a collection of output.
|
| CollectSink<IN> |
A specialized data sink to be used by DataStreamUtils.collect().
|
| ConcatenatedExtract<FROM,OVER,TO> |
Combines two extractors which will be executed one after each other.
|
| ContinuousEventTimeTrigger<W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A Trigger that continuously fires based on a given time interval.
|
| ContinuousProcessingTimeTrigger<W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A Trigger that continuously fires based on a given time interval as measured by the clock
of the machine on which the job is running.
|
| CosineDistance<DATA> |
This delta function calculates the cosine distance between two given vectors.
|
| DataGenerator<T> |
Stateful and re-scalable data generator.
|
| DataGeneratorSource<T> |
Deprecated.
|
| DatasetConfigFacet |
Builtin config facet for dataset.
|
| DatasetSchemaFacet |
Builtin schema facet for dataset.
|
| DatasetSchemaField<T> |
Field for schema in dataset.
|
| DataStreamUtils |
A collection of utilities for DataStreams.
|
| DefaultBucketFactoryImpl<IN,BucketID> |
|
| DefaultJobCreatedEvent |
|
| DefaultLineageVertex |
Default implementation for LineageVertex.
|
| DefaultSourceLineageVertex |
Default implementation for SourceLineageVertex.
|
| DeltaEvictor<T,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
An Evictor that keeps elements based on a DeltaFunction and a threshold.
|
| DeltaFunction<DATA> |
This interface allows the implementation of a function which calculates the delta between two
data points.
|
| DeltaTrigger<T,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
|
| DiscardingSink<T> |
Deprecated.
|
| DiscardingSink<IN> |
A special sink that ignores all elements.
|
| DynamicEventTimeSessionWindows<T> |
A WindowAssigner that windows elements into sessions based on the timestamp of the
elements.
|
| DynamicProcessingTimeSessionWindows<T> |
A WindowAssigner that windows elements into sessions based on the current processing
time.
|
| EuclideanDistance<DATA> |
This delta function calculates the euclidean distance between two given points.
|
| EventTimeSessionWindows |
A WindowAssigner that windows elements into sessions based on the timestamp of the
elements.
|
| ExtractionAwareDeltaFunction<DATA,TO> |
Extend this abstract class to implement a delta function which is aware of extracting the data on
which the delta is calculated from a more complex data structure.
|
| Extractor<FROM,TO> |
Extractors allow to extract/convert one type to another.
|
| FieldFromArray<OUT> |
Extracts a single field out of an array.
|
| FieldFromTuple<OUT> |
Extracts a single field out of a tuple.
|
| FieldsFromArray<OUT> |
Extracts multiple fields from an array and puts them into a new array of the specified type.
|
| FieldsFromTuple |
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
|
| FileLifeCycleListener<BucketID> |
Listener about the status of file.
|
| FlinkChillPackageRegistrar |
Registers all chill serializers used for Java types.
|
| GenericWriteAheadSink<IN> |
Generic Sink that emits its input elements into an arbitrary backend.
|
| InetSocketAddressSerializer |
InetSocketAddressSerializer is a Kryo 5.x serializer for InetSocketAddress.
|
| JobCreatedEvent |
Basic job created event.
|
| KeyMap<K,V> |
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
|
| KeyMap.Entry<K,V> |
An entry in the hash table.
|
| KeyMap.LazyFactory<V> |
A factory for lazy/on-demand instantiation of values.
|
| KeyMap.TraversalEvaluator<K,V> |
A visitor for a traversal over the union of multiple hash maps.
|
| MultipleConnectedStreams |
This is a very basic and rough stub for a class connecting multiple input DataStreams
into one, using MultipleInputStreamOperator.
|
| OnWatermarkCallback<KEY> |
A callback registered with the InternalWatermarkCallbackService service.
|
| OrderedStreamElementQueue<OUT> |
|
| PrintSink<IN> |
Sink implementation writing every element to the standard output or standard error stream.
|
| ProcessingTimeoutTrigger<T,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A Trigger that can turn any Trigger into a timeout Trigger.
|
| ProcessingTimeSessionWindows |
A WindowAssigner that windows elements into sessions based on the current processing
time.
|
| RandomGenerator<T> |
Random generator.
|
| ResultFuture<OUT> |
ResultFuture collects data / error in user codes while processing async i/o.
|
| RetryPredicates |
Utility class to create concrete retry predicates.
|
| RichAllWindowFunction<IN,OUT,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
A RichFunction version of AllWindowFunction.
|
| RichAsyncFunction<IN,OUT> |
|
| RichCoFlatMapFunction<IN1,IN2,OUT> |
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
|
| RichCoMapFunction<IN1,IN2,OUT> |
A RichCoMapFunction represents a Map transformation with two different input types.
|
| RichWindowFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> |
Rich variant of the WindowFunction.
|
| SequenceGenerator<T> |
A stateful, re-scalable DataGenerator that emits each number from a given interval
exactly once, possibly in parallel.
|
| SessionWindowTimeGapExtractor<T> |
A SessionWindowTimeGapExtractor extracts session time gaps for Dynamic Session Window
Assigners.
|
| SinkContextUtil |
Utility for creating Sink Contexts.
|
| SocketStreamIterator<T> |
An iterator that returns the data from a socket stream.
|
| StreamElementQueue<OUT> |
|
| StreamElementQueueEntry<OUT> |
|
| StreamingFileSink<IN> |
Deprecated.
|
| StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>> |
|
| StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>> |
A builder for configuring the sink for bulk-encoding formats, e.g.
|
| StreamingFileSink.DefaultBulkFormatBuilder<IN> |
|
| StreamingFileSink.DefaultRowFormatBuilder<IN> |
|
| StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>> |
A builder for configuring the sink for row-wise encoding formats.
|
| StreamingFileSinkHelper<IN> |
|
| StreamRecordQueueEntry<OUT> |
|
| TextInputFormat |
Deprecated.
|
| TextOutputFormat<T> |
Deprecated.
|
| TextOutputFormat.TextFormatter<IN> |
Formatter that transforms values into their String representations.
|
| TimeEvictor<W extends org.apache.flink.streaming.api.windowing.windows.Window> |
An Evictor that keeps elements for a certain amount of time.
|
| TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> |
Deprecated.
|
| TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> |
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
|
| TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> |
Custom TypeSerializer for the sink state.
|
| TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> |
|
| TwoPhaseCommitSinkFunction.TransactionHolder<TXN> |
Adds metadata (currently only the start time of the transaction) to the transaction object.
|
| UnorderedStreamElementQueue<OUT> |
|