- abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,STATE,F extends Function> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Deprecated.
- AbstractAlignedProcessingTimeWindowOperator(F, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<STATE>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- AbstractDeserializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
The deserialization schema describes how to turn the byte messages delivered by certain
data sources (for example Apache Kafka) into data types (Java/Scala objects) that are
processed by Flink.
- AbstractDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
-
- AbstractKeyedTimePanes<Type,Key,Aggregate,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Base class for a multiple key/value maps organized in panes.
- AbstractKeyedTimePanes() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operators.
- AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- AbstractStreamOperator.CountingOutput - Class in org.apache.flink.streaming.api.operators
-
- AbstractStreamOperator.CountingOutput(Output<StreamRecord<OUT>>, Counter) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- AbstractStreamOperator.LatencyGauge - Class in org.apache.flink.streaming.api.operators
-
The gauge uses a HashMap internally to avoid classloading issues when accessing
the values using JMX.
- AbstractUdfStreamOperator<OUT,F extends Function> - Class in org.apache.flink.streaming.api.operators
-
This is used as the base class for operators that have a user-defined
function.
- AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- AccumulatingKeyedTimePanes<Type,Key,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AccumulatingKeyedTimePanes(KeySelector<Type, Key>, WindowFunction<Type, Result, Key, Window>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
-
- AccumulatingProcessingTimeWindowOperator<KEY,IN,OUT> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Deprecated.
- AccumulatingProcessingTimeWindowOperator(WindowFunction<IN, OUT, KEY, TimeWindow>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
-
Deprecated.
- acknowledgeIDs(long, List<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
This method must be implemented to acknowledge the given set of IDs back to the message queue.
- acknowledgeIDs(long, List<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- acknowledgeSessionIDs(List<SessionId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ByteSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.DoubleSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.FloatSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.IntSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.LongSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ShortSum
-
- add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
- add(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Adds a buffer or event to the sequence of spilled buffers and events.
- addCoOperator(Integer, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addEdge(Integer, Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
-
- addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
-
- addFeedbackEdge(StreamTransformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Adds a feedback edge.
- addFeedbackEdge(StreamTransformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Adds a feedback edge.
- addId(UId) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Adds an ID to be stored with the current checkpoint.
- addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addNode(Integer, String, Class<? extends AbstractInvokable>, StreamOperator<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOperator(StreamTransformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- addOperator(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addOutputSelector(Integer, OutputSelector<T>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutputSelector(OutputSelector<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given sink to this DataStream.
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- addSink(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a Data Source to the streaming topology.
- addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to an input with a certain
partitioning.
- addVirtualSelectNode(Integer, Integer, List<String>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to only the outputs
with the selected names.
- addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Adds a new Window
to the set of in-flight windows.
- advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- AggregatingKeyedTimePanes<Type,Key> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AggregatingKeyedTimePanes(KeySelector<Type, Key>, ReduceFunction<Type>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
-
- AggregatingProcessingTimeWindowOperator<KEY,IN> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Deprecated.
- AggregatingProcessingTimeWindowOperator(ReduceFunction<IN>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
-
Deprecated.
- AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
-
- AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
-
- allOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
The allowed lateness for elements.
- AllWindowedStream<T,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
AllWindowedStream
represents a data stream where the stream of
elements is split into windows based on a
WindowAssigner
.
- AllWindowedStream(DataStream<T>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- AllWindowFunction<IN,OUT,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over non-keyed windows.
- apply(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Deprecated.
Use #fold(R, FoldFunction, AllWindowFunction)
instead.
- apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Deprecated.
Use #fold(R, FoldFunction, AllWindowFunction, TypeInformation, TypeInformation)
instead.
- apply(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed
for windowed groups.
- apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed
for windowed groups.
- apply(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Deprecated.
Use #fold(R, FoldFunction, WindowFunction)
instead.
- apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Deprecated.
Use #fold(R, FoldFunction, WindowFunction, TypeInformation, TypeInformation)
instead.
- apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction
-
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(Byte, W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- apply(Byte, W, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- apply(KEY, W, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- apply(KEY, W, IN, Collector<OUT>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Evaluates the window and outputs none or several elements.
- ArrayFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Converts a Tuple to an Object-Array.
- ArrayFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will convert the whole tuple (all
fields in the original order) to an array.
- ArrayFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will combine the fields as specified
in the indexes parameter in an object array.
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
Deprecated.
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
-
Deprecated.
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
-
A timestamp assigner and watermark generator for streams where timestamps are monotonously
ascending.
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
- AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Handler that fails the program when timestamp monotony is violated.
- AscendingTimestampExtractor.FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
-
- AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Handler that does nothing when timestamp monotony is violated.
- AscendingTimestampExtractor.IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
-
- AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Handler that only logs violations of timestamp monotony, on WARN log level.
- AscendingTimestampExtractor.LoggingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
-
- AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
-
Interface for handlers that handle violations of the monotonous ascending timestamps
property.
- asLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a LatencyMarker.
- asQueryableState(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as queryable ValueState instance.
- asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable ValueState instance.
- asQueryableState(String, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable FoldingState instance.
- asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable ReducingState instance.
- asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a StreamRecord.
- asResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
Return this async result as a async result collection.
- asResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- AssignerWithPeriodicWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
The AssignerWithPeriodicWatermarks
assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
- AssignerWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
The AssignerWithPunctuatedWatermarks
assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
- assignTimestamps(TimestampExtractor<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and periodically creates
watermarks to signal event time progress.
- assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and creates watermarks to
signal event time progress based on the elements themselves.
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a Collection
of windows that should be assigned to the element.
- asWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
Return this async result as a async watermark result.
- asWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a Watermark.
- AsyncCollectionResult<T> - Interface in org.apache.flink.streaming.api.operators.async.queue
-
AsyncResult
sub class for asynchronous result collections.
- AsyncCollector<OUT> - Interface in org.apache.flink.streaming.api.functions.async.collector
-
AsyncCollector
collects data / error in user codes while processing async i/o.
- AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
-
- AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
- AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
-
- AsyncExceptionHandler - Interface in org.apache.flink.streaming.runtime.tasks
-
An interface marking a task as capable of handling exceptions thrown
by different threads, other than the one executing the task itself.
- AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
A function to trigger Async I/O operation.
- AsynchronousException - Exception in org.apache.flink.streaming.runtime.tasks
-
An exception for wrapping exceptions that are thrown by an operator in threads other than the
main compute thread of that operator.
- AsynchronousException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- AsynchronousException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- asyncInvoke(IN, AsyncCollector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
-
Trigger async operation for each stream input.
- asyncInvoke(IN, AsyncCollector<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- AsyncResult - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
-
- AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- AsyncWatermarkResult - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- cancel() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
-
Cancels the source.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- cancel() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- cancel() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Returns true if this trigger supports merging of trigger state and can therefore
be used with a
MergingWindowAssigner
.
- chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- ChainingStrategy - Enum in org.apache.flink.streaming.api.operators
-
Defines the chaining scheme for the operator.
- checkAndGetNextWatermark(T, long) - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
-
Asks this implementation if it wants to emit a watermark.
- checkCollection(Collection<OUT>, Class<OUT>) - Static method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Verifies that all elements in the collection are non-null, and are of the given class, or
a subclass thereof.
- CheckpointBarrierHandler - Interface in org.apache.flink.streaming.runtime.io
-
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
- CheckpointCommitter - Class in org.apache.flink.streaming.runtime.operators
-
This class is used to save information about which sink operator instance has committed checkpoints to a backend.
- CheckpointCommitter() - Constructor for class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
- CheckpointConfig - Class in org.apache.flink.streaming.api.environment
-
Configuration that captures all checkpointing related settings.
- CheckpointConfig() - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- CheckpointConfig.ExternalizedCheckpointCleanup - Enum in org.apache.flink.streaming.api.environment
-
Cleanup behaviour for externalized checkpoints when the job is cancelled.
- Checkpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
-
- CheckpointedAsynchronously<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
-
- CheckpointedFunction - Interface in org.apache.flink.streaming.api.checkpoint
-
This is the core interface for stateful transformation functions, meaning functions
that maintain state across individual stream records.
- CheckpointedRestoring<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
-
Deprecated.
- CheckpointedRestoringOperator - Interface in org.apache.flink.streaming.api.operators
-
Deprecated.
- checkpointingLock - Variable in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- CheckpointingMode - Enum in org.apache.flink.streaming.api
-
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Invokes the
ClosureCleaner
on the given function if closure cleaning is enabled in the
ExecutionConfig
.
- clean(F) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns a "closure-cleaned" version of the given function.
- cleanFile(String) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Creates target file if it does not exist, cleans it if it exists.
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Cleans up all file resources held by this spilled sequence.
- cleanup() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Cleans up all internally held resources.
- cleanup() - Method in interface org.apache.flink.streaming.runtime.io.StreamingReader
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Remove all registered nodes etc.
- clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Clears any state that the trigger might still hold for the given window.
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- clearBuffers() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- close() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- close() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
This method is called by the system to shut down the context.
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- close() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Cleans up the current spilling channel and file.
- close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
Closes the writer.
- close() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Closes the resource/connection to it.
- close() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- closeWith(DataStream<T>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Closes the iteration.
- closeWith(DataStream<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
Closes the iteration.
- CoFeedbackTransformation<F> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- CoFeedbackTransformation(int, TypeInformation<F>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Creates a new CoFeedbackTransformation
from the given input.
- CoFlatMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a flat-map transformation over two
connected streams.
- coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a join operation.
- CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
CoGroupedStreams
represents two
DataStreams
that have been co-grouped.
- CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Creates new CoGroped data streams, which are the first step towards building a streaming co-group.
- CoGroupedStreams.TaggedUnion<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
Internal class for implementing tagged union co-group.
- CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
-
CoGrouped streams that have the key for one side defined.
- CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has
KeySelectors
defined for both inputs.
- CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
- CoGroupedStreams.WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- collect(Collection<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.collector.AsyncCollector
-
Set result.
- collect(Throwable) - Method in interface org.apache.flink.streaming.api.functions.async.collector.AsyncCollector
-
Set error
- collect(T) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source, without attaching a timestamp.
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- collect(Collection<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- collect(Throwable) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- collectWithTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source, and attaches the given timestamp.
- CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a map() transformation over two
connected streams.
- commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Mark the given checkpoint as completed in the resource.
- ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- ComparableAggregator(String, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- Comparator - Class in org.apache.flink.streaming.api.functions.aggregation
-
- Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- compareTo(TimestampedFileInputSplit) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- compareTo(InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- ConcatenatedExtract<FROM,OVER,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Combines two extractors which will be executed one after each other.
- ConcatenatedExtract(Extractor<FROM, OVER>, Extractor<OVER, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
Combines two extractors which will be executed one after each other.
- config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- ConfigurableStreamPartitioner - Interface in org.apache.flink.streaming.runtime.partitioner
-
Interface for
StreamPartitioner
which have to be configured with the maximum parallelism
of the stream transformation.
- configure(int) - Method in interface org.apache.flink.streaming.runtime.partitioner.ConfigurableStreamPartitioner
-
Configure the
StreamPartitioner
with the maximum parallelism of the down stream
operator.
- configure(int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- connect(DataStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
-
ConnectedStreams represent two connected streams of (possibly) different data types.
- ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - Constructor for class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- ConnectorSource<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- ConnectorSource(DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.ConnectorSource
-
- CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- context - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- ContinuousEventTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval.
- ContinuousFileMonitoringFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
This is the single (non-parallel) monitoring task which takes a
FileInputFormat
and, depending on the
FileProcessingMode
and the
FilePathFilter
, it is responsible for:
Monitoring a user-provided path.
Deciding which files should be further read and processed.
Creating the
splits
corresponding to those files.
Assigning them to downstream tasks for further processing.
The splits to be read are forwarded to the downstream
ContinuousFileReaderOperator
which can have parallelism greater than one.
- ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- ContinuousFileReaderOperator<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- ContinuousFileReaderOperator(FileInputFormat<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- ContinuousProcessingTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
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.
- CoProcessFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A function that processes elements of two streams and produces a single output one.
- CoProcessFunction.Context - Interface in org.apache.flink.streaming.api.functions.co
-
- CoProcessFunction.OnTimerContext - Interface in org.apache.flink.streaming.api.functions.co
-
- CoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- copy(InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- copy(InternalTimer<K, N>, InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- copy(GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(GlobalWindow, GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(TimeWindow, TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- copy(StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a copy of this stream record.
- copyFromLocal(File, URI) - Static method in class org.apache.flink.streaming.util.HDFSCopyFromLocal
-
- CopyingDirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
-
- CopyingDirectedOutput(List<OutputSelector<OUT>>, List<Tuple2<Output<StreamRecord<OUT>>, StreamEdge>>) - Constructor for class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
-
- copyTo(T, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Copies this record into the new stream record.
- copyToLocal(URI, File) - Static method in class org.apache.flink.streaming.util.HDFSCopyToLocal
-
- CosineDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the cosine distance between two given vectors.
- CosineDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CosineDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CoStreamFlatMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- CoStreamMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps up to a certain amount of elements.
- CountTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the count of elements in a pane reaches the given count.
- countWindow(long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling count windows.
- countWindow(long, long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding count windows.
- countWindowAll(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling count windows.
- countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding count windows.
- cover(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns the minimal window covers both this window and the given window.
- create() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
Creates an event-time trigger that fires once the watermark passes the end of the window.
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
Creates a new trigger that fires once system time passes the end of the window.
- create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
-
The factory method; creates the value.
- createBrokerIdString(JobID, String, int) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
Creates the identification string with which head and tail task find the shared blocking
queue for the back channel.
- createCheckpointStreamFactory(StreamOperator<?>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
This is only visible because
GenericWriteAheadSink
uses the
checkpoint stream factory to write write-ahead logs.
- createExecutionEnvironment() - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
-
Creates a StreamExecutionEnvironment from this factory.
- createInput(InputFormat<OUT, ?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat
.
- createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat
.
- createInputGate(Collection<InputGate>, Collection<InputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInputGate(InputGate[]) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInstance() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- createIterationSourceAndSink(int, int, int, long, int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- createJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- createKeyedStateBackend(TypeSerializer<K>, int, KeyGroupRange) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createLocalEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironment(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironment(int, Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createOperatorStateBackend(StreamOperator<?>, Collection<OperatorStateHandle>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
-
Deprecated.
- createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
-
Deprecated.
- createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createResource() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Creates/opens/connects to the resource that is used to store information.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current processing time.
- currentWatermark() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current event-time watermark.
- CustomPartitionerWrapper<K,T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that selects the channel with a user defined partitioner function on a key.
- CustomPartitionerWrapper(Partitioner<K>, KeySelector<T, K>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- failOperator(Throwable) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- failOperator(Throwable) - Method in interface org.apache.flink.streaming.api.operators.async.OperatorActions
-
Fail the respective stream operator with the given throwable.
- FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- FeedbackTransformation(StreamTransformation<T>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Creates a new FeedbackTransformation
from the given input.
- FieldAccessor<T,F> - Class in org.apache.flink.streaming.util.typeutils
-
These classes encapsulate the logic of accessing a field specified by the user as either an index
or a field expression string.
- FieldAccessor() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
- FieldAccessorFactory - Class in org.apache.flink.streaming.util.typeutils
-
- FieldAccessorFactory() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
- FieldFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of an array.
- FieldFromArray() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the first field (id 0) from the array
- FieldFromArray(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the field with the given id from the array.
- FieldFromTuple<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of a tuple.
- FieldFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the first field (id 0) from the tuple
- FieldFromTuple(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the field with the given id from the tuple.
- FieldsFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts multiple fields from an array and puts them into a new array of the
specified type.
- FieldsFromArray(Class<OUT>, int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
-
Extracts multiple fields from an array and puts them in the given order
into a new array of the specified type.
- FieldsFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts one or more fields of the type Double from a tuple and puts them
into a new double[]
- FieldsFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
-
Extracts one or more fields of the the type Double from a tuple and puts
them into a new double[] (in the specified order).
- fieldType - Variable in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
- FileMonitoringFunction - Class in org.apache.flink.streaming.api.functions.source
-
Deprecated.
- FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - Constructor for class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source
-
Deprecated.
- FileProcessingMode - Enum in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
-
Deprecated.
- FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
Deprecated.
- filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The finalize method shuts down the timer.
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- flatMap(CoFlatMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreams
and
maps the output to a common type.
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- flatMap(Tuple3<String, Long, Long>, Collector<String>) - Method in class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
Deprecated.
- flatMap1(IN1, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the first of the connected streams.
- flatMap2(IN2, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the second of the connected streams.
- flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- flushOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method should be called before finishing the record emission, to make sure any data
that is still buffered will be sent.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given fold function to each window.
- fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given fold function to each window.
- fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies a fold transformation on the grouped data stream grouped on by
the given key position.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given fold function to each window.
- fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given fold function to each window.
- fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- FoldApplyAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- FoldApplyWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- forceNonParallel() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism and maximum parallelism of this operator to one.
- format - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- forward() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are forwarded to the local subtask of the next operation.
- ForwardPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that forwards elements only to the locally running downstream operation.
- ForwardPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- from(StreamRecord<T>) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- fromCollection(Collection<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given non-empty collection.
- fromCollection(Collection<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given non-empty collection.
- fromCollection(Iterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given iterator.
- fromCollection(Iterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given iterator.
- fromElements(OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromElements(Class<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data set that contains the given elements.
- FromElementsFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
A stream source function that returns a sequence of elements.
- FromElementsFunction(TypeSerializer<T>, T...) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- FromElementsFunction(TypeSerializer<T>, Iterable<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- FromIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
- FromIteratorFunction(Iterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- fromParallelCollection(SplittableIterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- fromParallelCollection(SplittableIterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
- FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- generate(StreamExecutionEnvironment, List<StreamTransformation<?>>) - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
Generates a StreamGraph
by traversing the graph of StreamTransformations
starting from the given transformations.
- generateSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains a sequence of numbers.
- GenericWriteAheadSink<IN> - Class in org.apache.flink.streaming.runtime.operators
-
Generic Sink that emits its input elements into an arbitrary backend.
- GenericWriteAheadSink(CheckpointCommitter, TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- get() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
-
Return the asynchronous result collection.
- get() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- get() - Static method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- get(K) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Looks up the value mapped under the given key.
- get(T) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the value of the field (specified in the constructor) of the given record.
- getAccessor(TypeInformation<T>, int, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessor
for the given field position, which can be used to get and set
the specified field on instances of this type.
- getAccessor(TypeInformation<T>, String, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessor
for the field that is given by a field expression,
which can be used to get and set the specified field on instances of this type.
- getAccumulatorMap() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getActiveTimerTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- getAlignmentDurationNanos() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Gets the time that the latest alignment took, in nanoseconds.
- getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getAsyncOperationsThreadPool() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBrokerID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum time frequency (milliseconds) for the flushing of the
output buffers.
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the buffer timeout of the job
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the buffer timeout of this StreamTransformation
.
- getBytesWritten() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Gets the number of bytes written in the current spill file.
- getCancelables() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainEntryPoint() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getChainIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getChainLength() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the checkpoint config, which defines values like checkpoint interval, delay between
checkpoints, etc.
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the checkpointing mode (exactly-once vs.
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing mode (exactly-once vs.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the interval in which checkpoints are periodically scheduled.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing interval or -1 if checkpointing is disabled.
- getCheckpointLock() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Returns the checkpoint lock.
- getCheckpointLock() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the lock object on which all operations that involve data and state mutation have to lock.
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the checkpointing mode
- getCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum time that a checkpoint may take before being discarded.
- getClientConfiguration() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config object.
- getConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getConfiguration() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getCurrentCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
Gets the ID defining the current pending, or just completed, checkpoint.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getCurrentKey() - Method in interface org.apache.flink.streaming.api.operators.KeyContext
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getCurrentTableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the current table capacity, i.e., the number of slots in the hash table, without
and overflow chaining.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
-
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.TimestampExtractor
-
Deprecated.
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getDefaultLocalParallelism() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns the default trigger associated with this WindowAssigner
.
- getDelta(DATA, DATA) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.DeltaFunction
-
Calculates the delta between two given data points.
- getDelta(DATA, DATA) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
This method takes the two data point and runs the set extractor on it.
- getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- getEnvironment() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getEventTimeTimersPerKeyGroup() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Gets the execution config defined on the execution environment of the job to which this
operator belongs.
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the
program is currently executed.
- getExecutionPlan() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates the plan with which the system will execute the program, and
returns it as a String using a JSON representation of the execution data
flow graph.
- getExternalizedCheckpointCleanup() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns the cleanup behaviour for externalized checkpoints.
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the list of feedback StreamTransformations
.
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the list of feedback StreamTransformations
.
- getFieldType() - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the TypeInformation for the type of the field.
- getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getForAggregation(AggregationFunction.AggregationType) - Static method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- getForClass(Class<?>) - Static method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- getFormat() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
Returns the InputFormat
.
- getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
-
- getGlobalModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- getHeadOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getHost() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the hostname of the master (JobManager), where the
program will be executed.
- getId() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getId() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the unique ID of this StreamTransformation
.
- getInEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInPhysicalEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getInput() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the input StreamTransformation
of this FeedbackTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the input StreamTransformation
of this OneInputTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the input StreamTransformation
of this SinkTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Returns the input StreamTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the input StreamTransformation
of this SinkTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Returns the input StreamTransformation
.
- getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input StreamTransformation
of this TwoInputTransformation
.
- getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input StreamTransformation
of this TwoInputTransformation
.
- getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
Returns the list of input StreamTransformations
.
- getInputSplitProvider() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the input split provider associated with the operator.
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getInputType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the TypeInformation
for the elements of the input.
- getInputType1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- getInputType2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- getInternalTimerService(String, TypeSerializer<N>, Triggerable<?, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a
InternalTimerService
that can be used to query current processing time
and event time and to set timers.
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- getIterationId() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getIterationSourceSinkPairs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getIterationWaitTime() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobVertexClass() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- getKey() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- getKey() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector
-
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getKeyedStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- getKeyedStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getKeySelector() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the key selector that can get the key by which the stream if partitioned from the elements.
- getKeySelector() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getKeySerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the key serializer for the queryable state instance.
- getKeyType() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the type of the key by which the stream is partitioned.
- getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Deprecated.
- getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Deprecated.
- getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getLegacyOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- getLength() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getLocalKeyGroupRangeStartIdx() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getManagedKeyedState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- getManagedOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- getMarkedTime() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
Returns the timestamp marked by the LatencyMarker
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum number of checkpoint attempts that may be in progress at the same time.
- getMaxOutOfOrdernessInMillis() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- getMaxParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum degree of parallelism defined for the program.
- getMaxParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Gets the maximum parallelism for this stream transformation.
- getMaxParallelism() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- getMergingWindowSet() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the metric group for this
Evictor
.
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the metric group for this
Trigger
.
- getMetricGroup() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the minimal pause between checkpointing attempts.
- getModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- getName() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the name of the current data stream.
- getName() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the name of this StreamTransformation
.
- getName() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the name of the task, in the form "taskname (2/5)".
- getNamespace() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
-
- getNestedDelta(TO, TO) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
- getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- getNewNodeId() - Static method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- getNext() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Gets the next BufferOrEvent from the spilled sequence, or null
, if the
sequence is exhausted.
- getNextEvaluationTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- getNextNonBlocked() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
- getNextSlideTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- getNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumActiveTimers() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getNumberOfInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumElements() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements produced in total by this function.
- getNumElementsEmitted() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements emitted so far.
- getNumPanes() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- getNumPanesPerWindow() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getOperator() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the TwoInputStreamOperator
of this Transformation.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the
StreamSink
that is the operator of this
SinkTransformation
.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Returns the StreamSource
, the operator of this SourceTransformation
.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TwoInputStreamOperator
of this Transformation.
- getOperatorChainIndex() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Return the operator name.
- getOperators() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- getOperatorStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- getOriginalCause() - Method in exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
-
- getOutEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdgesInOrder(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutputSelector() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Returns the OutputSelector
- getOutputSelectors(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutputSelectors() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutputType() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- getPaneSize() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- getParallelism() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the parallelism for this operator.
- getParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the parallelism of this StreamTransformation
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Retrieves a
State
object that can be used to interact with
fault-tolerant state that is scoped to the window and key of the current
trigger invocation.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the StreamPartitioner
that must be used for partitioning the elements
of the input StreamTransformation
.
- getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the port of the master (JobManager), where the
program will be executed.
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns the
ProcessingTimeService
responsible for getting the current
processing time and registering timers.
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getProcessingTimeService() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Returns the
ProcessingTimeService
responsible for telling the current
processing time and registering timers.
- getProcessingTimeTimersPerKeyGroup() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- getProducedType() - Method in class org.apache.flink.streaming.api.functions.source.ConnectorSource
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
- getQueryableStateName() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the name under which the state can be queried.
- getRawKeyedState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- getRawOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getRehashThreshold() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getRestartStrategy() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the specified restart strategy configuration.
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a context that allows the operator to query information about the execution and also
to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getSelectedNames() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSelectedNames() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Returns the names of the split streams that this SelectTransformation
selects.
- getSelectorForArray(int[], TypeInformation<X>) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelectorForKeys(Keys<X>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelectorForOneKey(Keys<X>, Partitioner<K>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSerializedStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the length of this policy's time interval.
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
-
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSlotSharingGroup(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Determines the slot sharing group of an operation across virtual nodes.
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the slot sharing group of this transformation.
- getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, Output<StreamRecord<OUT>>, long) - Static method in class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
- getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSourceVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the state backend that defines how to store and checkpoint state.
- getStateBackend(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation.
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Sink.
- getStateKeySelector1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the first input.
- getStateKeySelector2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the second input.
- getStateKeySerializer(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateKeySerializer() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getStatePartitioner(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStatePartitioner1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStatePartitioner2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Returns the state window for the given in-flight Window
.
- getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamElement() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getStreamingPlanAsJSON() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNode(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNodes() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamOperator(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStreamOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getStreamRecord() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getStreamTimeCharacteristic() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the time characteristic.
- getSubtaskIndex() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTargetVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTimestamp() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
Returns the timestamp associated with this
Watermark
in milliseconds.
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the timestamp associated with this stream value in milliseconds.
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Returns the transformation that contains the actual sink operator of this sink.
- getTransformationUID() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns all transitive predecessor StreamTransformation
s of this StreamTransformation
.
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getType() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the type of the stream.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the first input
- getType2() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the second input
- getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getUid() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the user-specified ID of this transformation.
- getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the time unit for this policy's time interval.
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Gets the user function executed in this operator.
- getUserFunctionParameters() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Since the streaming API does not implement any parametrization of functions via a
configuration, the config returned here is actually empty.
- getUserHash() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getUserProvidedNodeHash() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Gets the user provided hash.
- getValue() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.LatencyGauge
-
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the value wrapped in this stream value.
- getValueSerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the value serializer for the queryable state instance.
- getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getVertexID() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- getVertexIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the wait time.
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the wait time.
- getWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncWatermarkResult
-
Get the resulting watermark.
- getWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
-
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a
TypeSerializer
for serializing windows that are assigned by
this
WindowAssigner
.
- getWindowSize() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- getWindowSize() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- getWindowSlide() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- getWindowStartWithOffset(long, long, long) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Method to get the window start for a timestamp.
- global() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output values
all go to the first instance of the next processing operator.
- GlobalPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that sends all elements to the downstream operator with subtask ID=0;
- GlobalPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
- GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
- GlobalWindow.Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- GlobalWindows.NeverTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
-
A trigger that never fires, as default Trigger for GlobalWindows.
- GlobalWindows.NeverTrigger() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- id - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- idCounter - Static variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- IngestionTimeExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
A timestamp assigner that assigns timestamps based on the machine's wall clock.
- IngestionTimeExtractor() - Constructor for class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- initializeState(FunctionInitializationContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when the parallel function instance is created during distributed
execution.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- initializeState(OperatorStateHandles) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state which can be restored need to override this hook method.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- initializeState(OperatorStateHandles) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Provides state handles to restore the operator state.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- InputFormatSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- InputFormatSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- InputGateUtil - Class in org.apache.flink.streaming.runtime.io
-
Utility for dealing with input gates.
- inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
-
Singleton instance
- InternalIterableAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- InternalTimer<K,N> - Class in org.apache.flink.streaming.api.operators
-
Internal class for keeping track of in-flight timers.
- InternalTimer(long, K, N) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimer
-
- InternalTimer.TimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
-
- InternalTimerService<N> - Interface in org.apache.flink.streaming.api.operators
-
Interface for working with time and timers.
- internalTimerService - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- InternalWindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal interface for functions that are evaluated over keyed (grouped) windows.
- intersects(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns true
if this window intersects the given window.
- invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.DiscardingSink
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
-
- invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
Function for standard sink behaviour.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Called when new data arrives to the sink, and forwards it to Socket.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Implementation of the invoke method of the SinkFunction class.
- invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isCanceled() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Checks whether the source has been canceled or stopped.
- isChainable(StreamEdge, StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- isChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isChainingEnabled - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether operator chaining is enabled.
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Checked the resource whether the given checkpoint was committed completely.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether checkpointing is enabled.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns true if checkpointing is enabled for the running job.
- isCleanupTime(W, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns true
if the given time is the cleanup time for the given window.
- isDone() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
True if the stream element queue entry has been completed; otherwise false.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- isEmpty() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
True if the queue is empty; otherwise false.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- isEmpty() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Checks if the barrier handler has buffered any data internally.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Checks whether the map is empty.
- isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
-
Method to decide whether the element signals the end of the stream.
- isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
-
Method to decide whether the element signals the end of the stream.
- isEndOfStream(String) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
This schema never considers an element to signal end-of-stream, so this method returns always false.
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns true
if elements are assigned to windows based on event time,
false
otherwise.
- isExternalizedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether checkpoints should be persisted externally.
- isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- isFastAccumulating() - Method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
-
- isFastAggregating() - Method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
-
- isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Deprecated.
This will be removed once iterations properly participate in checkpointing.
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isLate(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns true
if the watermark is after the end timestamp plus the allowed lateness
of the given window.
- isLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isPurge() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
True fi the async result is a collection of output elements; otherwise false.
- isResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Returns true if the service has been shut down, false otherwise.
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
True if the async result is a
Watermark
; otherwise false.
- isWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark.
- iterate() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterate(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterationIdCounter - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- IterativeStream<T> - Class in org.apache.flink.streaming.api.datastream
-
The iterative data stream represents the start of an iteration in a
DataStream
.
- IterativeStream(DataStream<T>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream
-
- IterativeStream.ConnectedIterativeStreams<I,F> - Class in org.apache.flink.streaming.api.datastream
-
- IterativeStream.ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
- iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates an iterator over the entries of this map.
- map(CoMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoMap transformation on a
ConnectedStreams
and maps
the output to a common type.
- map(MapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- map1(IN1) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
-
This method is called for each element in the first of the connected streams.
- map2(IN2) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
-
This method is called for each element in the second of the connected streams.
- markCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Marks this source as canceled or stopped.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum value of every window of
the data stream at the given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the maximum value of the pojo data
stream at the given field expression for every window.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the data stream
at the given position by the given key.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the
data stream at the given field expression by the given key.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum value of every window of
the data stream at the given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the maximum value of the pojo data
stream at the given field expression for every window.
- MAX_WATERMARK - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
-
The watermark that signifies end-of-event-time
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the maximum element of the pojo
data stream by the given field expression for every window.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum element of the
data stream by the given field expression by the given key.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the
maximum value at the given position by the given key.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the
maximum value at the given position by the given key.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the
maximum value at the given position by the given key.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the maximum element of the pojo
data stream by the given field expression for every window.
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
-
- merge(Collection<W>, W) - Method in interface org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner.MergeCallback
-
Specifies that the given windows should be merged into the result window.
- merge(W, Collection<W>, W, Collection<W>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet.MergeFunction
-
This gets called when a merge occurs.
- mergedWindows - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- mergePartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.OnMergeContext
-
- mergePartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- mergeWindows(Collection<W>, MergingWindowAssigner.MergeCallback<W>) - Method in class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
-
Determines which windows (if any) should be merged.
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- MergingWindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A WindowAssigner
that can merge windows.
- MergingWindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
-
- MergingWindowAssigner.MergeCallback<W> - Interface in org.apache.flink.streaming.api.windowing.assigners
-
- mergingWindowsDescriptor - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- MergingWindowSet<W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- MergingWindowSet(MergingWindowAssigner<?, W>, ListState<Tuple2<W, W>>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
- MergingWindowSet.MergeFunction<W> - Interface in org.apache.flink.streaming.runtime.operators.windowing
-
- MessageAcknowledgingSourceBase<Type,UId> - Class in org.apache.flink.streaming.api.functions.source
-
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
- MessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Metric group for the operator
- milliseconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of milliseconds.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the minimum value of every window
of the data stream at the given position.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the minimum value of the pojo data
stream at the given field expression for every window.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum of the data
stream at the given position by the given key.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum of the
data stream at the given field expression by the given key.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum value of every window
of the data stream at the given position.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum value of the pojo data
stream at the given field expression for every window.
- MIN_MONITORING_INTERVAL - Static variable in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
The minimum interval allowed between consecutive path scans.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the minimum element of the pojo
data stream by the given field expression for every window.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum element of the
data stream by the given field expression by the given key.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the
minimum value at the given position by the given key.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the
minimum value at the given position by the given key.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the
minimum value at the given position by the given key.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum element of the pojo
data stream by the given field expression for every window.
- minutes(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of minutes.
- MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId> - Class in org.apache.flink.streaming.api.functions.source
-
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
- MultipleIdsMessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MultipleIdsMessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
-
Creates a new
SlidingAlignedProcessingTimeWindows
WindowAssigner
that assigns
elements to sliding time windows based on the element timestamp.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
Creates a new
SlidingEventTimeWindows
WindowAssigner
that assigns
elements to sliding time windows based on the element timestamp.
- of(Time, Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
Creates a new
SlidingEventTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp and offset.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
Creates a new
SlidingProcessingTimeWindows
WindowAssigner
that assigns
elements to sliding time windows based on the element timestamp.
- of(Time, Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
Creates a new
SlidingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp and offset.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingTimeWindows
-
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingAlignedProcessingTimeWindows
-
Creates a new
TumblingAlignedProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp and offset.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp.
- of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindows
WindowAssigner
that assigns
elements to time windows based on the element timestamp and offset.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingTimeWindows
-
- of(long) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
Creates a CountEvictor
that keeps the given number of elements.
- of(long, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
Creates a CountEvictor
that keeps the given number of elements in the pane
Eviction is done before/after the window function based on the value of doEvictAfter.
- of(double, DeltaFunction<T>) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
Creates a DeltaEvictor
from the given threshold and DeltaFunction
.
- of(double, DeltaFunction<T>, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
Creates a DeltaEvictor
from the given threshold, DeltaFunction
.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
Creates a TimeEvictor
that keeps the given number of elements.
- of(Time, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
Creates a TimeEvictor
that keeps the given number of elements.
- of(long, TimeUnit) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
Creates a trigger that continuously fires based on the given interval.
- of(Time) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
Creates a trigger that continuously fires based on the given interval.
- of(long) - Static method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
Creates a trigger that fires once the number of elements in a pane reaches the given count.
- of(double, DeltaFunction<T>, TypeSerializer<T>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
Creates a delta trigger from the given threshold and DeltaFunction
.
- of(Trigger<T, W>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
Creates a new purging trigger from the given Trigger
.
- onComplete(AcceptFunction<StreamElementQueueEntry<T>>, Executor) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
Register the given complete function to be called once this queue entry has been completed.
- onCompleteHandler(StreamElementQueueEntry<?>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
Callback for onComplete events for the given stream element queue entry.
- one(T1) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- OneInputStreamOperator<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with one input.
- OneInputStreamTask<IN,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- OneInputStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- OneInputTransformation<IN,OUT> - Class in org.apache.flink.streaming.api.transformations
-
- OneInputTransformation(StreamTransformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Creates a new OneInputTransformation
from the given input and operator.
- onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called for every element that gets added to a pane.
- onElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- onEventTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
-
Invoked when an event-time timer fires.
- onEventTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when an event-time timer that was set using the trigger context fires.
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- onEventTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- onMerge(GlobalWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when several windows have been merged into one window by the
WindowAssigner
.
- onMerge(Collection<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- onProcessingTime(long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- onProcessingTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
-
Invoked when a processing-time timer fires.
- onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when a processing-time timer that was set using the trigger context fires.
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- onProcessingTime(long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeCallback
-
This method is invoked with the timestamp for which the trigger was scheduled.
- onTimer(long, CoProcessFunction.OnTimerContext, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
- onTimer(long, ProcessFunction.OnTimerContext, Collector<O>) - Method in interface org.apache.flink.streaming.api.functions.ProcessFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Initialize the connection with the Socket in the server.
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- open() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- open() - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- open() - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
- open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduce
-
- open() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic.
- open() - Method in class org.apache.flink.streaming.api.operators.StreamProject
-
- open() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Initializes the sequence for reading.
- open() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Opens/connects to the resource, and possibly creates it beforehand.
- open() - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- open() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- open() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- OperatorActions - Interface in org.apache.flink.streaming.api.operators.async
-
- OperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
The
OperatorChain
contains all operators that are executed as one chain within a single
StreamTask
.
- OperatorChain(StreamTask<OUT, OP>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- operatorId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
- OperatorSnapshotResult - Class in org.apache.flink.streaming.api.operators
-
- OperatorSnapshotResult() - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- OperatorSnapshotResult(RunnableFuture<KeyGroupsStateHandle>, RunnableFuture<KeyGroupsStateHandle>, RunnableFuture<OperatorStateHandle>, RunnableFuture<OperatorStateHandle>) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- OperatorStateHandles - Class in org.apache.flink.streaming.runtime.tasks
-
This class holds all state handles for one operator.
- OperatorStateHandles(int, StreamStateHandle, Collection<KeyGroupsStateHandle>, Collection<KeyGroupsStateHandle>, Collection<OperatorStateHandle>, Collection<OperatorStateHandle>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- OperatorStateHandles(TaskStateHandles, int) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
-
- OrderedStreamElementQueue - Class in org.apache.flink.streaming.api.operators.async.queue
-
- OrderedStreamElementQueue(int, Executor, OperatorActions) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Add an AsyncWaitOperator.
- orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
Add an AsyncWaitOperator.
- org.apache.flink.migration.streaming.api.graph - package org.apache.flink.migration.streaming.api.graph
-
- org.apache.flink.streaming.api - package org.apache.flink.streaming.api
-
- org.apache.flink.streaming.api.checkpoint - package org.apache.flink.streaming.api.checkpoint
-
- org.apache.flink.streaming.api.collector.selector - package org.apache.flink.streaming.api.collector.selector
-
- org.apache.flink.streaming.api.datastream - package org.apache.flink.streaming.api.datastream
-
- org.apache.flink.streaming.api.environment - package org.apache.flink.streaming.api.environment
-
- org.apache.flink.streaming.api.functions - package org.apache.flink.streaming.api.functions
-
- org.apache.flink.streaming.api.functions.aggregation - package org.apache.flink.streaming.api.functions.aggregation
-
- org.apache.flink.streaming.api.functions.async - package org.apache.flink.streaming.api.functions.async
-
- org.apache.flink.streaming.api.functions.async.collector - package org.apache.flink.streaming.api.functions.async.collector
-
- org.apache.flink.streaming.api.functions.co - package org.apache.flink.streaming.api.functions.co
-
- org.apache.flink.streaming.api.functions.query - package org.apache.flink.streaming.api.functions.query
-
- org.apache.flink.streaming.api.functions.sink - package org.apache.flink.streaming.api.functions.sink
-
- org.apache.flink.streaming.api.functions.source - package org.apache.flink.streaming.api.functions.source
-
- org.apache.flink.streaming.api.functions.timestamps - package org.apache.flink.streaming.api.functions.timestamps
-
- org.apache.flink.streaming.api.functions.util - package org.apache.flink.streaming.api.functions.util
-
- org.apache.flink.streaming.api.functions.windowing - package org.apache.flink.streaming.api.functions.windowing
-
- org.apache.flink.streaming.api.functions.windowing.delta - package org.apache.flink.streaming.api.functions.windowing.delta
-
- org.apache.flink.streaming.api.functions.windowing.delta.extractor - package org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
- org.apache.flink.streaming.api.graph - package org.apache.flink.streaming.api.graph
-
- org.apache.flink.streaming.api.operators - package org.apache.flink.streaming.api.operators
-
- org.apache.flink.streaming.api.operators.async - package org.apache.flink.streaming.api.operators.async
-
- org.apache.flink.streaming.api.operators.async.queue - package org.apache.flink.streaming.api.operators.async.queue
-
- org.apache.flink.streaming.api.operators.co - package org.apache.flink.streaming.api.operators.co
-
- org.apache.flink.streaming.api.transformations - package org.apache.flink.streaming.api.transformations
-
- org.apache.flink.streaming.api.watermark - package org.apache.flink.streaming.api.watermark
-
- org.apache.flink.streaming.api.windowing.assigners - package org.apache.flink.streaming.api.windowing.assigners
-
- org.apache.flink.streaming.api.windowing.evictors - package org.apache.flink.streaming.api.windowing.evictors
-
- org.apache.flink.streaming.api.windowing.time - package org.apache.flink.streaming.api.windowing.time
-
- org.apache.flink.streaming.api.windowing.triggers - package org.apache.flink.streaming.api.windowing.triggers
-
- org.apache.flink.streaming.api.windowing.windows - package org.apache.flink.streaming.api.windowing.windows
-
- org.apache.flink.streaming.runtime.io - package org.apache.flink.streaming.runtime.io
-
- org.apache.flink.streaming.runtime.operators - package org.apache.flink.streaming.runtime.operators
-
This package contains the operators that perform the stream transformations.
- org.apache.flink.streaming.runtime.operators.windowing - package org.apache.flink.streaming.runtime.operators.windowing
-
This package contains the operators that implement the various window operations
on data streams.
- org.apache.flink.streaming.runtime.operators.windowing.functions - package org.apache.flink.streaming.runtime.operators.windowing.functions
-
- org.apache.flink.streaming.runtime.partitioner - package org.apache.flink.streaming.runtime.partitioner
-
- org.apache.flink.streaming.runtime.streamrecord - package org.apache.flink.streaming.runtime.streamrecord
-
- org.apache.flink.streaming.runtime.tasks - package org.apache.flink.streaming.runtime.tasks
-
This package contains classes that realize streaming tasks.
- org.apache.flink.streaming.util - package org.apache.flink.streaming.util
-
- org.apache.flink.streaming.util.keys - package org.apache.flink.streaming.util.keys
-
- org.apache.flink.streaming.util.serialization - package org.apache.flink.streaming.util.serialization
-
- org.apache.flink.streaming.util.typeutils - package org.apache.flink.streaming.util.typeutils
-
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- Output<T> - Interface in org.apache.flink.streaming.api.operators
-
A
StreamOperator
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.
- OutputFormatSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Simple implementation of the SinkFunction writing tuples in the specified
OutputFormat format.
- OutputFormatSinkFunction(OutputFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- outputMap - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- OutputSelector<OUT> - Interface in org.apache.flink.streaming.api.collector.selector
-
- outputSelectors - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- OutputSelectorWrapper<OUT> - Interface in org.apache.flink.streaming.api.collector.selector
-
- outputType - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- OutputTypeConfigurable<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Stream operators can implement this interface if they need access to the output type information
at
StreamGraph
generation.
- PACT - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- ParallelSourceFunction<OUT> - Interface in org.apache.flink.streaming.api.functions.source
-
A stream data source that is executed in parallel.
- partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a tuple DataStream on the specified key fields using a custom partitioner.
- partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a POJO DataStream on the specified key fields using a custom partitioner.
- partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
- PartitionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a change of partitioning of the input elements.
- PartitionTransformation(StreamTransformation<T>, StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- PassThroughAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- PassThroughAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- PassThroughWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- PassThroughWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- path - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- peekBlockingly() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- peekBlockingly() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Peek at the head of the queue and return the first completed
AsyncResult
.
- peekBlockingly() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- pendingCheckpoints - Variable in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
The list with IDs from checkpoints that were triggered, but not yet completed or notified of completion
- persist() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Persist the updated mapping to the given state if the mapping changed since
initialization.
- poll() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- poll() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Poll the first completed
AsyncResult
from the head of this queue.
- poll() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- PREDECESSORS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- previousPanes - Variable in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
The previous time panes, ordered by time (early to late)
- print() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stdout).
- PrintSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Implementation of the SinkFunction writing every tuple to the standard
output or standard error stream.
- PrintSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out.
- PrintSinkFunction(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out.
- printToErr() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stderr).
- process(CoProcessFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunction
on the connected input streams,
thereby creating a transformed output stream.
- process(CoProcessFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunction
on the connected input streams,
thereby creating a transformed output stream.
- process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
ProcessFunction
on the input stream, thereby
creating a transformed output stream.
- process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
ProcessFunction
on the input stream, thereby
creating a transformed output stream.
- processElement(I, ProcessFunction.Context, Collector<O>) - Method in interface org.apache.flink.streaming.api.functions.ProcessFunction
-
Process one element from the input stream.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
-
- processElement(StreamRecord<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- processElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
Processes one element that arrived at this operator.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFilter
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduce
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamMap
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamProject
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- processElement1(IN1, CoProcessFunction.Context, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the first of the connected streams.
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- processElement1(StreamRecord<IN1>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the first input of this two-input operator.
- processElement2(IN2, CoProcessFunction.Context, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the second of the connected streams.
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- processElement2(StreamRecord<IN2>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the second input of this two-input operator.
- ProcessFunction<I,O> - Interface in org.apache.flink.streaming.api.functions
-
A function that processes elements of a stream.
- ProcessFunction.Context - Interface in org.apache.flink.streaming.api.functions
-
- ProcessFunction.OnTimerContext - Interface in org.apache.flink.streaming.api.functions
-
- ProcessingTimeCallback - Interface in org.apache.flink.streaming.runtime.tasks
-
- ProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
Defines the current processing time and handles all related actions,
such as register timers for tasks to be executed in the future.
- ProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
- ProcessingTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the current processing
time.
- ProcessingTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- ProcessingTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the current system time passes the end of the window
to which a pane belongs.
- processInput(OneInputStreamOperator<IN, ?>, Object) - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- processInput(TwoInputStreamOperator<IN1, IN2, ?>, Object) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
- processLatencyMarker1(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker1(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarker
that arrived on the first input of this two-input operator.
- processLatencyMarker2(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker2(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarker
that arrived on the second input of this two-input operator.
- ProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- ProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
- processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark1(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermark
that arrived on the first input of this two-input operator.
- processWatermark2(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark2(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermark
that arrived on the second input of this two-input operator.
- project(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates a Project transformation on a
Tuple
DataStream
.
Note: Only Tuple DataStreams can be projected.
- projectTuple1() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple10() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple11() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple12() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple13() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple14() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple15() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple16() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple17() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple18() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple19() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple2() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple20() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple21() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple22() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple23() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple24() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple25() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple3() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple4() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple5() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple6() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple7() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple8() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple9() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTupleX() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- PurgingTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A trigger that can turn any
Trigger
into a purging
Trigger
.
- put(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- put(StreamElementQueueEntry<T>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Put the given element in the queue if capacity is left.
- put(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- put(K, V) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts the given value, mapped under the given key.
- putIfAbsent(K, KeyMap.LazyFactory<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts a value for the given key, if no value is yet contained for that key.
- putOrAggregate(K, V, ReduceFunction<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts or aggregates a value into the hash map.
- randomEmit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- readFile(FileInputFormat<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the contents of the user-specified
filePath
based on the given
FileInputFormat
.
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, FilePathFilter) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the contents of the user-specified
filePath
based on the given
FileInputFormat
.
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the contents of the user-specified
filePath
based on the given
FileInputFormat
.
- readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFromInput(DataInputView, TypeSerializer<Key>, TypeSerializer<Aggregate>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- readTextFile(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the given file line-by-line and creates a data stream that contains a string with the contents of each such
line.
- readTextFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the given file line-by-line and creates a data stream that contains a string with the contents of each such
line.
- rebalance() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are distributed evenly to instances of the next operation in a round-robin
fashion.
- RebalancePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output
channels.
- RebalancePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- RecordWriterOutput<OUT> - Class in org.apache.flink.streaming.runtime.io
-
- RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies a reduce transformation on the grouped data stream grouped on by
the given key position.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- ReduceIterableAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceIterableAllWindowFunction(ReduceFunction<T>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction
-
- ReduceIterableWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceIterableWindowFunction(ReduceFunction<T>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction
-
- registerCheckpointEventHandler(StatefulTask) - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- registerCheckpointEventHandler(StatefulTask) - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- registerCheckpointEventHandler(StatefulTask) - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Registers the task be notified once all checkpoint barriers have been received for a checkpoint.
- registerCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Registers a timer to cleanup the content of the window.
- registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- registerEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when the event time watermark passes the given time.
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register an event-time callback.
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- registerProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register a system time callback.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerRestoredLegacyStateState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed when (processing) time is timestamp
.
- registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
Registers a task to be executed no sooner than time timestamp
, but without strong guarantees of order
- registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- registerType(Class<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with the serialization stack.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given Serializer via its class as a serializer for the
given type at the KryoSerializer
- releaseOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method releases all resources of the record writer output.
- RemoteStreamEnvironment - Class in org.apache.flink.streaming.api.environment
-
- RemoteStreamEnvironment(String, int, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- replace(X) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value.
- replace(X, long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value and the currently stored
timestamp with the new timestamp.
- reportLatency(LatencyMarker, boolean) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.LatencyGauge
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- reregisterStateFromLegacyAlignedWindowOperator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- reregisterStateFromLegacyWindowOperator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- rescale() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are distributed evenly to a subset of instances of the next operation in a round-robin
fashion.
- RescalePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output
channels.
- RescalePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- resetContextEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Statements to be executed after writing a batch goes here.
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
- resetSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Sets the state of the split to null
.
- restoreFunctionState(StateInitializationContext, Function) - Static method in class org.apache.flink.streaming.api.functions.util.StreamingFunctionUtils
-
- restoreState(T) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedRestoring
-
Deprecated.
Restores the state of the function or operator to that of a previous checkpoint.
- restoreState(List<T>) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Restores the state of the function or operator to that of a previous checkpoint.
- restoreState(Long) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- restoreState(FSDataInputStream) - Method in interface org.apache.flink.streaming.api.operators.CheckpointedRestoringOperator
-
Deprecated.
Restores the operator state, if this operator's execution is recovering from a checkpoint.
- restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- restoreTimersForKeyGroup(DataInputViewStreamWrapper, int, ClassLoader) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
Restore the timers (both processing and event time ones) for a given keyGroupIdx
.
- retireWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Removes the given window from the set of in-flight windows.
- returns(Class<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeHint<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
-
- RichAsyncFunction<IN,OUT> - Class in org.apache.flink.streaming.api.functions.async
-
- RichAsyncFunction() - Constructor for class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- RichCoFlatMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoFlatMapFunction represents a FlatMap transformation with two different input
types.
- RichCoFlatMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction
-
- RichCoMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoMapFunction represents a Map transformation with two different input
types.
- RichCoMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoMapFunction
-
- RichCoProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
- RichCoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoProcessFunction
-
- RichParallelSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
Base class for implementing a parallel data source.
- RichParallelSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction
-
- RichProcessFunction<I,O> - Class in org.apache.flink.streaming.api.functions
-
- RichProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.RichProcessFunction
-
- RichSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- RichSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
-
- RichSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- RichSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichSourceFunction
-
- RichWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
-
- rollOver() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Starts a new sequence of spilled buffers and event and returns the current sequence of spilled buffers
for reading.
- rollOverWithNewBuffer() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Starts a new sequence of spilled buffers and event and returns the current sequence of spilled buffers
for reading.
- run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- run(SourceFunction.SourceContext<T>) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
-
Starts the source.
- run(SourceFunction.SourceContext<Long>) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- run() - Method in class org.apache.flink.streaming.api.operators.async.Emitter
-
- run(Object) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run(Object, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed repeatedly at a fixed rate.
- scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- schema - Variable in class org.apache.flink.streaming.api.functions.source.ConnectorSource
-
- seconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of seconds.
- select(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelector
-
- select(String...) - Method in class org.apache.flink.streaming.api.datastream.SplitStream
-
Sets the output names for which the next operator will receive values.
- selectAllOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- selectOutputs(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- SelectTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a selection of only certain upstream elements.
- SelectTransformation(StreamTransformation<T>, List<String>) - Constructor for class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Creates a new SelectionTransformation
from the given input that only selects
the streams with the selected names.
- sendOutputs(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelectorWrapper
-
- sendValues(Iterable<IN>, long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
Write the given element into the backend.
- SerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
-
The serialization schema describes how to turn a data object into a different serialized
representation.
- serialize(InternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- serialize(GlobalWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- serialize(TimeWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- serialize(StreamElement, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- serialize(T) - Method in interface org.apache.flink.streaming.util.serialization.SerializationSchema
-
Serializes the incoming element to a specified type.
- serialize(String) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- serialize(T) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
- serializer - Variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- sessionIds - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionIdsPerSnapshot - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- set(T, F) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Sets the field (specified in the constructor) of the given record to the given value.
- setAbsoluteTimestamp(long) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the maximum time frequency (ms) for the flushing of the output
buffer.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum time frequency (milliseconds) for the flushing of the
output buffers.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setBufferTimeout(Integer, long) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setBufferTimeout(Long) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Set the buffer timeout of this StreamTransformation
.
- setChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChainIndex(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the chaining strategy of this StreamTransformation
.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- setChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointingEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointingMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the checkpointing mode (exactly-once vs.
- setCheckpointInterval(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the interval in which checkpoints are periodically scheduled.
- setCheckpointMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum time that a checkpoint may take before being discarded.
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Internal function for setting the partitioner for the DataStream
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setCurrentKey(Object) - Method in interface org.apache.flink.streaming.api.operators.KeyContext
-
- setCurrentTime(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setForceCheckpointing(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Deprecated.
This will be removed once iterations properly participate in checkpointing.
- setInitialState(TaskStateHandles) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setInputFormat(Integer, InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setInputFormat(InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setJobId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the job ID after instantiation.
- setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement1(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyedStateManagedFuture(RunnableFuture<KeyGroupsStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- setKeyedStateRawFuture(RunnableFuture<KeyGroupsStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum number of checkpoint attempts that may be in progress at the same time.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the maximum parallelism of this operator.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum degree of parallelism defined for the program.
- setMaxParallelism(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the maximum parallelism for this stream transformation.
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
Sets the metric group for this StreamInputProcessor.
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
Sets the metric group for this StreamTwoInputProcessor.
- setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the minimal pause between checkpointing attempts.
- setName(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Changes the name of this StreamTransformation
.
- setNonChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setNumberOfInputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNumberOfOutputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOneInputStateKey(Integer, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOperator(Integer, StreamOperator<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setOperatorId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the operator ID after instantiation.
- setOperatorName(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOperatorStateManagedFuture(RunnableFuture<OperatorStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- setOperatorStateRawFuture(RunnableFuture<OperatorStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
-
- setOutEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutEdgesInOrder(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutputSelectors(List<OutputSelector<?>>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- setOutputType(Function, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.api.functions.util.StreamingFunctionUtils
-
- setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.OutputTypeConfigurable
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
- setOutputType(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Tries to fill in the type information.
- setOutType(Integer, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the parallelism for this sink.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSource
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism for this operator.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the parallelism for operations executed through this environment.
- setParallelism(Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setParallelism(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the parallelism of this StreamTransformation
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the restart strategy configuration.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- setSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSerializersFrom(Integer, Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the slot sharing group of this transformation.
- setSplitState(Serializable) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Sets the state of the split.
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the state backend that describes how to store and checkpoint operator state.
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setStateKeySelector(KeySelector<IN, ?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Sets the
KeySelector
that must be used for partitioning keyed state of this operation.
- setStateKeySelector(KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Sets the
KeySelector
that must be used for partitioning keyed state of this Sink.
- setStateKeySelectors(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Sets the
KeySelectors
that must be used for partitioning keyed state of
this transformation.
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setStatePartitioner(int, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStatePartitioner1(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStatePartitioner2(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStreamTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the time characteristic for all streams create from this environment, e.g., processing
time, event time, or ingestion time.
- setTargetToStandardErr() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- setTargetToStandardOut() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setTypeSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setUid(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets an user provided hash for this operator.
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Initializes the operator.
- setUserHash(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setVertexID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- SHIP_STRATEGY - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- shuffle() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are shuffled uniformly randomly to the next operation.
- ShufflePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by selecting one output channel
randomly.
- ShufflePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Shuts down and clean up the timer service provider hard and immediately.
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- SimpleStringSchema - Class in org.apache.flink.streaming.util.serialization
-
Very simple serialization schema for strings.
- SimpleStringSchema() - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- SimpleTimerService - Class in org.apache.flink.streaming.api
-
- SimpleTimerService(InternalTimerService<VoidNamespace>) - Constructor for class org.apache.flink.streaming.api.SimpleTimerService
-
- SingleOutputStreamOperator<T> - Class in org.apache.flink.streaming.api.datastream
-
SingleOutputStreamOperator
represents a user defined transformation
applied on a
DataStream
with one predefined output type.
- SingleOutputStreamOperator(StreamExecutionEnvironment, StreamTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink
-
Interface for implementing user defined sink functionality.
- SinkTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents a Sink.
- SinkTransformation(StreamTransformation<T>, String, StreamSink<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Creates a new SinkTransformation
from the given input StreamTransformation
.
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- size() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Return the size of the queue.
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- size() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Gets the size of this spilled sequence.
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the number of elements currently in the map.
- slidePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- SlidingAlignedProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
This is a special window assigner used to tell the system to use the
"Fast Aligned Processing Time Window Operator" for windowing.
- SlidingAlignedProcessingTimeWindows(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
-
- SlidingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the timestamp of the
elements.
- SlidingEventTimeWindows(long, long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- SlidingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the current
system time of the machine the operation is running on.
- SlidingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - Static method in class org.apache.flink.streaming.api.functions.util.StreamingFunctionUtils
-
- snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.Checkpointed
-
Deprecated.
Gets the current state of the function of operator.
- snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when a snapshot for a checkpoint is requested.
- snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Gets the current state of the function.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- snapshotState(long, long, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state, which want to participate in a snapshot need to override this hook method.
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- snapshotState(FSDataOutputStream, long, long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- snapshotState(FSDataOutputStream, long, long) - Method in interface org.apache.flink.streaming.api.operators.StreamCheckpointedOperator
-
Deprecated.
Called to draw a state snapshot from the operator.
- snapshotState(long, long, CheckpointStreamFactory) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Called to draw a state snapshot from the operator.
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- snapshotState(FSDataOutputStream, long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- snapshotTimersForKeyGroup(DataOutputViewStreamWrapper, int) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
Snapshots the timers (both processing and event time ones) for a given keyGroupIdx
.
- SocketClientSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Socket client that acts as a streaming sink.
- SocketClientSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink.
- SocketClientSink(String, int, SerializationSchema<IN>, int) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- SocketClientSink(String, int, SerializationSchema<IN>, int, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- socketTextStream(String, int, String, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int, char) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- socketTextStream(String, int, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- SocketTextStreamFunction - Class in org.apache.flink.streaming.api.functions.source
-
A source function that reads strings from a socket.
- SocketTextStreamFunction(String, int, String, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SocketTextStreamFunction(String, int, String, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SourceFunction<T> - Interface in org.apache.flink.streaming.api.functions.source
-
Base interface for all stream data sources in Flink.
- SourceFunction.SourceContext<T> - Interface in org.apache.flink.streaming.api.functions.source
-
Interface that source functions use to emit elements, and possibly watermarks.
- SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
-
Task for executing streaming sources.
- SourceStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- SourceTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a Source.
- SourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Creates a new SourceTransformation
from the given operator.
- split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Operator used for directing tuples to specific named outputs using an
OutputSelector
.
- SplitStream<OUT> - Class in org.apache.flink.streaming.api.datastream
-
The SplitStream represents an operator that has been split using an
OutputSelector
.
- SplitStream(DataStream<OUT>, OutputSelector<OUT>) - Constructor for class org.apache.flink.streaming.api.datastream.SplitStream
-
- SplitTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
- SplitTransformation(StreamTransformation<T>, OutputSelector<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Creates a new SplitTransformation
from the given input and OutputSelector
.
- startNewChain() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Starts a new task chain beginning at this operator.
- startNewKey(K) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called whenever the traversal starts with a new key.
- startTimerService(TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
Starts the local
HeapInternalTimerService
by:
Setting the
keySerialized
and
namespaceSerializer
for the timers it will contain.
Setting the
triggerTarget
which contains the action to be performed when a timer fires.
Re-registering timers that were retrieved after recoveting from a node failure, if any.
This method can be called multiple times, as long as it is called with the same serializers.
- StatefulSequenceSource - Class in org.apache.flink.streaming.api.functions.source
-
A stateful streaming source that emits each number from a given interval exactly once,
possibly in parallel.
- StatefulSequenceSource(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
Creates a source that emits all numbers from the given interval exactly once.
- STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- stop() - Method in class org.apache.flink.streaming.api.operators.async.Emitter
-
- stop() - Method in class org.apache.flink.streaming.api.operators.StoppableStreamSource
-
- stop() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.runtime.tasks
-
Stoppable task for executing stoppable streaming sources.
- StoppableSourceStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.api.operators
-
- StoppableStreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StoppableStreamSource
-
- StreamCheckpointedOperator - Interface in org.apache.flink.streaming.api.operators
-
Deprecated.
- StreamConfig - Class in org.apache.flink.streaming.api.graph
-
- StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
-
- StreamContextEnvironment - Class in org.apache.flink.streaming.api.environment
-
- StreamContextEnvironment(ContextEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamContextEnvironment
-
- StreamEdge - Class in org.apache.flink.streaming.api.graph
-
An edge in the streaming topology.
- StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
-
- StreamElement - Class in org.apache.flink.streaming.runtime.streamrecord
-
An element in a data stream.
- StreamElement() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
- StreamElementQueue - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- StreamElementQueueEntry<T> - Class in org.apache.flink.streaming.api.operators.async.queue
-
- StreamElementQueueEntry(StreamElement) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- StreamElementSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- StreamElementSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.environment
-
The StreamExecutionEnvironment is the context in which a streaming program is executed.
- StreamExecutionEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- StreamExecutionEnvironmentFactory - Interface in org.apache.flink.streaming.api.environment
-
Factory class for stream execution environments.
- StreamFilter<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamFilter(FilterFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFilter
-
- StreamFlatMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamFlatMap(FlatMapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- StreamGraph - Class in org.apache.flink.streaming.api.graph
-
Class representing the streaming topology.
- StreamGraph(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
-
- StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
- StreamGraphHasher - Interface in org.apache.flink.streaming.api.graph
-
Interface for different implementations of generating hashes over a stream graph.
- StreamGraphHasherV1 - Class in org.apache.flink.migration.streaming.api.graph
-
StreamGraphHasher from Flink 1.1.
- StreamGraphHasherV1() - Constructor for class org.apache.flink.migration.streaming.api.graph.StreamGraphHasherV1
-
- StreamGraphHasherV2 - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher from Flink 1.2.
- StreamGraphHasherV2() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
- StreamGraphUserHashHasher - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher that works with user provided hashes.
- StreamGraphUserHashHasher() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
-
- StreamGroupedFold<IN,OUT,KEY> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
- StreamGroupedReduce<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedReduce(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduce
-
- StreamingFunctionUtils - Class in org.apache.flink.streaming.api.functions.util
-
Utility class that contains helper methods to work with Flink Streaming
Functions
.
- StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
- StreamingJobGraphGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- StreamingReader - Interface in org.apache.flink.streaming.runtime.io
-
- StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
-
- StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- StreamInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
-
- StreamInputProcessor(InputGate[], TypeSerializer<IN>, StatefulTask, CheckpointingMode, IOManager, Configuration) - Constructor for class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- StreamIterationHead() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
- StreamIterationTail() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
-
- StreamNode - Class in org.apache.flink.streaming.api.graph
-
Class representing the operators in the streaming programs, with all their properties.
- StreamNode(StreamExecutionEnvironment, Integer, String, StreamOperator<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
-
- StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Basic interface for stream operators.
- StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
- StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- StreamPlanEnvironment - Class in org.apache.flink.streaming.api.environment
-
- StreamPlanEnvironment(ExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamPlanEnvironment
-
- StreamProject<IN,OUT extends Tuple> - Class in org.apache.flink.streaming.api.operators
-
- StreamProject(int[], TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamProject
-
- StreamProjection<IN> - Class in org.apache.flink.streaming.api.datastream
-
- StreamProjection(DataStream<IN>, int[]) - Constructor for class org.apache.flink.streaming.api.datastream.StreamProjection
-
- StreamRecord<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
One value in a data stream.
- StreamRecord(T) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord.
- StreamRecord(T, long) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord wrapping the given value.
- StreamRecordQueueEntry<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
-
- StreamRecordQueueEntry(StreamRecord<?>) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- StreamRecordWriter<T extends IOReadableWritable> - Class in org.apache.flink.streaming.runtime.io
-
This record writer keeps data in buffers at most for a certain timeout.
- StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long, String) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamSink(SinkFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSink
-
- StreamSource<OUT,SRC extends SourceFunction<OUT>> - Class in org.apache.flink.streaming.api.operators
-
- StreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
- StreamSourceContexts - Class in org.apache.flink.streaming.api.operators
-
Source contexts for various stream time characteristics.
- StreamSourceContexts() - Constructor for class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
- StreamTask<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
Base class for all streaming tasks.
- StreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- StreamTaskException - Exception in org.apache.flink.streaming.runtime.tasks
-
An exception that is thrown by the stream vertices when encountering an
illegal condition.
- StreamTaskException() - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with no message and no cause.
- StreamTaskException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and no cause.
- StreamTaskException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given cause and no message.
- StreamTaskException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and cause.
- StreamTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
A
StreamTransformation
represents the operation that creates a
DataStream
.
- StreamTransformation(String, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Creates a new StreamTransformation
with the given name, output type and parallelism.
- StreamTwoInputProcessor<IN1,IN2> - Class in org.apache.flink.streaming.runtime.io
-
- StreamTwoInputProcessor(Collection<InputGate>, Collection<InputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>, StatefulTask, CheckpointingMode, IOManager, Configuration) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the data stream at the
given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at
the given field for every window.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives a rolling sum of the data stream at the
given position grouped by the given key.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current sum of the data
stream at the given field by the given key.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the data stream at the
given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at
the given field for every window.
- SumAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumAggregator(int, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumAggregator(String, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumFunction - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- SumFunction.ByteSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.ByteSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ByteSum
-
- SumFunction.DoubleSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.DoubleSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.DoubleSum
-
- SumFunction.FloatSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.FloatSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.FloatSum
-
- SumFunction.IntSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.IntSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.IntSum
-
- SumFunction.LongSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.LongSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.LongSum
-
- SumFunction.ShortSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.ShortSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ShortSum
-
- SystemProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
- SystemProcessingTimeService(AsyncExceptionHandler, Object) - Constructor for class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- SystemProcessingTimeService(AsyncExceptionHandler, Object, ThreadFactory) - Constructor for class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- TestProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
- TestProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- Time - Class in org.apache.flink.streaming.api.windowing.time
-
The definition of a time interval for windowing.
- TimeCharacteristic - Enum in org.apache.flink.streaming.api
-
The time characteristic defines how the system determines time for time-dependent
order and operations that depend on time (such as time windows).
- timeDomain() - Method in interface org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
-
- timeDomain() - Method in interface org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
-
- TimeDomain - Enum in org.apache.flink.streaming.api
-
TimeDomain
specifies whether a firing timer is based on event time or processing time.
- TimeEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps elements for a certain amount of time.
- TimeEvictor(long) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- TimeEvictor(long, boolean) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- TimerException - Exception in org.apache.flink.streaming.runtime.tasks
-
RuntimeException
for wrapping exceptions that are thrown in the timer callback of
the timer service in
StreamTask
.
- TimerException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- timerService() - Method in interface org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
- timerService() - Method in interface org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
- TimerService - Interface in org.apache.flink.streaming.api
-
Interface for working with time and timers.
- timestamp() - Method in interface org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in interface org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- TimestampAssigner<T> - Interface in org.apache.flink.streaming.api.functions
-
A TimestampAssigner
assigns event time timestamps to elements.
- TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
-
- TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- timestampedCollector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
This is given to the InternalWindowFunction
for emitting elements with a given timestamp.
- TimestampedFileInputSplit - Class in org.apache.flink.streaming.api.functions.source
-
- TimestampedFileInputSplit(long, int, Path, long, long, String[]) - Constructor for class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- TimestampedValue<T> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Stores the value and the timestamp of the record.
- TimestampedValue(T) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue.
- TimestampedValue(T, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue wrapping the given value.
- TimestampExtractor<T> - Interface in org.apache.flink.streaming.api.functions
-
- TimestampsAndPeriodicWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
- TimestampsAndPeriodicWatermarksOperator(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- TimestampsAndPunctuatedWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that extracts timestamps from stream elements and
generates watermarks based on punctuation elements.
- TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
- timeWindow(Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling time windows.
- timeWindow(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding time windows.
- TimeWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
A
Window
that represents a time interval from
start
(inclusive) to
start + size
(exclusive).
- TimeWindow(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- TimeWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
- TimeWindow.Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- timeWindowAll(Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling time windows.
- timeWindowAll(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding time windows.
- toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Converts the time interval to milliseconds.
- toString() - Method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
-
- toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- toString() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- toString() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- toString() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- toString() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators along with the type
information that will transform the DataStream.
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
-
- transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- traverseAllPanes(KeyMap.TraversalEvaluator<Key, Aggregate>, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Performs a traversal about logical the multi-map that results from the union of the
given maps.
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.migration.streaming.api.graph.StreamGraphHasherV1
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in interface org.apache.flink.streaming.api.graph.StreamGraphHasher
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
-
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the Trigger
that should be used to trigger window emission.
- Trigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A Trigger
determines when a pane of a window should be evaluated to emit the
results for that part of the window.
- Trigger() - Constructor for class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
- trigger - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- Trigger.OnMergeContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
- Trigger.TriggerContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
A context object that is given to
Trigger
methods to allow them to register timer
callbacks and deal with state.
- TRIGGER_THREAD_GROUP - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The thread group that holds all trigger timer threads
- Triggerable<K,N> - Interface in org.apache.flink.streaming.api.operators
-
- triggerCheckpoint(CheckpointMetaData) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- triggerCheckpointOnBarrier(CheckpointMetaData) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
-
Result type for trigger methods.
- truncatePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- tryPut(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- tryPut(StreamElementQueueEntry<T>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Try to put the given element in the queue.
- tryPut(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- TumblingAlignedProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
This is a special window assigner used to tell the system to use the
"Fast Aligned Processing Time Window Operator" for windowing.
- TumblingAlignedProcessingTimeWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingAlignedProcessingTimeWindows
-
- TumblingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into windows based on the timestamp of the
elements.
- TumblingEventTimeWindows(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- TumblingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into windows based on the current
system time of the machine the operation is running on.
- TumblingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- tupleList - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- TwoInputStreamOperator<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with two inputs.
- TwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- TwoInputStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- TwoInputTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents the application of a
TwoInputStreamOperator
to two input
StreamTransformations
.
- TwoInputTransformation(StreamTransformation<IN1>, StreamTransformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new TwoInputTransformation
from the given inputs and operator.
- TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- TypeInformationSerializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
A serialization and deserialization schema that uses Flink's serialization stack to
transform typed from and to byte arrays.
- TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
Creates a new de-/serialization schema for the given type.
- typeUsed - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- values() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- values() - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- Watermark - Class in org.apache.flink.streaming.api.watermark
-
A Watermark tells operators that receive it that no elements with a timestamp older or equal
to the watermark timestamp should arrive at the operator.
- Watermark(long) - Constructor for class org.apache.flink.streaming.api.watermark.Watermark
-
Creates a new watermark with the given timestamp in milliseconds.
- WatermarkQueueEntry - Class in org.apache.flink.streaming.api.operators.async.queue
-
- WatermarkQueueEntry(Watermark) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
-
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Specifies a
KeySelector
for elements from the first input.
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Specifies a
KeySelector
for elements from the first input.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where.EqualTo
-
Specifies the window on which the co-group operation works.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where.EqualTo
-
Specifies the window on which the join operation works.
- window(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this data stream to a WindowedStream
, which evaluates windows
over a key grouped stream.
- Window - Class in org.apache.flink.streaming.api.windowing.windows
-
A Window
is a grouping of elements into finite buckets.
- Window() - Constructor for class org.apache.flink.streaming.api.windowing.windows.Window
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this data stream to a KeyedTriggerWindowDataStream
, which evaluates windows
over a key grouped stream.
- WindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
assigns zero or more
Windows
to an element.
- WindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
- windowAssigner - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- WindowAssigner.WindowAssignerContext - Class in org.apache.flink.streaming.api.windowing.assigners
-
A context provided to the
WindowAssigner
that allows it to query the
current processing time.
- WindowAssigner.WindowAssignerContext() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
-
- windowAssignerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- WindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
WindowedStream
represents a data stream where elements are grouped by
key, and for each key, the stream of elements is split into windows based on a
WindowAssigner
.
- WindowedStream(KeyedStream<T, K>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.WindowedStream
-
- WindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over keyed (grouped) windows.
- WindowOperator<K,IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Creates a new WindowOperator
based on the given policies and user functions.
- WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, LegacyWindowOperatorType) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Creates a new WindowOperator
based on the given policies and user functions.
- WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Context
is a utility for handling Trigger
invocations.
- WindowOperator.Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- WindowOperator.Timer<K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Internal class for keeping track of in-flight timers.
- WindowOperator.Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
For serializing the window in checkpoints.
- windowStateDescriptor - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- with(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- with(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- with(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- with(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- with(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- with(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
- withFeedbackType(String) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply
co-transformations on the input and feedback stream, as in a
ConnectedStreams
.
- withFeedbackType(Class<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply
co-transformations on the input and feedback stream, as in a
ConnectedStreams
.
- withFeedbackType(TypeInformation<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply
co-transformations on the input and feedback stream, as in a
ConnectedStreams
.
- withGap(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns
elements to sessions based on the element timestamp.
- withGap(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
Creates a new
SessionWindows
WindowAssigner
that assigns
elements to sessions based on the element timestamp.
- withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
Sets the handler for violations to the ascending timestamp order.
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormat
-
Writes the contents of tupleList to the file specified by path.
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
-
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
-
- writeAsCsv(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by the path parameter.
- writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by the path parameter.
- writeAsCsv(String, FileSystem.WriteMode, String, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by the path parameter.
- writeAsText(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by path in text format.
- writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by path in text format.
- WriteFormat<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Abstract class for formatting the output of the writeAsText and writeAsCsv
functions.
- WriteFormat() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormat
-
- WriteFormatAsCsv<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Writes tuples in csv format.
- WriteFormatAsCsv() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
-
- WriteFormatAsText<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Writes tuples in text format.
- WriteFormatAsText() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
-
- WriteSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Simple implementation of the SinkFunction writing tuples as simple text to
the file specified by path.
- WriteSinkFunction(String, WriteFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- WriteSinkFunctionByMillis<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Implementation of WriteSinkFunction.
- WriteSinkFunctionByMillis(String, WriteFormat<IN>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
- writeToOutput(DataOutputView, TypeSerializer<Key>, TypeSerializer<Aggregate>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- writeToSocket(String, int, SerializationSchema<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes the DataStream to a socket as a byte array.
- writeUsingOutputFormat(OutputFormat<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes the dataStream into an output, described by an OutputFormat.