Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y 

A

abort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Abort a transaction.
abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
abortCheckpointOnBarrier(long, Throwable, OperatorChain<?, ?>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
 
abortPendingCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
abortPendingCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
abortPendingCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
AbstractDataOutput<T> - Class in org.apache.flink.streaming.runtime.io
Base class for all data outputs.
AbstractDataOutput(StreamStatusMaintainer) - Constructor for class org.apache.flink.streaming.runtime.io.AbstractDataOutput
 
AbstractDeserializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
Deprecated.
Use AbstractDeserializationSchema instead.
AbstractDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
Deprecated.
 
AbstractInput<IN,OUT> - Class in org.apache.flink.streaming.api.operators
Base abstract implementation of Input interface intended to be used when extending AbstractStreamOperatorV2.
AbstractInput(AbstractStreamOperatorV2<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.AbstractInput
 
AbstractMultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
Base class for transformations representing the application of a MultipleInputStreamOperator to input Transformations.
AbstractMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
AbstractPartFileWriter<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
An abstract writer for the currently open part file in a specific Bucket.
AbstractPartFileWriter(BucketID, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.AbstractPartFileWriter
 
AbstractPerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
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
 
AbstractStreamOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
Base class for all stream operator factories.
AbstractStreamOperatorFactory() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
AbstractStreamOperatorV2<OUT> - Class in org.apache.flink.streaming.api.operators
New base class for all stream operators, intended to eventually replace AbstractStreamOperator.
AbstractStreamOperatorV2(StreamOperatorParameters<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
AbstractTwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
Abstract class for executing a TwoInputStreamOperator.
AbstractTwoInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
AbstractUdfStreamOperator<OUT,F extends org.apache.flink.api.common.functions.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
 
accumulateFinalResults() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
acknowledgeIDs(long, Set<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, Set<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.
ACTIVE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
ACTIVE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
add(T) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
addAll(List<T>) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
addCoOperator(Integer, String, String, StreamOperatorFactory<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
 
addFeedbackEdge(Transformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Adds a feedback edge.
addFeedbackEdge(Transformation<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
 
addInput(Transformation<?>, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
addInput(Transformation<?>) - Method in class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
 
addLegacySource(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addMultipleInputOperator(Integer, String, String, StreamOperatorFactory<OUT>, List<TypeInformation<?>>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addNode(Integer, String, String, Class<? extends AbstractInvokable>, StreamOperatorFactory<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addOperator(Transformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds an operator to the list of operators that should be executed when calling StreamExecutionEnvironment.execute().
addOperator(Integer, String, String, StreamOperatorFactory<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, String, StreamOperatorFactory<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
Adds 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, String, SourceOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>, ShuffleMode) - 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.
addVirtualSideOutputNode(Integer, Integer, OutputTag) - 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 side-output OutputTag.
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.
advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Emits the MAX_WATERMARK so that all registered timers are fired.
advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
afterInvoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, 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.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
A AllWindowFunction that composes an AggregateFunction and AllWindowFunction.
AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
A WindowFunction that composes an AggregateFunction and WindowFunction.
AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
 
AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
Aggregation types that can be used on a windowed stream or keyed stream.
ALL - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
The InputSelection instance which indicates to select all inputs.
allActionsCompleted() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
This method must be called to end the stream task when all actions for the tasks have been performed.
allActionsCompleted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
This method must be called to end the stream task when all actions for the tasks have been performed.
allActionsCompleted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
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.CoGroupedStreams.WithWindow
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
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
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
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
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
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
Deprecated.
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
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(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.
applyToKeyedState(StateDescriptor<S, VS>, KeyedStateFunction<KS, S>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
Applies the provided function to the state associated with the provided state descriptor.
areAllInputsFinished() - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
areAllInputsSelected() - Method in class org.apache.flink.streaming.api.operators.InputSelection
Tests if all inputs are selected.
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
Deprecated.
AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Deprecated.
 
AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Deprecated.
Handler that fails the program when timestamp monotony is violated.
AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Deprecated.
Handler that does nothing when timestamp monotony is violated.
AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Deprecated.
Handler that only logs violations of timestamp monotony, on WARN log level.
AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
Deprecated.
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
Deprecated.
will be removed in a future version
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.
AssignerWithPeriodicWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
Deprecated.
AssignerWithPeriodicWatermarksAdapter<T> - Class in org.apache.flink.streaming.runtime.operators.util
An adapter that wraps a AssignerWithPeriodicWatermarks into a WatermarkGenerator.
AssignerWithPeriodicWatermarksAdapter(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
 
AssignerWithPeriodicWatermarksAdapter.Strategy<T> - Class in org.apache.flink.streaming.runtime.operators.util
A WatermarkStrategy that returns an AssignerWithPeriodicWatermarks wrapped as a WatermarkGenerator.
AssignerWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
Deprecated.
AssignerWithPunctuatedWatermarksAdapter<T> - Class in org.apache.flink.streaming.runtime.operators.util
An adapter that wraps a AssignerWithPunctuatedWatermarks into a WatermarkGenerator.
AssignerWithPunctuatedWatermarksAdapter(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
 
AssignerWithPunctuatedWatermarksAdapter.Strategy<T> - Class in org.apache.flink.streaming.runtime.operators.util
A WatermarkStrategy that returns an AssignerWithPunctuatedWatermarks wrapped as a WatermarkGenerator.
assignTimestampsAndWatermarks(WatermarkStrategy<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and generates watermarks to signal event time progress.
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
Deprecated.
 
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
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.
asStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamStatus.
asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a Watermark.
AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
A helper class to apply AsyncFunction to a data stream.
AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
 
AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
Output mode for asynchronous operations.
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, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
Trigger async operation for each stream input.
asyncInvoke(IN, ResultFuture<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
The AsyncWaitOperator allows to asynchronously process incoming stream records.
AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode, ProcessingTimeService, MailboxExecutor) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
AsyncWaitOperatorFactory<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
The factory of AsyncWaitOperator.
AsyncWaitOperatorFactory(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 

B

BackendRestorerProcedure<T extends Closeable & org.apache.flink.util.Disposable,S extends org.apache.flink.runtime.state.StateObject> - Class in org.apache.flink.streaming.api.operators
This class implements the logic that creates (and potentially restores) a state backend.
BackendRestorerProcedure(FunctionWithException<Collection<S>, T, Exception>, CloseableRegistry, String) - Constructor for class org.apache.flink.streaming.api.operators.BackendRestorerProcedure
Creates a new backend restorer using the given backend supplier and the closeable registry.
BaseAlignedWindowAssigner - Class in org.apache.flink.streaming.api.windowing.assigners
Deprecated.
will be removed in a future version. please use other WindowAssigners listed under org.apache.flink.streaming.api.windowing.assigners.
BaseAlignedWindowAssigner(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
Deprecated.
 
BaseBroadcastProcessFunction - Class in org.apache.flink.streaming.api.functions.co
The base class containing the functionality available to all broadcast process function.
BaseBroadcastProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction
 
BaseBroadcastProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
A base context available to the broadcasted stream side of a BroadcastConnectedStream.
BaseBroadcastProcessFunction.ReadOnlyContext - Class in org.apache.flink.streaming.api.functions.co
A context available to the non-broadcasted stream side of a BroadcastConnectedStream.
BasePathBucketAssigner<T> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners
A BucketAssigner that does not perform any bucketing of files.
BasePathBucketAssigner() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
BatchTimestampsAndWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
An implementation of TimestampsAndWatermarks to be used during batch execution of a program.
BatchTimestampsAndWatermarks(TimestampAssigner<T>) - Constructor for class org.apache.flink.streaming.api.operators.source.BatchTimestampsAndWatermarks
Creates a new BatchTimestampsAndWatermarks with the given TimestampAssigner.
beforeInvoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
beginNewAlignment(long, InputChannelInfo, long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
beginTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Method that starts a new transaction.
between(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
Specifies the time boundaries over which the join operation works, so that
BlockingQueueBroker - Class in org.apache.flink.streaming.runtime.io
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams.
booleanGenerator() - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
BoundedMultiInput - Interface in org.apache.flink.streaming.api.operators
Interface for the multi-input operators that can process EndOfInput event.
BoundedOneInput - Interface in org.apache.flink.streaming.api.operators
Interface for the one-input operators that can process EndOfInput event.
BoundedOutOfOrdernessTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
This is a AssignerWithPeriodicWatermarks used to emit Watermarks that lag behind the element with the maximum timestamp (in event time) seen so far by a fixed amount of time, t_late.
BoundedOutOfOrdernessTimestampExtractor(Time) - Constructor for class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
broadcast() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are broadcasted to every parallel instance of the next operation.
broadcast(MapStateDescriptor<?, ?>...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are broadcasted to every parallel instance of the next operation.
BroadcastConnectedStream<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
A BroadcastConnectedStream represents the result of connecting a keyed or non-keyed stream, with a BroadcastStream with broadcast state(s).
BroadcastConnectedStream(StreamExecutionEnvironment, DataStream<IN1>, BroadcastStream<IN2>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
 
broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
broadcastEvent(AbstractEvent) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
BroadcastPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that selects all the output channels.
BroadcastPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
BroadcastProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A function to be applied to a BroadcastConnectedStream that connects BroadcastStream, i.e.
BroadcastProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
 
BroadcastProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
A context available to the broadcast side of a BroadcastConnectedStream.
BroadcastProcessFunction.ReadOnlyContext - Class in org.apache.flink.streaming.api.functions.co
A context available to the non-keyed side of a BroadcastConnectedStream (if any).
BroadcastStream<T> - Class in org.apache.flink.streaming.api.datastream
A BroadcastStream is a stream with broadcast state(s).
BroadcastStream(StreamExecutionEnvironment, DataStream<T>, MapStateDescriptor<?, ?>...) - Constructor for class org.apache.flink.streaming.api.datastream.BroadcastStream
 
Bucket<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
A bucket is the directory organization of the output of the StreamingFileSink.
BucketAssigner<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
A BucketAssigner is used with a StreamingFileSink to determine the Bucket each incoming element should be put into.
BucketAssigner.Context - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
Context that the BucketAssigner can use for getting additional data about an input record.
bucketCreated(Bucket<IN, BucketID>) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketLifeCycleListener
Notifies a new bucket has been created.
bucketInactive(Bucket<IN, BucketID>) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketLifeCycleListener
Notifies a bucket become inactive.
BucketLifeCycleListener<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
Listener about the status of Bucket.
Buckets<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
The manager of the different active buckets in the StreamingFileSink.
BucketsBuilder() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
 
BucketWriter<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
An interface for factories that create the different writers.
BucketWriter.PendingFile - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
This represents the file that can not write any data to.
BufferEntry(T, boolean) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
 
BufferEntrySerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
BufferEntrySerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
BufferSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
Deprecated.
 
BufferSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
Deprecated.
 
build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig.OutputFileConfigBuilder
 
build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy.PolicyBuilder
 
build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Creates the actual policy.
build() - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
Creates the actual sink.
build() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
Creates the actual sink.
build(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
Build normalized mask, if all inputs were manually selected, inputMask will be normalized to -1.
build() - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
 
builder() - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig
 
builder() - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
Creates a new DefaultRollingPolicy.PolicyBuilder that is used to configure and build an instance of DefaultRollingPolicy.
Builder() - Constructor for class org.apache.flink.streaming.api.operators.InputSelection.Builder
 
BulkFormatBuilder(Path, BulkWriter.Factory<IN>, BucketAssigner<IN, BucketID>) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
BulkFormatBuilder(Path, BulkWriter.Factory<IN>, BucketAssigner<IN, BucketID>, CheckpointRollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
byteGenerator(byte, byte) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
byteGenerator(byte, byte) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 

C

cacheFile - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
calculateOverallStatus() - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
call(Callable<R>) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
call(Callable<R>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
Deprecated.
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
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.OperatorSnapshotFutures
 
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.SourceStreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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 - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
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
Deprecated.
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.
CheckpointBarrierAligner - Class in org.apache.flink.streaming.runtime.io
CheckpointBarrierAligner keep tracks of received CheckpointBarrier on given channels and controls the alignment, by deciding which channels should be blocked and when to release blocked channels.
CheckpointBarrierHandler - Class in org.apache.flink.streaming.runtime.io
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
CheckpointBarrierHandler(AbstractInvokable) - Constructor for class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
CheckpointBarrierTracker - Class in org.apache.flink.streaming.runtime.io
The CheckpointBarrierTracker keeps track of what checkpoint barriers have been received from which input channels.
CheckpointBarrierTracker(int, AbstractInvokable) - Constructor for class org.apache.flink.streaming.runtime.io.CheckpointBarrierTracker
 
CheckpointBarrierUnaligner - Class in org.apache.flink.streaming.runtime.io
CheckpointBarrierUnaligner is used for triggering checkpoint while reading the first barrier and keeping track of the number of received barriers and consumed barriers.
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
 
checkpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
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.
checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
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.
CheckpointedInputGate - Class in org.apache.flink.streaming.runtime.io
The CheckpointedInputGate uses CheckpointBarrierHandler to handle incoming CheckpointBarrier from the InputGate.
CheckpointedInputGate(InputGate, CheckpointBarrierHandler) - Constructor for class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
Creates a new checkpoint stream aligner.
CHECKPOINTING_INTERVAL - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CHECKPOINTING_MODE - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CHECKPOINTING_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
CheckpointingMode - Enum in org.apache.flink.streaming.api
The checkpointing mode defines what consistency guarantees the system gives in the presence of failures.
CheckpointRollingPolicy<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
An abstract RollingPolicy which rolls on every checkpoint.
CheckpointRollingPolicy() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy
 
CheckpointRollingPolicy.PolicyBuilder<IN,BucketID,T extends CheckpointRollingPolicy.PolicyBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
The base abstract builder class for CheckpointRollingPolicy.
checkpointState(CheckpointMetaData, CheckpointOptions, CheckpointMetrics, OperatorChain<?, ?>, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
checkSupportedInputCount(int) - Static method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
 
clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
 
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
Deprecated.
Creates target file if it does not exist, cleans it if it exists.
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
 
cleanupInProgressFileRecoverable(InProgressFileWriter.InProgressFileRecoverable) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter
Frees up any resources that were previously occupied in order to be able to recover from a (potential) failure.
cleanUpInvoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
Deletes any state in the Context when the Window expires (the watermark passes its maxTimestamp + allowedLateness).
clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
Deletes any state in the Context when the Window expires (the watermark passes its maxTimestamp + allowedLateness).
clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Remove all registered nodes etc.
clear() - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
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(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
Deletes any state in the Context when the Window expires (the watermark passes its maxTimestamp + allowedLateness).
clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
clearJobListeners() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Clear all registered JobListeners.
close() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
Deprecated.
 
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.sink.TwoPhaseCommitSinkFunction
 
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.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
close() - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
close() - Method in class org.apache.flink.streaming.api.operators.CountingOutput
 
close() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
close() - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
close() - Method in class org.apache.flink.streaming.experimental.CollectSink
Closes the connection with the Socket server.
close() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
 
close() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
close() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
close() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
Cleans up all internally held resources.
close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
close() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
close() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
close() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
close() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
close() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
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.TimestampsAndWatermarksOperator
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
close() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Lifecycle method to close the mailbox for action submission/retrieval.
close() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Close the mailbox.
close() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
close(StreamTaskActionExecutor) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
Closes the wrapped operator and propagates the close operation to the next wrapper that the StreamOperatorWrapper.next points to.
closeForCommit() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.InProgressFileWriter
 
closeForCommit() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputStreamBasedPartFileWriter
 
closeOperators(StreamTaskActionExecutor) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
Closes all operators in a chain effect way.
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.
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
CoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
CoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
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 CoGrouped 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.UnionSerializer<T1,T2> - Class in org.apache.flink.streaming.api.datastream
TypeSerializer for CoGroupedStreams.TaggedUnion.
CoGroupedStreams.UnionSerializerConfigSnapshot<T1,T2> - Class in org.apache.flink.streaming.api.datastream
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards compatibility. It is fully replaced by CoGroupedStreams.UnionSerializerSnapshot.
CoGroupedStreams.UnionSerializerSnapshot<T1,T2> - Class in org.apache.flink.streaming.api.datastream
The TypeSerializerSnapshot for the CoGroupedStreams.UnionSerializer.
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
A co-group operation that has KeySelectors defined for both inputs as well as a WindowAssigner.
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(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
collect(DataStream<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
Returns an iterator to iterate over the elements of the DataStream.
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.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - Method in interface org.apache.flink.streaming.api.operators.Output
Emits a record the side output identified by the given OutputTag.
collect(T) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
collect(T, long) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
CollectCoordinationRequest - Class in org.apache.flink.streaming.api.operators.collect
A CoordinationRequest from the client indicating that it wants a new batch of query results.
CollectCoordinationRequest(String, long) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
CollectCoordinationRequest(DataInputView) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
CollectCoordinationResponse<T> - Class in org.apache.flink.streaming.api.operators.collect
A CoordinationResponse from the coordinator containing the required batch or new results and other necessary information in serialized form.
CollectCoordinationResponse(String, long, List<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
CollectCoordinationResponse(DataInputView) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
CollectResultFetcher<T> - Class in org.apache.flink.streaming.api.operators.collect
A fetcher which fetches query results from sink and provides exactly-once semantics.
CollectResultFetcher(CompletableFuture<OperatorID>, TypeSerializer<T>, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
CollectResultIterator<T> - Class in org.apache.flink.streaming.api.operators.collect
An iterator which iterates through the results of a query job.
CollectResultIterator(CompletableFuture<OperatorID>, TypeSerializer<T>, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
CollectResultIterator(CompletableFuture<OperatorID>, TypeSerializer<T>, String, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
CollectSink<IN> - Class in org.apache.flink.streaming.experimental
A specialized data sink to be used by DataStreamUtils.collect().
CollectSink(InetAddress, int, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.experimental.CollectSink
Creates a CollectSink that will send the data to the specified host.
CollectSinkAddressEvent - Class in org.apache.flink.streaming.api.operators.collect
An OperatorEvent that passes the socket server address in the sink to the coordinator.
CollectSinkAddressEvent(InetSocketAddress) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
 
CollectSinkFunction<IN> - Class in org.apache.flink.streaming.api.operators.collect
A sink function that collects query results and sends them back to the client.
CollectSinkFunction(TypeSerializer<IN>, int, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
CollectSinkOperator<IN> - Class in org.apache.flink.streaming.api.operators.collect
A StreamSink that collects query results and sends them back to the client.
CollectSinkOperator(TypeSerializer<IN>, int, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
CollectSinkOperatorCoordinator - Class in org.apache.flink.streaming.api.operators.collect
OperatorCoordinator for CollectSinkFunction.
CollectSinkOperatorCoordinator(int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
CollectSinkOperatorCoordinator.Provider - Class in org.apache.flink.streaming.api.operators.collect
CollectSinkOperatorFactory<IN> - Class in org.apache.flink.streaming.api.operators.collect
The Factory class for CollectSinkOperator.
CollectSinkOperatorFactory(TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
CollectSinkOperatorFactory(TypeSerializer<IN>, String, int, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
CollectStreamSink<T> - Class in org.apache.flink.streaming.api.operators.collect
A DataStreamSink which is used to collect results of a data stream.
CollectStreamSink(DataStream<T>, CollectSinkOperatorFactory<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
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.
commit() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter.PendingFile
Commits the pending file, making it visible.
commit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Commit a pre-committed transaction.
commitAfterRecovery() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter.PendingFile
Commits the pending file, making it visible.
commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Mark the given checkpoint as completed in the resource.
commitUpToCheckpoint(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
commitUpToCheckpoint(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
An AggregationFunction that computes values based on comparisons of Comparables.
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
Internal comparator implementation, for use with ComparableAggregator.
Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
 
comparePriorityTo(InternalTimer<?, ?>) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
compareTo(TimestampedInputSplit) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
complete(Collection<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
Completes the result future with a collection of result objects.
completeExceptionally(Throwable) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
Completes the result future exceptionally with an exception.
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
 
config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
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.
configuration - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The configuration of this streaming task.
configure(ReadableConfig) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets all relevant options contained in the ReadableConfig such as e.g.
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
Creates a new ConnectedStreams by connecting DataStream outputs of (possible) different types with each other.
connect(BroadcastStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a new BroadcastConnectedStream by connecting the current DataStream or KeyedStream with a BroadcastStream.
ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
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
 
CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.Context
 
context - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
 
Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
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.
ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit> - Class in org.apache.flink.streaming.api.functions.source
The operator that reads the splits received from the preceding ContinuousFileMonitoringFunction.
ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> - Class in org.apache.flink.streaming.api.functions.source
ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>, TypeInformation<OUT>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
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.
CoordinatedOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
A factory class for the StreamOperators implementing OperatorEventHandler.
CoProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A function that processes elements of two streams and produces a single output one.
CoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction
 
CoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
CoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
Information available in an invocation of CoProcessFunction.onTimer(long, OnTimerContext, Collector).
CoProcessOperator<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(CoGroupedStreams.TaggedUnion<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
copy(CoGroupedStreams.TaggedUnion<T1, T2>, CoGroupedStreams.TaggedUnion<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
copy(IntervalJoinOperator.BufferEntry<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
copy(IntervalJoinOperator.BufferEntry<T>, IntervalJoinOperator.BufferEntry<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
copy(TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
copy(TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.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.
CopyingDirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
Special version of DirectedOutput that performs a shallow copy of the StreamRecord to ensure that multi-chaining works correctly.
CopyingDirectedOutput(List<OutputSelector<OUT>>, List<? extends Tuple2<? extends 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.
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.
CountingOutput<OUT> - Class in org.apache.flink.streaming.api.operators
Wrapping Output that updates metrics on the number of emitted elements.
CountingOutput(Output<StreamRecord<OUT>>, Counter) - Constructor for class org.apache.flink.streaming.api.operators.CountingOutput
 
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.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
Deprecated.
create(OperatorCoordinator.Context) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
 
create() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
Creates a new GlobalWindows WindowAssigner that assigns all elements to the same GlobalWindow.
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.
createAndRestore(List<? extends Collection<S>>) - Method in class org.apache.flink.streaming.api.operators.BackendRestorerProcedure
Creates a new state backend and restores it from the provided set of state snapshot alternatives.
createBatch() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Creates a batch of mails that can be taken with TaskMailbox.tryTakeFromBatch().
createBatch() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
createBatchEventTimeLogic(WatermarkStrategy<E>, MetricGroup) - Static method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
 
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.
createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
 
createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
createBuckets(int) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
createCheckpointedInputGate(AbstractInvokable, StreamConfig, SubtaskCheckpointCoordinator, IndexedInputGate[], TaskIOMetricGroup, String) - Static method in class org.apache.flink.streaming.runtime.io.InputProcessorUtil
 
createCheckpointedMultipleInputGate(AbstractInvokable, StreamConfig, SubtaskCheckpointCoordinator, TaskIOMetricGroup, String, List<IndexedInputGate>...) - Static method in class org.apache.flink.streaming.runtime.io.InputProcessorUtil
 
createExecutionEnvironment() - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
Creates a StreamExecutionEnvironment from this factory.
createExecutor(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorFactory
Creates a new executor for the given priority.
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(List<IndexedInputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
 
createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>) - Method in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
createInputProcessor(List<IndexedInputGate>[], TypeSerializer<?>[], WatermarkGauge[]) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>) - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
createInstance() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
createInstance() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
createInstance() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
createInstance() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
createInstance() - Method in class org.apache.flink.streaming.api.operators.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, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
createJobGraph(StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
createJobGraph(StreamGraph, JobID) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
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
Creates a LocalStreamEnvironment for local program execution that also starts the web monitoring UI.
createMainOutput(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.api.operators.source.BatchTimestampsAndWatermarks
 
createMainOutput(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.api.operators.source.StreamingTimestampsAndWatermarks
 
createMainOutput(PushingAsyncDataInput.DataOutput<T>) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
Creates the ReaderOutput for the source reader, than internally runs the timestamp extraction and watermark generation.
createMasterTriggerRestoreHook() - Method in interface org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
Creates the hook that should be called by the checkpoint coordinator.
createOperator(StreamOperatorFactory<OUT>, StreamTask<OUT, ?>, StreamConfig, Output<StreamRecord<OUT>>, OperatorEventDispatcher) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
Creates a new operator using a factory and makes sure that all special factory traits are properly handled.
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
createProcessingTimeService(MailboxExecutor) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceFactory
Creates a new processing time service with the mailbox executor.
createRecordWriterDelegate(StreamConfig, Environment) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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.
createStreamingEventTimeLogic(WatermarkStrategy<E>, MetricGroup, ProcessingTimeService, long) - Static method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
 
createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 
createStreamOperator(StreamOperatorParameters<Object>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - Method in interface org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
The implementation should return an instance of OperatorEventHandler.
createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
createStreamOperator(StreamOperatorParameters<OUT>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
Create the operator.
createStreamTaskStateInitializer() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
 
createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
 
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
 
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
 
createWithSameOutputs(PushingAsyncDataInput.DataOutput<E>, TimestampAssigner<E>, WatermarkGenerator<E>) - Static method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the (possibly different) WatermarkOutput.
createWithSeparateOutputs(PushingAsyncDataInput.DataOutput<E>, WatermarkOutput, WatermarkOutput, TimestampAssigner<E>, WatermarkGenerator<E>) - Static method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the different WatermarkOutputs.
currentProcessingTime() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner.Context
Returns the current processing time.
currentProcessingTime() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
Returns the current processing time.
currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the current processing time.
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.operators.InternalTimerServiceImpl
 
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.
currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
currentProcessingTime() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
currentTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
currentWatermark() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner.Context
Returns the current event-time watermark.
currentWatermark() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
Returns the current event-time watermark.
currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the current event-time watermark.
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.operators.InternalTimerServiceImpl
 
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.
currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
currentWatermark() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
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
 

D

DataGenerator<T> - Interface in org.apache.flink.streaming.api.functions.source.datagen
Stateful and re-scalable data generator.
DataGeneratorSource<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
A data generator source that abstract data generator.
DataGeneratorSource(DataGenerator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
Creates a source that emits records by DataGenerator without controlling emit rate.
DataGeneratorSource(DataGenerator<T>, long) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
Creates a source that emits records by DataGenerator.
DataStream<T> - Class in org.apache.flink.streaming.api.datastream
A DataStream represents a stream of elements of the same type.
DataStream(StreamExecutionEnvironment, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStream
Create a new DataStream in the given execution environment with partitioning set to forward by default.
DataStreamSink<T> - Class in org.apache.flink.streaming.api.datastream
A Stream Sink.
DataStreamSink(DataStream<T>, StreamSink<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSink
 
DataStreamSource<T> - Class in org.apache.flink.streaming.api.datastream
The DataStreamSource represents the starting point of a DataStream.
DataStreamSource(StreamExecutionEnvironment, TypeInformation<T>, StreamSource<T, ?>, boolean, String) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
The constructor used to create legacy sources.
DataStreamSource(SingleOutputStreamOperator<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
Constructor for "deep" sources that manually set up (one or more) custom configured complex operators.
DataStreamSource(StreamExecutionEnvironment, Source<T, ?, ?>, WatermarkStrategy<T>, TypeInformation<T>, String) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
Constructor for new Sources (FLIP-27).
DataStreamUtils - Class in org.apache.flink.streaming.api.datastream
A collection of utilities for DataStreams.
DateTimeBucketAssigner<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners
A BucketAssigner that assigns to buckets based on current system time.
DateTimeBucketAssigner() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with format string "yyyy-MM-dd--HH".
DateTimeBucketAssigner(String) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with the given date/time format string.
DateTimeBucketAssigner(ZoneId) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with format string "yyyy-MM-dd--HH" using the given timezone.
DateTimeBucketAssigner(String, ZoneId) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
Creates a new DateTimeBucketAssigner with the given date/time format string using the given timezone.
days(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of days.
declineCheckpoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
declineCheckpoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
DEFAULT_BUCKET_CHECK_INTERVAL - Static variable in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
 
DEFAULT_JOB_NAME - Static variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
The default name to use for a streaming job if no other name has been specified.
DEFAULT_JOB_NAME - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_LOWER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_MAX_CONCURRENT_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default limit of concurrently happening checkpoints: one.
DEFAULT_MIN_PAUSE_BETWEEN_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default minimum pause to be made between checkpoints: none.
DEFAULT_MODE - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default checkpoint mode: exactly once.
DEFAULT_NETWORK_BUFFER_TIMEOUT - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
The default buffer timeout (max delay of records in the network stack).
DEFAULT_SCHEDULE_MODE - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_SLOT_SHARING_GROUP - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_TIME_CHARACTERISTIC - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default timeout of a checkpoint attempt: 10 minutes.
DefaultRollingPolicy<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
The default implementation of the RollingPolicy.
DefaultRollingPolicy.PolicyBuilder - Class in org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
A helper class that holds the configuration properties for the DefaultRollingPolicy.
deleteCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Deletes the cleanup timer set for the contents of the provided window.
deleteEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Deletes the timer for the given key and namespace.
deleteEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
deleteEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
 
deleteEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
Deletes the event-time timer with the given trigger time.
deleteEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Delete the event-time trigger for the given time.
deleteEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
deleteOnCancellation() - Method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
Returns whether persistent checkpoints shall be discarded on cancellation of the job.
deleteProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Deletes the timer for the given key and namespace.
deleteProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
deleteProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
 
deleteProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
Deletes the processing-time timer with the given trigger time.
deleteProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Delete the processing time trigger for the given time.
deleteProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
DeltaEvictor<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
An Evictor that keeps elements based on a DeltaFunction and a threshold.
DeltaFunction<DATA> - Interface in org.apache.flink.streaming.api.functions.windowing.delta
This interface allows the implementation of a function which calculates the delta between two data points.
DeltaTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that fires based on a DeltaFunction and a threshold.
DeserializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
Deprecated.
Use DeserializationSchema instead.
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
deserialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataInputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
deserialize(int, byte[]) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
deserialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataInputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
deserialize(IntervalJoinOperator.BufferEntry<T>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
deserialize(TimerHeapInternalTimer<K, N>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
deserialize(TimerHeapInternalTimer<K, N>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
deserialize(GlobalWindow, DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
deserialize(TimeWindow, DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
deserialize(StreamElement, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
deserialize(byte[]) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
Deprecated.
Deserializes the byte message.
deserializeAccumulatorResult(byte[]) - Static method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
DirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
Wrapping Output that forwards to other Outputs based on a list of OutputSelectors.
DirectedOutput(List<OutputSelector<OUT>>, List<? extends Tuple2<? extends Output<StreamRecord<OUT>>, StreamEdge>>) - Constructor for class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
disableChaining() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - Method in class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
disableOperatorChaining() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Disables operator chaining for streaming operators.
DiscardingSink<T> - Class in org.apache.flink.streaming.api.functions.sink
A stream sink that ignores all elements.
DiscardingSink() - Constructor for class org.apache.flink.streaming.api.functions.sink.DiscardingSink
 
dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
dispose() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.InProgressFileWriter
Dispose the part file.
dispose() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputStreamBasedPartFileWriter
 
dispose() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
dispose() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
dispose() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
doTransform(String, TypeInformation<R>, StreamOperatorFactory<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
 
doTransform(String, TypeInformation<R>, StreamOperatorFactory<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
doubleGenerator(double, double) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
doubleGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
drain() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Finishes running all mails in the mailbox.
drain() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Drains the mailbox and returns all mails that were still enqueued.
drain() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
duplicate() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
duplicate() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
duplicate() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
duplicate() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
duplicate() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
duplicate() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
DynamicEventTimeSessionWindows<T> - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sessions based on the timestamp of the elements.
DynamicEventTimeSessionWindows(SessionWindowTimeGapExtractor<T>) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
DynamicProcessingTimeSessionWindows<T> - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sessions based on the current processing time.
DynamicProcessingTimeSessionWindows(SessionWindowTimeGapExtractor<T>) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 

E

emitCompletedElement(TimestampedCollector<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
emitCompletedElement(TimestampedCollector<OUT>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Emits one completed element from the head of this queue into the given output.
emitCompletedElement(TimestampedCollector<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
 
emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Output
 
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitNext(PushingAsyncDataInput.DataOutput<OUT>) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
Pushes the next element to the output from current data input, and returns the input status to indicate whether there are more available data in current input.
emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
emitPeriodicWatermark() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
emitRecord(StreamRecord<T>) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitStreamStatus(StreamStatus) - Method in class org.apache.flink.streaming.runtime.io.AbstractDataOutput
 
emitStreamStatus(StreamStatus) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitStreamStatus(StreamStatus) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits the given Watermark.
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
 
emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Output
Emits a Watermark from an operator.
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
EMPTY_ARGS - Static variable in interface org.apache.flink.streaming.api.operators.MailboxExecutor
A constant for empty args to save on object allocation.
ENABLE_UNALIGNED - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
enableCheckpointing(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long, CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long, CheckpointingMode, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Deprecated.
Use StreamExecutionEnvironment.enableCheckpointing(long, CheckpointingMode) instead. Forcing checkpoints will be removed in the future.
enableCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
enableExternalizedCheckpoints(CheckpointConfig.ExternalizedCheckpointCleanup) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Enables checkpoints to be persisted externally.
enableTransactionTimeoutWarnings(double) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Enables logging of warnings if a transaction's elapsed time reaches a specified ratio of the transactionTimeout.
enableUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
enableUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
endHeadOperatorInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
Ends the head operator input specified by inputId).
endInput() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
endInput(int) - Method in interface org.apache.flink.streaming.api.operators.BoundedMultiInput
It is notified that no more data will arrive on the input identified by the inputId.
endInput() - Method in interface org.apache.flink.streaming.api.operators.BoundedOneInput
It is notified that no more data will arrive on the input.
endOperatorInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
Ends an input of the operator contained by this wrapper.
environment - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
environment - Variable in class org.apache.flink.streaming.api.datastream.DataStream
 
environment - Variable in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
equals(Object) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
equals(Object) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
equals(Object) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.InputSelection
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
Specifies a KeySelector for elements from the second input.
equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
Specifies a KeySelector for elements from the second input with explicit type information for the key type.
equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
Specifies a KeySelector for elements from the second input.
equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
Specifies a KeySelector for elements from the second input with explicit type information for the key type.
eraseTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
eraseTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
EuclideanDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
This delta function calculates the euclidean distance between two given points.
EuclideanDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
EuclideanDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
EventTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sessions based on the timestamp of the elements.
EventTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
EventTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that fires once the watermark passes the end of the window to which a pane belongs.
evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
Optionally evicts elements.
evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
Optionally evicts elements.
evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
EvictingWindowOperator<K,IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
A WindowOperator that also allows an Evictor to be used.
EvictingWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends ListState<StreamRecord<IN>>, ?>, InternalWindowFunction<Iterable<IN>, OUT, K, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Sets the Evictor that should be used to evict elements from a window before emission.
Evictor<T,W extends Window> - Interface in org.apache.flink.streaming.api.windowing.evictors
An Evictor can remove elements from a pane before/after the evaluation of WindowFunction and after the window evaluation gets triggered by a Trigger
Evictor.EvictorContext - Interface in org.apache.flink.streaming.api.windowing.evictors
A context object that is given to Evictor methods.
ExceptionInChainedOperatorException - Exception in org.apache.flink.streaming.runtime.tasks
A special exception that signifies that the cause exception came from a chained operator.
ExceptionInChainedOperatorException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
ExceptionInChainedOperatorException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
 
execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
execute() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(ThrowingRunnable<? extends Exception>, String) - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
Executes the given command at some time in the future in the mailbox thread.
execute(ThrowingRunnable<? extends Exception>, String, Object...) - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
Executes the given command at some time in the future in the mailbox thread.
execute(ThrowingRunnable<? extends Exception>, String, Object...) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
executeAsync() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program asynchronously.
executeAsync(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution asynchronously.
executeAsync(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution asynchronously.
executeInTaskThread(ThrowingRunnable<E>, String, Object...) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
executeInTaskThread(ThrowingRunnable<E>, String, Object...) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
ExecutionCheckpointingOptions - Class in org.apache.flink.streaming.api.environment
Execution ConfigOption for configuring checkpointing related parameters.
ExecutionCheckpointingOptions() - Constructor for class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
EXTERNALIZED_CHECKPOINT - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
ExternallyInducedSource<T,CD> - Interface in org.apache.flink.streaming.api.checkpoint
Sources that implement this interface do not trigger checkpoints when receiving a trigger message from the checkpoint coordinator, but when their input data/events indicate that a checkpoint should be triggered.
ExternallyInducedSource.CheckpointTrigger - Interface in org.apache.flink.streaming.api.checkpoint
Through the CheckpointTrigger, the source function notifies the Flink source operator when to trigger the checkpoint.
extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
 
extract(FROM) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
extract(FROM) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.extractor.Extractor
Extracts/Converts the given input to an object of the output type.
extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
 
extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
 
extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
 
extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
 
extract(T) - Method in interface org.apache.flink.streaming.api.windowing.assigners.SessionWindowTimeGapExtractor
Extracts the session time gap.
extractAscendingTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Deprecated.
Extracts the timestamp from the given element.
extractFieldTypes(int[], TypeInformation<?>) - Static method in class org.apache.flink.streaming.api.datastream.StreamProjection
 
ExtractionAwareDeltaFunction<DATA,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta
Extend this abstract class to implement a delta function which is aware of extracting the data on which the delta is calculated from a more complex data structure.
ExtractionAwareDeltaFunction(Extractor<DATA, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
 
Extractor<FROM,TO> - Interface in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Extractors allow to extract/convert one type to another.
extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
Deprecated.
 
extractTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.TimestampAssigner
Deprecated.
Assigns a timestamp to an element, in milliseconds since the Epoch.
extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Deprecated.
 
extractTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
Extracts the timestamp from the given element.
extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 

F

FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
Deprecated.
 
fairSelectNextIndex(long, int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
Fairly select one of the available inputs for reading.
fairSelectNextIndexOutOf2(int, int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
Fairly select one of the two inputs for reading.
FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This represents a feedback point in a topology.
FeedbackTransformation(Transformation<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
Static factories for the FieldAccessor utilities.
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(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 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.
Internal class deprecated in favour of ContinuousFileMonitoringFunction.
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.
The watch type of the FileMonitoringFunction.
FileProcessingMode - Enum in org.apache.flink.streaming.api.functions.source
The mode in which the ContinuousFileMonitoringFunction operates.
FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
Deprecated.
Internal class deprecated in favour of ContinuousFileMonitoringFunction.
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
Applies a Filter transformation on a 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
 
finishRecoveringContext(Collection<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Callback for subclasses which is called after restoring (each) user context.
finishTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
finishTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Instructs the task to go through its normal termination routine, i.e.
FIRST - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
The InputSelection instance which indicates to select the first input.
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(CoFlatMapFunction<IN1, IN2, R>, TypeInformation<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
Applies a FlatMap transformation on a DataStream.
flatMap(FlatMapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies a FlatMap transformation on a 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.
floatGenerator(float, float) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
floatGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
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
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Deprecated.
will be removed in a future version
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
FoldApplyAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
FoldApplyProcessAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyProcessAllWindowFunction(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
FoldApplyProcessWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyProcessWindowFunction(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
FoldApplyWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
forBulkFormat(Path, BulkWriter.Factory<IN>) - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
Creates the builder for a StreamingFileSink with row-encoding format.
forceNonParallel() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the parallelism and maximum parallelism of this operator to one.
forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Performs an action for each registered timer.
forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Performs an action for each registered timer.
forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
format - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Deprecated.
 
forRowFormat(Path, Encoder<IN>) - Static method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
Creates the builder for a StreamingFileSink with row-encoding format.
forTimestamp(long) - Static method in class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
Creates a SinkFunction.Context that throws an exception when trying to access the current watermark or processing time.
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(InputSelection) - Static method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
Returns a Builder that uses the input mask of the specified selection as the initial mask.
from(StreamRecord<T>) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a TimestampedValue from given StreamRecord.
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
A SourceFunction that reads elements from an Iterator and emits them.
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.
fromSource(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Add a data Source to the environment to get a DataStream.
fromSource(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Add a data Source to the environment to get a DataStream.
FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
A SourceFunction that reads elements from an SplittableIterator and emits them.
FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 

G

generate() - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
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 class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
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.
getActiveTimerTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getAddress() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
getAllFutures() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getAllOperatorFactory() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
Returns an Iterable which traverses all operators in forward topological order.
getAllOperators(boolean) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
Returns an Iterable which traverses all operators in forward or reverse topological order.
getAsyncOperationsThreadPool() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
getBindAddress() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
 
getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
Fetches the BroadcastState with the specified name.
getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
Fetches a read-only view of the broadcast state with the specified name.
getBroadcastStateDescriptor() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
 
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
 
getBucketCheckInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
getBucketCheckInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
getBucketId() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.AbstractPartFileWriter
 
getBucketId() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
 
getBucketId(IN, BucketAssigner.Context) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner
Returns the identifier of the bucket the provided element should be put into.
getBucketId(T, BucketAssigner.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
getBucketId(IN, BucketAssigner.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
 
getBucketId() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getBucketPath() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
 
getBufferReceivedListener() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
getBufferReceivedListener() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
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.
getCachedFiles() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Get the list of cached files that were registered for distribution among the task managers.
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 class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
Deprecated.
 
getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
Get the chaining strategy of operator factory.
getChannel(int) - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
getChannelInfos() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
getChannelStateWriter() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
 
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.
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.
getCheckpointStartDelayNanos() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
getCheckpointStorage() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getCheckpointStorage() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
 
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
Deprecated.
This method is going to be removed in the next releases.
getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
getCollector() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
getCollector() - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
getCoLocationGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getCompatibleVersions() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the config object.
getConfiguration() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
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
 
getContainingTask() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
 
getCoordinatorProvider(String, OperatorID) - Method in interface org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
Get the operator coordinator provider for this operator.
getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
getCreationTime() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.AbstractPartFileWriter
 
getCreationTime() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
Get the key of the firing timer.
getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
Get key of the element being processed.
getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
Get key of the element being processed.
getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
Get key of the firing timer.
getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
Get key of the element being processed.
getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
Get key of the firing timer.
getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getCurrentKey() - Method in interface org.apache.flink.streaming.api.operators.KeyContext
 
getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
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 interface 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
Deprecated.
Returns the current watermark.
getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
Deprecated.
 
getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Deprecated.
 
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
Gets the default parallelism that will be used for the local execution environment created by StreamExecutionEnvironment.createLocalEnvironment().
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
Deprecated.
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
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.
getElement() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
 
getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the end timestamp of this window.
getEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
 
getEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
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.
getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
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.BroadcastConnectedStream
 
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Returns the StreamExecutionEnvironment that was used to create this DataStream.
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
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.
getExternalResourceInfos(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the list of feedback Transformations.
getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the list of feedback Transformations.
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.BroadcastConnectedStream
Returns the non-broadcast DataStream.
getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the first DataStream.
getFoldingState(FoldingStateDescriptor<T, A>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
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.sink.OutputFormatSinkFunction
Deprecated.
 
getFormat() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
Returns the InputFormat.
getGlobalAggregateManager() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the global aggregate manager for the current job.
getGlobalDataExchangeMode() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
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
Returns the ID of the DataStream in the current StreamExecutionEnvironment.
getId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getIdleTime() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
getInactivityInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
Returns time duration of allowed inactivity after which a part file will have to roll.
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 Transformation of this FeedbackTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the input Transformation of this OneInputTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
Returns the input Transformation of this SinkTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
Returns the input Transformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
Returns the input Transformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the input Transformation of this SinkTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
Returns the input Transformation.
getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the first input Transformation of this TwoInputTransformation.
getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the second input Transformation of this TwoInputTransformation.
getInputChannelStateFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getInputChannelStatus(int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
 
getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getInputFormat() - Method in interface org.apache.flink.streaming.api.operators.InputFormatOperatorFactory
 
getInputFormat() - Method in class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
 
getInputIndex() - Method in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
Returns the input index of this input.
getInputIndex() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
getInputIndex() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
This method is invalid and never called by the one/source input processor.
getInputMask() - Method in class org.apache.flink.streaming.api.operators.InputSelection
 
getInputs() - Method in interface org.apache.flink.streaming.api.operators.MultipleInputStreamOperator
 
getInputs() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
Returns the list of input Transformations.
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 second input.
getInputTypes() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
Returns the TypeInformation for the elements from the inputs.
getInternalIndex() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, 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.
getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Returns a InternalTimerService that can be used to query current processing time and event time and to set timers.
getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>, KeyedStateBackend<K>) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
getInternalTimerService(String, TimerSerializer<K, N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
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.InternalAggregateProcessAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
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.InternalIterableProcessAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
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.InternalSingleValueProcessAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
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
Gets the assembled JobGraph with a random JobID.
getJobGraph(JobID) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Gets the assembled JobGraph with a specified JobID.
getJobListeners() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the config JobListeners.
getJobManagerOwnedState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
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 interface org.apache.flink.streaming.api.operators.InternalTimer
Returns the key that is bound to this timer.
getKey() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
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
 
getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getKeyedStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getKeyedStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
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.
getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
getKeySerializerSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
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
getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
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
 
getLastCheckpointedOffset() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
getLastUpdateTime() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.AbstractPartFileWriter
 
getLastUpdateTime() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierTracker
 
getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
getLeftTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getLength() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
getLength() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
getLength() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
getLength() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
getLength() - Method in class org.apache.flink.streaming.api.operators.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
 
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the base-2 logarithm of the hash table capacity, as returned by KeyMap.getCurrentTableCapacity().
getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getMailboxExecutor(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Returns an executor service facade to submit actions to the mailbox.
getMailboxExecutorFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getMainMailboxExecutor() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
getManagedMemoryFraction() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getManagedMemoryWeight() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
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.runtime.partitioner.KeyGroupStreamPartitioner
 
getMaxPartCounter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
getMaxPartSize() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
Returns the maximum part file size before rolling.
getMergingWindowSet() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Retrieves the MergingWindowSet for the currently active key.
getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
 
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.
getMinResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Gets the minimum resources for this operator.
getMinResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getModificationTime() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
 
getMutex() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
Deprecated.
 
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.runtime.tasks.StreamTask
Gets the name of the task, in the form "taskname (2/5)".
getNamespace() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
Returns the namespace that is bound to this timer.
getNamespace() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
getNamespaceSerializerSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
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
This method is exactly the same as DeltaFunction.getDelta(Object, Object) except that it gets the result of the previously done extractions as input.
getNestedSerializers(CoGroupedStreams.UnionSerializer<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
getNestedSerializers(TwoPhaseCommitSinkFunction.StateSerializer<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
getNestedSerializers(IntervalJoinOperator.BufferEntrySerializer<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
 
getNestedSerializers(TimerSerializer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
getNestedSerializers(StreamElementSerializer<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
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
Deprecated.
This method will be replaced by StreamExecutionEnvironment.getRestartStrategy().
getNumberOfInputChannels() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
getNumberOfInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getNumberOfOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getNumClosedChannels() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
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.
getOffset() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
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.operators.SimpleOperatorFactory
 
getOperator() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getOperator() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
 
getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOperatorEventDispatcher() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getOperatorEventDispatcher() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getOperatorFactory() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
Returns the StreamOperatorFactory of this Transformation.
getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
Returns the StreamOperatorFactory of this LegacySourceTransformation.
getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the StreamOperatorFactory of this Transformation.
getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the StreamOperatorFactory of this SinkTransformation.
getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
Returns the StreamOperatorFactory of this LegacySourceTransformation.
getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the StreamOperatorFactory of this Transformation.
getOperatorID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOperatorId() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
 
getOperatorID() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
getOperatorId() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
getOperatorIdFuture() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
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.
getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
Return the operator name.
getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
getOperatorStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getOperatorStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getOperatorUniqueID() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returned value is guaranteed to be unique between operators within the same job and to be stable and the same across job submissions.
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
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
 
getOutput() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getOutputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOutputFormat() - Method in interface org.apache.flink.streaming.api.operators.OutputFormatOperatorFactory
 
getOutputFormat() - Method in class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
 
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
 
getOutputTag() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getOutputTag() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
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
 
getPartCounter() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket
 
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 class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
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.AbstractStreamOperatorV2
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.StreamOperatorStateHandler
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
 
getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
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 Transformation.
getPartPrefix() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig
The prefix for the part name.
getPartSuffix() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig
The suffix for the part name.
getPendingCommitTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getPendingTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Gets the port of the master (JobManager), where the program will be executed.
getPort() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
Returns the port on which the iterator is getting the data.
getPreferredResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Gets the preferred resources for this operator.
getPreferredResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getPriority() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
getProcessingTimeDelay(long, long) - Static method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
Returns the remaining delay of the processing time specified by processingTimestamp.
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.AbstractStreamOperatorV2
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.api.operators.StreamOperatorParameters
 
getProcessingTimeServiceFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
 
getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
 
getProperties() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter
 
getQueryableStateName() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the name under which the state can be queried.
getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
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.
getResults(TypeSerializer<T>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
getResultSubpartitionStateFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
getRightTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getRolloverInterval() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
Returns the maximum time duration a part file can stay open before rolling.
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.api.operators.AbstractStreamOperatorV2
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.InternalAggregateProcessAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
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.InternalIterableProcessAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
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.InternalSingleValueProcessAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
getSavepointRestoreSettings() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getScheduleMode() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Returns the BroadcastStream.
getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the second DataStream.
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
 
getSerializer() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner
 
getSerializer() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
getSerializer() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
 
getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
 
getShuffleMode() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getShuffleMode() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
getSideOutput(OutputTag<X>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Gets the DataStream that contains the elements that are emitted from an operation into the side output with the given OutputTag.
getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getSize() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputStreamBasedPartFileWriter
 
getSize() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.PartFileInfo
 
getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
Deprecated.
 
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.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
 
getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>, long, long) - Static method in class org.apache.flink.streaming.api.operators.StreamSourceContexts
Depending on the TimeCharacteristic, this method will return the adequate SourceFunction.SourceContext.
getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getSourceReader() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
getSourceVertex(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getSplitState() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
 
getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the starting timestamp of the window.
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getState() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns the current state of the mailbox as defined by the lifecycle enum TaskMailbox.State.
getState() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
getStateBackend() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets 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.api.datastream.QueryableStateStream
Returns the state descriptor for the queryable state instance.
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.
getStateKeySelectors() - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
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.KeyedMultipleInputTransformation
 
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
 
getStatePartitioners() - 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.
getStatus() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
getStreamConfig() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
getStreamEdges(int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamEdgesOrThrow(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Deprecated.
getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job.
getStreamGraph(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job.
getStreamGraph(String, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job with the option to clear previously registered transformations.
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
 
getStreamOperator() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
 
getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 
getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
getStreamOperatorClass(ClassLoader) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
Returns the runtime class of the stream operator.
getStreamOperatorFactory(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
Creates a StreamRecord from this TimestampedValue.
getStreamStatus() - Method in interface org.apache.flink.streaming.runtime.streamstatus.StreamStatusProvider
Returns the current stream status.
getStreamStatus() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getStreamStatusMaintainer() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getTaskLocalState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
getTaskManagerRuntimeInfo() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the task manager runtime info of the task manager running this stream task.
getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getTimeServiceManager() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getTimeServiceManager() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
 
getTimestamp() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
Returns the timestamp of the timer.
getTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
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.
getTolerableCheckpointFailureNumber() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Get the tolerable checkpoint failure number which used by the checkpoint failure manager to determine when we need to fail the job.
getTransformation() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
 
getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Returns the Transformation that represents the operation that logically creates this DataStream.
getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Returns the transformation that contains the actual sink operator of this sink.
getTransformation() - Method in class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
getTransformationUID() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTransitiveChainedTaskConfigsWithSelf(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
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.LegacySourceTransformation
 
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.SideOutputTransformation
 
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.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.BroadcastStream
 
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.BroadcastConnectedStream
Gets the type of the first input.
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.BroadcastConnectedStream
Gets the type of the second 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
 
getTypeSerializerIn(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerIn(int) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
Deprecated.
getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
Deprecated.
getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerSideOut(OutputTag<?>, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializersIn(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializersIn() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Gets the time unit for this policy's time interval.
getUserArtifacts() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getUserClassloader() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
getUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
Gets the user function executed in this operator.
getUserFunction() - Method in class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
 
getUserFunction() - Method in interface org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
 
getUserFunctionClassName() - Method in class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
 
getUserFunctionClassName() - Method in interface org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
 
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
 
getValue() - Method in class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
 
getValue() - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
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.
getVersion() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
getVersion() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
getVersion() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
getVersion() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
Deprecated.
 
getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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.
getWatermarkGauge() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
getWatermarkGauge() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
getWatermarkGauge() - Method in interface org.apache.flink.streaming.runtime.tasks.OperatorChain.WatermarkGaugeExposingOutput
 
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
Deprecated.
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
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
 
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.
getWriterForVersion(int, InternalTimersSnapshot<K, N>, TypeSerializer<K>, TypeSerializer<N>) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
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.
GlobalDataExchangeMode - Enum in org.apache.flink.streaming.api.graph
This mode decides the default ResultPartitionType of job edges.
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
 
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
State accessor for per-key global state.
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
State accessor for per-key global state.
globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
globalState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
The default window into which all data is placed (via GlobalWindows).
GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
A TypeSerializer for GlobalWindow.
GlobalWindow.Serializer.GlobalWindowSerializerSnapshot - Class in org.apache.flink.streaming.api.windowing.windows
Serializer configuration snapshot for compatibility and format evolution.
GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that assigns all elements to the same GlobalWindow.
GlobalWindows.NeverTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
A trigger that never fires, as default Trigger for GlobalWindows.
GlobalWindowSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer.GlobalWindowSerializerSnapshot
 

H

handleAsyncException(String, Throwable) - Method in interface org.apache.flink.streaming.runtime.tasks.AsyncExceptionHandler
Handles an exception thrown by another thread (e.g.
handleAsyncException(String, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Handles an exception thrown by another thread (e.g.
handleCoordinationRequest(CoordinationRequest) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
handleEventFromOperator(int, OperatorEvent) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
handleOperatorEvent(OperatorEvent) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
 
handleOperatorEvent(OperatorEvent) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
Deprecated.
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
Deprecated.
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
Deprecated.
 
handleViolation(long, long) - Method in interface org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.MonotonyViolationHandler
Deprecated.
Called when the property of monotonously ascending timestamps is violated, i.e., when elementTimestamp < lastTimestamp.
hasBeenJoined() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
 
hasBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
hasCompletedElements() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
hasCompletedElements() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Checks if there is at least one completed head element.
hasCompletedElements() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
hashCode() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
hashCode() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
hashCode() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
hashCode() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
hashCode() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
hashCode() - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
hashCode() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
hasInflightData(long, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Returns true if there is in-flight data in the buffers for the given channel and checkpoint.
hasInflightData(long, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
hasMail() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
hasMail() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns true if the mailbox contains mail.
hasMail() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
hasNext() - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
hasNext() - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
hasNext() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
hasNext() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
Returns true if the DataStream has more elements.
hasTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Checks whether this record has a timestamp.
hasTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Checks whether this record has a timestamp.
headOperator - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
the head operator that consumes the input streams of this task.
hours(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of hours.

I

ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
IDLE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
IDLE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
ignoreFailuresAfterTransactionTimeout() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
If called, the sink will only log but not propagate exceptions thrown in TwoPhaseCommitSinkFunction.recoverAndCommit(Object) if the transaction is older than a specified transaction timeout.
IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
Deprecated.
 
IMMEDIATE - Static variable in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
IngestionTimeExtractor<T> - Class in org.apache.flink.streaming.api.functions
Deprecated.
IngestionTimeExtractor() - Constructor for class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
Deprecated.
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
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
 
initCheckpoint(long, CheckpointOptions) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Initialize new checkpoint.
initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
initializeOperatorState(StreamOperatorStateHandler.CheckpointedStreamOperator) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
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(ListState<byte[]>, ListState<Long>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
Initializes the state after recovery from a failure.
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
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.datagen.DataGeneratorSource
 
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(StreamTaskStateInitializer) - 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(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
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(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
initializeState(StreamTaskStateInitializer) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Provides a context to initialize all state in the operator.
initializeState(StateInitializationContext) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
Initialize state and open all operators in the chain from tail to head, contrary to StreamOperator.close() which happens head to tail (see OperatorChain.closeOperators(StreamTaskActionExecutor)).
initializeUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
initMetric(TaskMetricGroup) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
InProgressFileWriter<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
The Bucket uses the InProgressFileWriter to write element to a part file.
InProgressFileWriter.InProgressFileRecoverable - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
A handle can be used to recover in-progress file..
InProgressFileWriter.PendingFileRecoverable - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
The handle can be used to recover pending file.
Input<IN> - Interface in org.apache.flink.streaming.api.operators
input1WatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
input2WatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
InputChannelStatus() - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
InputFormatOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
Input format source operator factory.
InputFormatSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
A SourceFunction that reads data using an InputFormat.
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.
inputId - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
 
inputProcessor - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The input processor.
InputProcessorUtil - Class in org.apache.flink.streaming.runtime.io
Utility for creating CheckpointedInputGate based on checkpoint mode for StreamOneInputProcessor and StreamTwoInputProcessor.
InputProcessorUtil() - Constructor for class org.apache.flink.streaming.runtime.io.InputProcessorUtil
 
inputs - Variable in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
InputSelectable - Interface in org.apache.flink.streaming.api.operators
Interface for stream operators that can select the input to get StreamRecord.
InputSelection - Class in org.apache.flink.streaming.api.operators
Describe the input selection that stream operators want to read records.
InputSelection.Builder - Class in org.apache.flink.streaming.api.operators
Utility class for creating InputSelection.
inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputStreamStatus(StreamStatus, int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Feed a StreamStatus into the valve.
inputWatermark(Watermark, int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Feed a Watermark into the valve.
INSTANCE - Static variable in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
Singleton instance.
InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable and an AggregateFunction.
InternalAggregateProcessAllWindowFunction(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessWindowFunction that takes an Iterable and an AggregateFunction.
InternalAggregateProcessWindowFunction(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
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
 
InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable when the window state also is an Iterable.
InternalIterableProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessWindowFunction that takes an Iterable when the window state also is an Iterable.
InternalIterableProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
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
 
InternalProcessAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal reusable context wrapper.
InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Internal reusable context wrapper.
InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Internal reusable context wrapper.
InternalProcessWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal reusable context wrapper.
internalSetKeyContextElement(StreamRecord<T>, KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
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
 
InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable when the window state is a single value.
InternalSingleValueProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessWindowFunction that takes an Iterable when the window state is a single value.
InternalSingleValueProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
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> - Interface in org.apache.flink.streaming.api.operators
Internal interface for in-flight timers.
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
 
InternalTimerServiceImpl<K,N> - Class in org.apache.flink.streaming.api.operators
InternalTimerService that stores timers on the Java heap.
internalTimerServiceManager() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns the internal timer service manager for the stream operator.
InternalTimerServiceSerializationProxy<K> - Class in org.apache.flink.streaming.api.operators
Serialization proxy for the timer services for a given key-group.
InternalTimerServiceSerializationProxy(InternalTimeServiceManager<K>, ClassLoader, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
Constructor to use when restoring timer services.
InternalTimerServiceSerializationProxy(InternalTimeServiceManager<K>, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
Constructor to use when writing timer services.
InternalTimersSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
A snapshot of internal timers, containing event and processing timers and the serializers to use to write / read them.
InternalTimersSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
Empty constructor used when restoring the timers.
InternalTimersSnapshot(TypeSerializer<K>, TypeSerializer<N>, Set<TimerHeapInternalTimer<K, N>>, Set<TimerHeapInternalTimer<K, N>>) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
Constructor to use when snapshotting the timers.
InternalTimersSnapshotReaderWriters - Class in org.apache.flink.streaming.api.operators
Readers and writers for different versions of the InternalTimersSnapshot.
InternalTimersSnapshotReaderWriters() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> - Interface in org.apache.flink.streaming.api.operators
A reader for a InternalTimersSnapshot.
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter - Interface in org.apache.flink.streaming.api.operators
A writer for a InternalTimersSnapshot.
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
A TypeSerializer used to serialize/deserialize a TimerHeapInternalTimer.
InternalTimeServiceManager<K> - Class in org.apache.flink.streaming.api.operators
An entity keeping all the time-related services available to all operators extending the AbstractStreamOperator.
internalTimeServiceManager(AbstractKeyedStateBackend<K>, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
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.
InternalWindowFunction.InternalWindowContext - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
A context for InternalWindowFunction, similar to ProcessWindowFunction.Context but for internal use.
intersects(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Returns true if this window intersects the given window or if this window is just after or before the given window.
intervalJoin(KeyedStream<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Join elements of this KeyedStream with elements of another KeyedStream over a time interval that can be specified with KeyedStream.IntervalJoin.between(Time, Time).
IntervalJoined(KeyedStream<IN1, KEY>, KeyedStream<IN2, KEY>, long, long, boolean, boolean) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
 
IntervalJoinOperator<K,T1,T2,OUT> - Class in org.apache.flink.streaming.api.operators.co
An operator to execute time-bounded stream inner joins.
IntervalJoinOperator(long, long, boolean, boolean, TypeSerializer<T1>, TypeSerializer<T2>, ProcessJoinFunction<T1, T2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
Creates a new IntervalJoinOperator.
IntervalJoinOperator.BufferEntry<T> - Class in org.apache.flink.streaming.api.operators.co
A container for elements put in the left/write buffer.
IntervalJoinOperator.BufferEntrySerializer<T> - Class in org.apache.flink.streaming.api.operators.co
A serializer for the IntervalJoinOperator.BufferEntry.
IntervalJoinOperator.BufferEntrySerializerSnapshot<T> - Class in org.apache.flink.streaming.api.operators.co
A TypeSerializerSnapshot for IntervalJoinOperator.BufferEntrySerializer.
IntervalJoinOperator.BufferSerializerConfigSnapshot<T> - Class in org.apache.flink.streaming.api.operators.co
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards compatibility. It is fully replaced by IntervalJoinOperator.BufferEntrySerializerSnapshot.
intGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
intGenerator(int, int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.DiscardingSink
 
invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
Deprecated.
 
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
invoke(IN, SinkFunction.Context) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
Writes the given value to the sink.
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(TXN, IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Write value within a transaction.
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
This should not be implemented by subclasses.
invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Deprecated.
Implementation of the invoke method of the SinkFunction class.
invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.experimental.CollectSink
 
invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
isAcceptingMails() - Method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
 
isActive() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
isAllVerticesInSameSlotSharingGroupByDefault() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Gets whether to put all vertices into the same slot sharing group by default.
isBlocked(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
isBlocked(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Checks whether the channel with the given index is blocked.
isBroadcast() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
isBroadcast() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
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.
isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierTracker
 
isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
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.
isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
Checks if the wrapped operator has been closed.
isDefaultActionUnavailable() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
isElementLate(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Decide if a record is currently late, based on current watermark and allowed lateness.
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.operators.windowing.KeyMap
Checks whether the map is empty.
isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
Deprecated.
Method to decide whether the element signals the end of the stream.
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
Deprecated.
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
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.
isExactlyOnceCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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
 
isFailOnCheckpointingErrors() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
isFinished() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
 
isFlushAlwaysEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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.
Forcing checkpoints will be removed in future version.
isIdle() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
isIdle() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
isImmutableType() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.operators.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
 
isInputFinished(int) - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
isInputSelected(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
Tests if the input specified by inputId is selected.
isInputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isInputTypeConfigurable() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
If the stream operator need to be configured with the data type they will operate on.
isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
isLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a latency marker.
isMailboxLoopRunning() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
isMailboxThread() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Check if the current thread is the mailbox thread.
isMailboxThread() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Check if the current thread is the mailbox thread.
isMailboxThread() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isOutputTypeConfigurable() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
If the stream operator need access to the output type information at StreamGraph generation.
isPreferCheckpointForRecovery() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Returns whether a job recovery should fallback to checkpoint when there is a more recent savepoint.
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.
isRestored() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns true, the states provided by this context are restored from a checkpoint/savepoint.
isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
isStreamSource() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
isStreamSource() - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
isStreamSource() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
Is this factory for StreamSource.
isStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a stream status.
isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
isTerminated() - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
Returns true if the service has been shut down, false otherwise.
isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Returns whether unaligned checkpoints are enabled.
isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a watermark.
isWatermarkAligned - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
isWindowLate(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.
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.
ITERATION_SINK_NAME_PREFIX - Static variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
ITERATION_SOURCE_NAME_PREFIX - Static variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
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
The IterativeStream.ConnectedIterativeStreams represent a start of an iterative part of a streaming program, where the original input of the iteration and the feedback of the iteration are connected as in a ConnectedStreams.
iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates an iterator over the entries of this map.

J

jobId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
join(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a join operation.
JoinedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
JoinedStreams represents two DataStreams that have been joined.
JoinedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams
Creates new JoinedStreams data streams, which are the first step towards building a streaming co-group.
JoinedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
Joined streams that have the key for one side defined.
JoinedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
A join operation that has KeySelectors defined for both inputs.
JoinedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
A join operation that has KeySelectors defined for both inputs as well as a WindowAssigner.
JSONGenerator - Class in org.apache.flink.streaming.api.graph
Helper class for generating a JSON representation from a StreamGraph.
JSONGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.JSONGenerator
 

K

key - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
key - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
KEY_EXTRACTOR_FUNCTION - Static variable in interface org.apache.flink.streaming.api.operators.InternalTimer
Function to extract the key from a InternalTimer.
keyBy(int, int) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(int[], int[]) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(String, String) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream using key expressions.
keyBy(String[], String[]) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream using key expressions.
keyBy(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(KeySelector<IN1, KEY>, KeySelector<IN2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
It creates a new KeyedStream that uses the provided key for partitioning its operator states.
keyBy(KeySelector<T, K>, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
It creates a new KeyedStream that uses the provided key with explicit type information for partitioning its operator states.
keyBy(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
keyBy(String...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
keyBy(int[], int[]) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(String, String) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(String[], String[]) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(KeySelector<I, ?>, KeySelector<F, ?>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(KeySelector<I, KEY>, KeySelector<F, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
KeyContext - Interface in org.apache.flink.streaming.api.operators
Inteface for setting and querying the current key of keyed operations.
keyDone() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called when the traversal for the current key is complete.
KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A function to be applied to a BroadcastConnectedStream that connects BroadcastStream, i.e.
KeyedBroadcastProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
 
KeyedBroadcastProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
A context available to the broadcast side of a BroadcastConnectedStream.
KeyedBroadcastProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
KeyedBroadcastProcessFunction.ReadOnlyContext - Class in org.apache.flink.streaming.api.functions.co
A context available to the keyed stream side of a BroadcastConnectedStream (if any).
KeyedCoProcessFunction<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A function that processes elements of two keyed streams and produces a single output one.
KeyedCoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
 
KeyedCoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
KeyedCoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
Information available in an invocation of KeyedCoProcessFunction.onTimer(long, OnTimerContext, Collector).
KeyedCoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
A StreamOperator for executing keyed KeyedCoProcessFunction.
KeyedCoProcessOperator(KeyedCoProcessFunction<K, IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
KeyedMultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
AbstractMultipleInputTransformation implementation for keyed streams.
KeyedMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, TypeInformation<?>) - Constructor for class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
KeyedProcessFunction<K,I,O> - Class in org.apache.flink.streaming.api.functions
A keyed function that processes elements of a stream.
KeyedProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction
 
KeyedProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
KeyedProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
Information available in an invocation of KeyedProcessFunction.onTimer(long, OnTimerContext, Collector).
KeyedProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators
KeyedProcessOperator(KeyedProcessFunction<K, IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
keyedStateBackend() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns the keyed state backend for the stream operator.
keyedStatedBackend(TypeSerializer<K>, String, PrioritizedOperatorSubtaskState, CloseableRegistry, MetricGroup) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
KeyedStream<T,KEY> - Class in org.apache.flink.streaming.api.datastream
A KeyedStream represents a DataStream on which operator state is partitioned by key using a provided KeySelector.
KeyedStream(DataStream<T>, KeySelector<T, KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream
Creates a new KeyedStream using the given KeySelector to partition operator state by key.
KeyedStream(DataStream<T>, KeySelector<T, KEY>, TypeInformation<KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream
Creates a new KeyedStream using the given KeySelector to partition operator state by key.
KeyedStream.IntervalJoin<T1,T2,KEY> - Class in org.apache.flink.streaming.api.datastream
Perform a join over a time interval.
KeyedStream.IntervalJoined<IN1,IN2,KEY> - Class in org.apache.flink.streaming.api.datastream
IntervalJoined is a container for two streams that have keys for both sides as well as the time boundaries over which elements should be joined.
KeyGroupStreamPartitioner<T,K> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner selects the target channel based on the key group index.
KeyGroupStreamPartitioner(KeySelector<T, K>, int) - Constructor for class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
KeyMap<K,V> - Class in org.apache.flink.streaming.runtime.operators.windowing
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
KeyMap() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates a new hash table with the default initial capacity.
KeyMap(int) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates a new table with a capacity tailored to the given expected number of elements.
KeyMap.Entry<K,V> - Class in org.apache.flink.streaming.runtime.operators.windowing
An entry in the hash table.
KeyMap.LazyFactory<V> - Interface in org.apache.flink.streaming.runtime.operators.windowing
A factory for lazy/on-demand instantiation of values.
KeyMap.TraversalEvaluator<K,V> - Interface in org.apache.flink.streaming.runtime.operators.windowing
A visitor for a traversal over the union of multiple hash maps.
KeySelectorUtil - Class in org.apache.flink.streaming.util.keys
Utility class that contains helper methods to manipulating KeySelector for streaming.
KeySelectorUtil.ArrayKeySelector<IN> - Class in org.apache.flink.streaming.util.keys
A key selector for selecting individual array fields as keys and returns them as a Tuple.
KeySelectorUtil.ComparableKeySelector<IN> - Class in org.apache.flink.streaming.util.keys
A key selector for selecting key fields via a TypeComparator.
KeySelectorUtil.OneKeySelector<IN,K> - Class in org.apache.flink.streaming.util.keys
Key extractor that extracts a single field via a generic comparator.
keySerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the key in checkpoints.

L

lateDataOutputTag - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
OutputTag to use for late arriving events.
LatencyMarker - Class in org.apache.flink.streaming.runtime.streamrecord
Special record type carrying a timestamp of its creation time at a source operator and the vertexId and subtask index of the operator.
LatencyMarker(long, OperatorID, int) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
Creates a latency mark with the given timestamp.
latencyStats - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
latencyStats - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
LatencyStats - Class in org.apache.flink.streaming.util
The LatencyStats objects are used to track and report on the behavior of latencies across measurements.
LatencyStats(MetricGroup, int, int, OperatorID, LatencyStats.Granularity) - Constructor for class org.apache.flink.streaming.util.LatencyStats
 
LatencyStats.Granularity - Enum in org.apache.flink.streaming.util
Granularity for latency metrics.
LegacyKeyedCoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
Deprecated.
Replaced by KeyedCoProcessOperator which takes KeyedCoProcessFunction
LegacyKeyedCoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
LegacyKeyedProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators
Deprecated.
Replaced by KeyedProcessOperator which takes KeyedProcessFunction
LegacyKeyedProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
Deprecated.
 
LegacySourceTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This represents a Source.
LegacySourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
Creates a new LegacySourceTransformation from the given operator.
LegacySourceTransformation(String, StreamOperatorFactory<T>, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
ListCheckpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
Deprecated.
If you need to do non-keyed state snapshots of your operator, use CheckpointedFunction. This should only be needed in rare cases, though.
LocalStreamEnvironment - Class in org.apache.flink.streaming.api.environment
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
LocalStreamEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Creates a new mini cluster stream environment that uses the default configuration.
LocalStreamEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Creates a new mini cluster stream environment that configures its local executor with the given configuration.
LOG - Static variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
The logger used by the operator class and its subclasses.
LOG - Static variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
The logger used by the operator class and its subclasses.
LOG - Static variable in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
LOG - Static variable in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
LOG - Static variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
LOG - Static variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
LOG - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The logger used by the StreamTask and its subclasses.
LoggingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
Deprecated.
 
longGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
longGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
lowerBoundExclusive() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Set the lower bound to be exclusive.

M

Mail - Class in org.apache.flink.streaming.runtime.tasks.mailbox
An executable bound to a specific operator in the chain, such that it can be picked for downstream mailbox.
Mail(ThrowingRunnable<? extends Exception>, int, String, Object...) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
Mail(ThrowingRunnable<? extends Exception>, int, StreamTaskActionExecutor, String, Object...) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
mailbox - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
The mailbox data-structure that manages request for special actions, like timers, checkpoints, ...
MailboxController(MailboxProcessor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
MailboxDefaultAction - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
Interface for the default action that is repeatedly invoked in the mailbox-loop.
mailboxDefaultAction - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Action that is repeatedly executed if no action request is in the mailbox.
MailboxDefaultAction.Controller - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
This context is a feedback interface for the default action to interact with the mailbox execution.
MailboxDefaultAction.Suspension - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
Represents the suspended state of a MailboxDefaultAction, ready to resume.
MailboxExecutor - Interface in org.apache.flink.streaming.api.operators
Executor like interface for an build around a mailbox-based execution model (see TaskMailbox).
MailboxExecutorFactory - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
A factory for creating mailbox executors with a given priority.
MailboxExecutorImpl - Class in org.apache.flink.streaming.runtime.tasks.mailbox
Implementation of an executor service build around a mailbox-based execution model.
MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor, MailboxProcessor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
MailboxProcessor - Class in org.apache.flink.streaming.runtime.tasks.mailbox
This class encapsulates the logic of the mailbox-based execution model.
MailboxProcessor(MailboxDefaultAction) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
MailboxProcessor(MailboxDefaultAction, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
mailboxProcessor - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
MailboxProcessor.MailboxController - Class in org.apache.flink.streaming.runtime.tasks.mailbox
Implementation of MailboxDefaultAction.Controller that is connected to a MailboxProcessor instance.
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(CoMapFunction<IN1, IN2, R>, TypeInformation<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
Applies a Map transformation on a DataStream.
map(MapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies a Map transformation on a 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.
markAsTemporarilyIdle() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Marks the source to be temporarily idle.
markCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
Marks this source as canceled or stopped.
markCheckpointStart(long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
markIdle() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
 
markIdle() - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
 
markWrite(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.AbstractPartFileWriter
 
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_CONCURRENT_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
MAX_PRIORITY - Static variable in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
The maximal priority for mails.
MAX_SUPPORTED_INPUT_COUNT - Static variable in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
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 field.
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
Gets the largest timestamp that still belongs to this window.
maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
Gets the largest timestamp that still belongs to this 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.DynamicEventTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
Merge overlapping TimeWindows.
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
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Merge overlapping TimeWindows.
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
Callback to be used in MergingWindowAssigner.mergeWindows(Collection, MergeCallback) for specifying which windows should be merged.
MergingWindowSet<W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
Utility for keeping track of merging Windows when using a MergingWindowAssigner in a WindowOperator.
MergingWindowSet(MergingWindowAssigner<?, W>, ListState<Tuple2<W, W>>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Restores a MergingWindowSet from the given state.
MergingWindowSet.MergeFunction<W> - Interface in org.apache.flink.streaming.runtime.operators.windowing
MergingWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
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.
metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
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.
MIN_PAUSE_BETWEEN_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
MIN_PRIORITY - Static variable in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
The minimal priority for mails.
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 field.
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.
minInputWatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
 
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.
MinWatermarkGauge - Class in org.apache.flink.streaming.runtime.metrics
A Gauge for exposing the minimum watermark of chosen WatermarkGauges.
MinWatermarkGauge(WatermarkGauge...) - Constructor for class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
 
MultipleConnectedStreams - Class in org.apache.flink.streaming.api.datastream
This is a very basic and rough stub for a class connecting multiple input DataStreams into one, using MultipleInputStreamOperator.
MultipleConnectedStreams(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
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.
MultipleInputSelectionHandler - Class in org.apache.flink.streaming.runtime.io
This handler is mainly used for selecting the next available input index in StreamMultipleInputProcessor.
MultipleInputSelectionHandler(InputSelectable, int) - Constructor for class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
MultipleInputStreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
Interface for stream operators with multiple Inputs.
MultipleInputStreamTask<OUT> - Class in org.apache.flink.streaming.runtime.tasks
A StreamTask for executing a MultipleInputStreamOperator and supporting the MultipleInputStreamOperator to select input for reading.
MultipleInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
 
MultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
AbstractMultipleInputTransformation implementation for non-keyed streams.
MultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
 

N

name(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the name of this sink.
name(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the name of the current data stream.
name(String) - Method in class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
NeverTrigger() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
next() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
next() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
next() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
Returns the next element of the DataStream.
nextSelection() - Method in interface org.apache.flink.streaming.api.operators.InputSelectable
Returns the next InputSelection that wants to get the record.
nextValue(V) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called for each value found for the current key.
NO_VERSION - Static variable in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
 
NONE_AVAILABLE - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
 
nonParallel - Variable in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Indicate this is a non-parallel operator and cannot set a non-1 degree of parallelism.
notifyAbort(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
notifyAbortOnCancellationBarrier(long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
notifyCheckpoint(CheckpointBarrier, long) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
notifyCheckpointAbortAsync(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
notifyCheckpointAborted(long, OperatorChain<?, ?>, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Notified on the task side once a distributed checkpoint has been aborted.
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
 
notifyCheckpointComplete(long, OperatorChain<?, ?>, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
Notified on the task side once a distributed checkpoint has been completed.
notifyCheckpointCompleteAsync(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
notifyOfError(Throwable) - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
 
numberOfChannels - Variable in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numEventTimeTimers(N) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
numLateRecordsDropped - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numProcessingTimeTimers(N) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 

O

of(StreamOperator<OUT>) - Static method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
Create a SimpleOperatorFactory from existed StreamOperator.
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.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
Deprecated.
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
Creates a new Time of the given duration and TimeUnit.
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.
onBarrier(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
Blocks the given channel index, from which a barrier has been received.
OnCheckpointRollingPolicy<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
A RollingPolicy which rolls (ONLY) on every checkpoint.
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.
OneInputStreamOperatorFactory<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
A factory to create OneInputStreamOperator.
OneInputStreamTask<IN,OUT> - Class in org.apache.flink.streaming.runtime.tasks
OneInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
OneInputStreamTask(Environment, TimerService) - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
OneInputTransformation<IN,OUT> - Class in org.apache.flink.streaming.api.transformations
This Transformation represents the application of a OneInputStreamOperator to one input Transformation.
OneInputTransformation(Transformation<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.
OneInputTransformation(Transformation<IN>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
onElement(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
onElement(IN, long, Long, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
onElement(IN, long, Long, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
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
 
onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
 
onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
 
onEventTime(InternalTimer<KS, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
onEventTime(InternalTimer<K, String>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
Deprecated.
 
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
 
onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter
 
onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
onProcessingTime(InternalTimer<KS, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
 
onProcessingTime(InternalTimer<K, String>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
Deprecated.
 
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.TimestampsAndWatermarksOperator
 
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<IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, KeyedCoProcessFunction<K, IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, KeyedProcessFunction<K, I, O>.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, ProcessFunction<I, O>.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
Called when a timer set using TimerService fires.
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
 
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
 
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
 
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
 
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
 
onWatermark(KEY, Watermark) - Method in interface org.apache.flink.streaming.api.operators.OnWatermarkCallback
The action to be triggered upon reception of a watermark.
OnWatermarkCallback<KEY> - Interface in org.apache.flink.streaming.api.operators
A callback registered with the InternalWatermarkCallbackService service.
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
Deprecated.
 
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(String, FunctionInitializationContext, RuntimeContext) - Method in interface org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
Open and initialize state for DataGenerator.
open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
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
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
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.AbstractStreamOperatorV2
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.CoBroadcastWithKeyedOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
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.co.IntervalJoinOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
open() - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
Deprecated.
 
open() - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
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.api.operators.StreamSink
 
open(Configuration) - Method in class org.apache.flink.streaming.experimental.CollectSink
Initialize the connection with the Socket in the server.
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.GenericWriteAheadSink
 
open() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
openNewInProgressFile(BucketID, Path, long) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter
Used to create a new InProgressFileWriter.
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>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
operatorChain - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The chain of operators executed by this task.
OperatorChain.WatermarkGaugeExposingOutput<T> - Interface in org.apache.flink.streaming.runtime.tasks
An Output that measures the last emitted watermark with a WatermarkGauge.
operatorFactory - Variable in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
operatorId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
OperatorSnapshotFinalizer - Class in org.apache.flink.streaming.api.operators
This class finalizes OperatorSnapshotFutures.
OperatorSnapshotFinalizer(OperatorSnapshotFutures) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
 
OperatorSnapshotFutures - Class in org.apache.flink.streaming.api.operators
OperatorSnapshotFutures() - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>>, RunnableFuture<SnapshotResult<KeyedStateHandle>>, RunnableFuture<SnapshotResult<OperatorStateHandle>>, RunnableFuture<SnapshotResult<OperatorStateHandle>>, Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>, Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
operatorStateBackend() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns the operator state backend for the stream operator.
operatorStateBackend(String, PrioritizedOperatorSubtaskState, CloseableRegistry) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
OrderedStreamElementQueue<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
Ordered StreamElementQueue implementation.
OrderedStreamElementQueue(int) - 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.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.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.sink.filesystem - package org.apache.flink.streaming.api.functions.sink.filesystem
 
org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners - package org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners
 
org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies - package org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies
 
org.apache.flink.streaming.api.functions.source - package org.apache.flink.streaming.api.functions.source
 
org.apache.flink.streaming.api.functions.source.datagen - package org.apache.flink.streaming.api.functions.source.datagen
 
org.apache.flink.streaming.api.functions.timestamps - package org.apache.flink.streaming.api.functions.timestamps
 
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.operators.collect - package org.apache.flink.streaming.api.operators.collect
 
org.apache.flink.streaming.api.operators.source - package org.apache.flink.streaming.api.operators.source
 
org.apache.flink.streaming.api.operators.util - package org.apache.flink.streaming.api.operators.util
 
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.experimental - package org.apache.flink.streaming.experimental
This package holds classes that are experimental.
org.apache.flink.streaming.runtime.io - package org.apache.flink.streaming.runtime.io
 
org.apache.flink.streaming.runtime.metrics - package org.apache.flink.streaming.runtime.metrics
 
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.util - package org.apache.flink.streaming.runtime.operators.util
 
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.streamstatus - package org.apache.flink.streaming.runtime.streamstatus
 
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.runtime.tasks.mailbox - package org.apache.flink.streaming.runtime.tasks.mailbox
 
org.apache.flink.streaming.util - package org.apache.flink.streaming.util
 
org.apache.flink.streaming.util.functions - package org.apache.flink.streaming.util.functions
 
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(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
Emits a record to the side output identified by the OutputTag.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Emits a record to the side output identified by the OutputTag.
output - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
 
output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
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.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
output(OutputTag<X>, X) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
OutputFileConfig - Class in org.apache.flink.streaming.api.functions.sink.filesystem
Part file name configuration.
OutputFileConfig(String, String) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig
Initiates the PartFileConfig with values passed as parameters.
OutputFileConfig.OutputFileConfigBuilder - Class in org.apache.flink.streaming.api.functions.sink.filesystem
A builder to create the part file configuration.
OutputFormatOperatorFactory<IN> - Interface in org.apache.flink.streaming.api.operators
Interface for operator factories which create the sink operator containing an OutputFormat.
OutputFormatSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
Please use the StreamingFileSink for writing to files from a streaming program.
OutputFormatSinkFunction(OutputFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
Deprecated.
 
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
 
OutputStreamBasedPartFileWriter<IN,BucketID> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
The base class for all the part file writer that use RecoverableFsDataOutputStream.
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.
owner - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
 

P

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.
PartFileInfo<BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
An interface exposing the information concerning the current (open) part file that is necessary to the RollingPolicy in order to determine if it should roll the part file or not.
partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
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(Transformation<T>, StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
Creates a new PartitionTransformation from the given input and StreamPartitioner.
PartitionTransformation(Transformation<T>, StreamPartitioner<T>, ShuffleMode) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
Creates a new PartitionTransformation from the given input and StreamPartitioner.
PassThroughAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
A AllWindowFunction that just emits each input element.
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
A WindowFunction that just emits each input element.
PassThroughWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
 
path - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Deprecated.
 
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.
pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
pendingTransaction - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
pendingTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
persist() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.InProgressFileWriter
 
persist() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputStreamBasedPartFileWriter
 
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.
PerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
PhysicalTransformation<T> - Class in org.apache.flink.streaming.api.transformations
A Transformation that creates a physical operation.
PolicyBuilder() - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy.PolicyBuilder
 
pollNext() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
preCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Pre commit previously created transaction.
PREDECESSORS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
PREFER_CHECKPOINT_FOR_RECOVERY - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
prepareClose() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Lifecycle method to close the mailbox for action submission.
prepareSnapshot(ChannelStateWriter, long) - Method in interface org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
prepareSnapshot(ChannelStateWriter, long) - Method in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
Prepares to spill the in-flight input buffers as checkpoint snapshot.
prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
prepareSnapshotPreBarrier(long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
This method is called when the operator should do a snapshot, before it emits its own checkpoint barrier.
prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
print() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stdout).
print(String) - 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.
PrintSinkFunction(String, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
Instantiates a print sink function that prints to standard out and gives a sink identifier.
printToErr() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stderr).
printToErr(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stderr).
process(ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
process(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a KeyedStream and applies the given KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream.
process(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a KeyedStream and applies the given KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream.
process(BroadcastProcessFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a non-keyed DataStream and applies the given BroadcastProcessFunction on them, thereby creating a transformed output stream.
process(BroadcastProcessFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
Assumes as inputs a BroadcastStream and a non-keyed DataStream and applies the given BroadcastProcessFunction on them, thereby creating a transformed output stream.
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(KeyedCoProcessFunction<K, IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Applies the given KeyedCoProcessFunction on the connected input keyed streams, thereby creating a transformed output stream.
process(KeyedCoProcessFunction<K, IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Applies the given KeyedCoProcessFunction on the connected input streams, thereby creating a transformed output stream.
process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
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.DataStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessJoinFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Completes the join operation with the given user function that is executed for each joined pair of elements.
process(ProcessJoinFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Completes the join operation with the given user function that is executed for each joined pair of elements.
process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
process(KeyedProcessFunction<KEY, T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies the given KeyedProcessFunction on the input stream, thereby creating a transformed output stream.
process(KeyedProcessFunction<KEY, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies the given KeyedProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
process(ProcessAllWindowFunction<IN, OUT, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
Evaluates the window and outputs none or several elements.
process(KEY, ProcessWindowFunction<IN, OUT, KEY, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
Evaluates the window and outputs none or several elements.
process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
process(K, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
Evaluates the window and outputs none or several elements.
ProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Base abstract class for functions that are evaluated over non-keyed windows using a context for retrieving extra information.
ProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
 
ProcessAllWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
The context holding window metadata.
processBarrier(CheckpointBarrier, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
processBarrier(CheckpointBarrier, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
processBarrier(CheckpointBarrier, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierTracker
 
processBarrier(CheckpointBarrier, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
We still need to trigger checkpoint via ThreadSafeUnaligner#notifyBarrierReceived(CheckpointBarrier, InputChannelInfo) while reading the first barrier from one channel, because this might happen earlier than the previous async trigger via mailbox by netty thread.
processBroadcastElement(IN2, BroadcastProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
This method is called for each element in the broadcast stream.
processBroadcastElement(IN2, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
This method is called for each element in the broadcast stream.
processCancellationBarrier(CancelCheckpointMarker) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
processCancellationBarrier(CancelCheckpointMarker) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
processCancellationBarrier(CancelCheckpointMarker) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierTracker
 
processCancellationBarrier(CancelCheckpointMarker) - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
processContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processElement(IN1, BroadcastProcessFunction<IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
This method is called for each element in the (non-broadcast) data stream.
processElement(IN1, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
This method is called for each element in the (non-broadcast) keyed stream.
processElement(IN1, IN2, ProcessJoinFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
This method is called for each joined pair of elements.
processElement(I, KeyedProcessFunction<K, I, O>.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
Process one element from the input stream.
processElement(I, ProcessFunction<I, O>.Context, Collector<O>) - Method in class 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<T>) - 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.Input
Processes one element that arrived on this input of the MultipleInputStreamOperator.
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
Deprecated.
 
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
Deprecated.
 
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<IN>) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
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<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
This method is called for each element in the first of the connected streams.
processElement1(IN1, KeyedCoProcessFunction<K, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
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.CoBroadcastWithKeyedOperator
 
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
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<T1>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
Process a StreamRecord from the left stream.
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
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<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
This method is called for each element in the second of the connected streams.
processElement2(IN2, KeyedCoProcessFunction<K, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
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.CoBroadcastWithKeyedOperator
 
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
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<T2>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
Process a StreamRecord from the right stream.
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Deprecated.
 
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.
processEndOfPartition() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
processEndOfPartition() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
processEndOfPartition() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierTracker
 
processEndOfPartition() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
ProcessFunction<I,O> - Class in org.apache.flink.streaming.api.functions
A function that processes elements of a stream.
ProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction
 
ProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
ProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
Information available in an invocation of ProcessFunction.onTimer(long, OnTimerContext, Collector).
ProcessingTimeCallback - Interface in org.apache.flink.streaming.runtime.tasks
Interface for processing-time callbacks that can be registered at a ProcessingTimeService.
processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
ProcessingTimeService - Interface 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.
ProcessingTimeServiceAware - Interface in org.apache.flink.streaming.runtime.tasks
Interface for StreamOperatorFactory, which enables stream operators to access ProcessingTimeService.
ProcessingTimeServiceFactory - Interface in org.apache.flink.streaming.runtime.tasks
A factory for creating processing time services with a given MailboxExecutor.
ProcessingTimeServiceUtil - Class in org.apache.flink.streaming.runtime.tasks
Utility for classes that implements the ProcessingTimeService interface.
ProcessingTimeServiceUtil() - Constructor for class org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
 
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() - Method in interface org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
This method implements the default action of the task (e.g.
ProcessJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A function that processes two joined elements and produces a single output one.
ProcessJoinFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
 
ProcessJoinFunction.Context - Class in org.apache.flink.streaming.api.functions.co
The context that is available during an invocation of ProcessJoinFunction.processElement(Object, Object, Context, Collector).
processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
 
processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Input
Processes a LatencyMarker that arrived on the first input of this two-input operator.
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<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.AbstractInput
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Input
Processes a Watermark that arrived on the first input of this two-input operator.
processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
Processes a Watermark.
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSink
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
Override the base implementation to completely ignore watermarks propagated from upstream, except for the "end of time" watermark.
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.
ProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.
ProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
 
ProcessWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
The context holding window metadata.
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
Projects a Tuple DataStream to the previously selected fields.
projectTuple10() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple11() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple12() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple13() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple14() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple15() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple16() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple17() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple18() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple19() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple2() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple20() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple21() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple22() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple23() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple24() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple25() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple3() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple4() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple5() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple6() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple7() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple8() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple9() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTupleX() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Chooses a projectTupleX according to the length of StreamProjection.fieldIndexes.
Provider(OperatorID, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
 
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.
PushingAsyncDataInput<T> - Interface in org.apache.flink.streaming.runtime.io
The variant of PullingAsyncDataInput that is defined for handling both network input and source input in a unified way via PushingAsyncDataInput.emitNext(DataOutput) instead of returning Optional.empty() via PullingAsyncDataInput.pollNext().
PushingAsyncDataInput.DataOutput<T> - Interface in org.apache.flink.streaming.runtime.io
Basic data output interface used in emitting the next element from data input.
put(K, V) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts the given value, mapped under the given key.
put(Mail) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Enqueues the given mail to the mailbox and blocks until there is capacity for a successful put.
put(Mail) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
putFirst(Mail) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Adds the given action to the head of the mailbox.
putFirst(Mail) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
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.

Q

QueryableAppendingStateOperator<IN> - Class in org.apache.flink.streaming.api.functions.query
Internal operator handling queryable AppendingState instances.
QueryableAppendingStateOperator(String, StateDescriptor<? extends AppendingState<IN, ?>, ?>) - Constructor for class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
 
QueryableStateStream<K,V> - Class in org.apache.flink.streaming.api.datastream
Queryable state stream instance.
QueryableStateStream(String, StateDescriptor<?, V>, TypeSerializer<K>) - Constructor for class org.apache.flink.streaming.api.datastream.QueryableStateStream
Creates a queryable state stream.
QueryableValueStateOperator<IN> - Class in org.apache.flink.streaming.api.functions.query
Internal operator handling queryable ValueState instances.
QueryableValueStateOperator(String, StateDescriptor<ValueState<IN>, IN>) - Constructor for class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
 
quiesce() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Quiesce the mailbox.
quiesce() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
quiesce() - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
This method puts the service into a state where it does not register new timers, but returns for each call to ProcessingTimeService.registerTimer(long, org.apache.flink.streaming.runtime.tasks.ProcessingTimeCallback) or ProcessingTimeService.scheduleAtFixedRate(org.apache.flink.streaming.runtime.tasks.ProcessingTimeCallback, long, long) a "mock" future and the "mock" future will be never completed.
quiesce() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
quiesce() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 

R

random - Variable in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
RandomGenerator<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
Random generator.
RandomGenerator() - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
rawKeyedStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.
rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
rawOperatorStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to this stream operator.
rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
read(DataInputView, boolean) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
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
Deprecated.
Use FileInputFormat.setFilesFilter(FilePathFilter) to set a filter and StreamExecutionEnvironment.readFile(FileInputFormat, String, FileProcessingMode, long)
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
ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
 
ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.ReadOnlyContext
 
ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
 
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.
readTimersSnapshot(DataInputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader
Reads a timers snapshot from the provided input view.
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
Implementation of Output that sends data using a RecordWriter.
RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, OutputTag, StreamStatusProvider) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
recoverAndAbort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Abort a transaction that was rejected by a coordinator after a failure.
recoverAndCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Invoked on recovered transactions after a failure.
recoverPendingFile(InProgressFileWriter.PendingFileRecoverable) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter
Recovers a pending file for finalizing and committing.
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>, ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessAllWindowFunction<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(ReduceFunction<T>, ProcessWindowFunction<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>, ProcessWindowFunction<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
Internal AllWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
ReduceApplyProcessAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal ProcessAllWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyProcessAllWindowFunction(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
ReduceApplyProcessWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal ProcessWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyProcessWindowFunction(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal WindowFunction that is used for implementing a fold on a window configuration that only allows WindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
 
registerCachedFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
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 interface org.apache.flink.streaming.api.operators.InternalTimerService
Registers a timer to be fired when event time watermark passes the given time.
registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
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
 
registerJobListener(JobListener) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Register a JobListener in this environment.
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(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
 
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
 
registerTimer(long, ProcessingTimeCallback) - Method in interface 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.
reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
Reinterprets the given DataStream as a KeyedStream, which extracts keys with the given KeySelector.
reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
Reinterprets the given DataStream as a KeyedStream, which extracts keys with the given KeySelector.
releaseBlocksAndResetBarriers() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierAligner
 
releaseBlocksAndResetBarriers() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
 
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
A StreamExecutionEnvironment for executing on a cluster.
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.
RemoteStreamEnvironment(String, int, Configuration, String[], URL[], SavepointRestoreSettings) - 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(PipelineExecutorServiceLoader, String, int, Configuration, String[], URL[], SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
remove() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
 
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) - Method in class org.apache.flink.streaming.util.LatencyStats
 
reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.StreamSink
 
reportThrowable(Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Reports a throwable for rethrowing from the mailbox thread.
reportWatermark(Watermark, int) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
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
Deprecated.
Statements to be executed after writing a batch goes here.
resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
Deprecated.
 
resetSplitState() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
Sets the state of the split to null.
resetToCheckpoint(byte[]) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
resolveSchemaCompatibility(TypeSerializer<CoGroupedStreams.TaggedUnion<T1, T2>>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<IntervalJoinOperator.BufferEntry<T>>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<StreamElement>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
Deprecated.
 
restoreFunctionState(StateInitializationContext, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
restoreState(List<T>) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
Deprecated.
Restores the state of the function or operator to that of a previous checkpoint.
restoreStateForKeyGroup(InputStream, int, ClassLoader) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
restoreTimersForKeyGroup(InternalTimersSnapshot<?, ?>, int) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
Restore the timers (both processing and event time ones) for a given keyGroupIdx.
ResultFuture<OUT> - Interface in org.apache.flink.streaming.api.functions.async
ResultFuture collects data / error in user codes while processing async i/o.
resume() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Suspension
Resume execution of the default action.
resumeInProgressFileFrom(BucketID, InProgressFileWriter.InProgressFileRecoverable, long) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketWriter
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.
RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
A RichFunction version of AllWindowFunction.
RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
 
RichAsyncFunction<IN,OUT> - Class in org.apache.flink.streaming.api.functions.async
Rich variant of the AsyncFunction.
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
 
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
 
RichProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
RichProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessAllWindowFunction
Deprecated.
 
RichProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
RichProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessWindowFunction
Deprecated.
 
RichSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
A RichFunction version of SinkFunction.
RichSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
 
RichSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
Base class for implementing a parallel data source that has access to context information (via AbstractRichFunction.getRuntimeContext()) and additional life-cycle methods (AbstractRichFunction.open(org.apache.flink.configuration.Configuration) and AbstractRichFunction.close().
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
Rich variant of the WindowFunction.
RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
 
RollingPolicy<IN,BucketID> - Interface in org.apache.flink.streaming.api.functions.sink.filesystem
The policy based on which a Bucket in the StreamingFileSink rolls its currently open part file and opens a new one.
RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
RowFormatBuilder(Path, Encoder<IN>, BucketAssigner<IN, BucketID>, RollingPolicy<IN, BucketID>, long, BucketFactory<IN, BucketID>, OutputFileConfig) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
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(Object, StreamStatusMaintainer, OperatorChain<?, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
run(Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>, OperatorChain<?, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
run(RunnableWithException) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
run(RunnableWithException) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
Deprecated.
 
runDefaultAction(MailboxDefaultAction.Controller) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction
This method implements the default action of the mailbox loop (e.g.
runExclusively(Runnable) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Runs the given code exclusively on this mailbox.
runExclusively(Runnable) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
runMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
Runs the mailbox processing loop.
runMailboxStep() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
 
runMailboxStep() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
runThrowing(ThrowingRunnable<E>) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
 
runThrowing(ThrowingRunnable<E>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
Deprecated.
 

S

scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in interface 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
 
scheduleWithFixedDelay(ProcessingTimeCallback, long, long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed repeatedly with a fixed delay.
scheduleWithFixedDelay(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
scheduleWithFixedDelay(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
SECOND - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
The InputSelection instance which indicates to select the second input.
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
Method for selecting output names for the emitted objects when using the SingleOutputStreamOperator.split(org.apache.flink.streaming.api.collector.selector.OutputSelector<T>) method.
select(String...) - Method in class org.apache.flink.streaming.api.datastream.SplitStream
Deprecated.
Sets the output names for which the next operator will receive values.
select(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
Selects an input identified by the given inputId.
selectAllOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
Note: Broadcast mode could be handled directly for all the output channels in record writer, so it is no need to select channels via this method.
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
selectChannel(SerializationDelegate<StreamRecord<T>>) - 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(Transformation<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.
self() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy.PolicyBuilder
 
self() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BucketsBuilder
 
sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
Write the given element into the backend.
SequenceGenerator<T> - Class in org.apache.flink.streaming.api.functions.source.datagen
A stateful, re-scalable DataGenerator that emits each number from a given interval exactly once, possibly in parallel.
SequenceGenerator(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
Creates a DataGenerator that emits all numbers from the given interval exactly once.
SerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
Deprecated.
Use SerializationSchema instead.
serialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataOutputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
serialize(String) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.SimpleVersionedStringSerializer
 
serialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
serialize(IntervalJoinOperator.BufferEntry<T>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
serialize(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
 
serialize(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
 
serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.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
Deprecated.
Serializes the incoming element to a specified type.
serializeAccumulatorResult(long, String, long, List<T>, TypeSerializer<T>) - Static method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
SERIALIZEDUDF - Static variable in class org.apache.flink.streaming.api.graph.StreamConfig
 
Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
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
 
sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
SessionWindowTimeGapExtractor<T> - Interface in org.apache.flink.streaming.api.windowing.assigners
A SessionWindowTimeGapExtractor extracts session time gaps for Dynamic Session Window Assigners.
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
 
setAllVerticesInSameSlotSharingGroupByDefault(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Set whether to put all vertices into the same slot sharing group by default.
setBucketLifeCycleListener(BucketLifeCycleListener<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the buffering timeout for data produced by this operation.
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
 
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
 
setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
Deprecated.
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
Set the chaining strategy for operator factory.
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
Sets the chaining strategy of this Transformation.
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.TwoInputTransformation
 
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.
setCheckpointTrigger(ExternallyInducedSource.CheckpointTrigger) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource
Sets the checkpoint trigger through which the source can trigger the checkpoint.
setCoLocationGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
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
 
setContext(Optional<CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
setCurrentKey(Object) - Method in interface org.apache.flink.streaming.api.operators.KeyContext
 
setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
setCurrentTime(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
setCurrentWatermark(long) - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
setDefaultBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the default parallelism that will be used for the local execution environment created by StreamExecutionEnvironment.createLocalEnvironment().
setEventTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setFailOnCheckpointingErrors(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
setForceCheckpointing(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Deprecated.
This will be removed once iterations properly participate in checkpointing.
setGlobalDataExchangeMode(GlobalDataExchangeMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setGlobalDataExchangeMode(GlobalDataExchangeMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
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
Deprecated.
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
setInternalIndex(int) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setJobClient(JobClient) - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
 
setJobClient(JobClient) - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
 
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
 
setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setKeyContextElement(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractInput
 
setKeyContextElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.Input
 
setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setKeyContextElement1(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
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 class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setKeyedStateStore(KeyedStateStore) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
setKeySerializerSnapshot(TypeSerializerSnapshot<K>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setMailboxExecutor(MailboxExecutor) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
setMailboxExecutor(MailboxExecutor) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperatorFactory
 
setMailboxExecutor(MailboxExecutor) - Method in interface org.apache.flink.streaming.api.operators.YieldingOperatorFactory
 
setManagedMemoryFraction(double) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setManagedMemoryWeight(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setManagedMemoryWeight(int) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
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
 
setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the minimal pause between checkpointing attempts.
setMultipleInputStateKey(Integer, List<KeySelector<?, ?>>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setNamespaceSerializerSnapshot(TypeSerializerSnapshot<N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
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
Deprecated.
This method will be replaced by StreamExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.fixedDelayRestart(int, Time) contains the number of execution retries.
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
 
setOperatorEventGateway(OperatorEventGateway) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
setOperatorID(OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
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
 
setOutputFormat(Integer, OutputFormat<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setOutputFormat(OutputFormat<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
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(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
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
Is called by the org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, String, StreamOperator, TypeInformation, TypeInformation, String) method when the StreamGraph is generated.
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
setOutputType(Function, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
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.operators.collect.CollectStreamSink
 
setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
setPendingCommitTransactions(List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setPendingTransaction(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
setPreferCheckpointForRecovery(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets whether a job recovery should fallback to checkpoint when there is a more recent savepoint.
setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Deprecated.
The ProcessingTimeService instance should be passed by the operator constructor and this method will be removed along with SetupableStreamOperator.
setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
 
setProcessingTimeService(ProcessingTimeService) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceAware
 
setProcessingTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
 
setResources(int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the restart strategy configuration.
setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
Deprecated.
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setScheduleMode(ScheduleMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setScheduleMode(ScheduleMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
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
 
setSerializersIn(TypeSerializer<?>...) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setSplitState(Serializable) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Sets the state of the split.
setSplitState(Serializable) - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
Sets the state of the split.
setStateBackend(StateBackend) - 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.environment.StreamExecutionEnvironment
setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
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
 
setStatePartitioners(KeySelector<?, ?>...) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setStreamOperatorFactory(StreamOperatorFactory<?>) - 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.
setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
setTolerableCheckpointFailureNumber(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Set the tolerable checkpoint failure number, the default value is 0 that means we do not tolerance any checkpoint failure.
setTransactionTimeout(long) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Sets the transaction timeout.
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
 
setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializersIn(TypeSerializer<?>...) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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.operators.collect.CollectStreamSink
 
setUnalignedCheckpointsEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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.SetupableStreamOperator
Deprecated.
Initializes the operator.
setup(int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
setup(int) - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
SetupableStreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
Deprecated.
This class is deprecated in favour of using StreamOperatorFactory and it's StreamOperatorFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<OUT>) and passing the required parameters to the Operator's constructor in create method.
setupNumRecordsInCounter(StreamOperator) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
setUserArtifacts(Collection<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setUserArtifacts(Collection<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
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
 
shortGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
shortGenerator(short, short) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
shouldRollOnCheckpoint(PartFileInfo<BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy
 
shouldRollOnCheckpoint(PartFileInfo<BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
 
shouldRollOnCheckpoint(PartFileInfo<BucketID>) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.RollingPolicy
Determines if the in-progress part file for a bucket should roll on every checkpoint.
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy
 
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
 
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
shouldRollOnEvent(PartFileInfo<BucketID>, IN) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.RollingPolicy
Determines if the in-progress part file for a bucket should roll based on its current state, e.g.
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.CheckpointRollingPolicy
 
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy
 
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.OnCheckpointRollingPolicy
 
shouldRollOnProcessingTime(PartFileInfo<BucketID>, long) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.RollingPolicy
Determines if the in-progress part file for a bucket should roll based on a time condition.
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.
ShuffleMode - Enum in org.apache.flink.streaming.api.transformations
The shuffle mode defines the data exchange mode between operators.
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.SystemProcessingTimeService
 
shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
shutdownService() - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
Shuts down and clean up the timer service provider hard and immediately.
shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
shutdownServiceUninterruptible(long) - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
Shuts down and clean up the timer service provider hard and immediately.
SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
sideOutput(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Write skipped late arriving element to SideOutput.
sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Send late arriving data to the side output identified by the given OutputTag.
sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Send late arriving data to the side output identified by the given OutputTag.
SideOutputTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a selection of a side output of an upstream operation with a given OutputTag.
SideOutputTransformation(Transformation<?>, OutputTag<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
SimpleInputFormatOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
Input format source operator factory which just wrap existed StreamSource.
SimpleInputFormatOperatorFactory(StreamSource<OUT, InputFormatSourceFunction<OUT>>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
 
SimpleOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
Simple factory which just wrap existed StreamOperator.
SimpleOperatorFactory(StreamOperator<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
 
SimpleOutputFormatOperatorFactory<IN> - Class in org.apache.flink.streaming.api.operators
A simple operator factory which create StreamSink containing an OutputFormat.
SimpleOutputFormatOperatorFactory(StreamSink<IN>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
 
SimpleStringSchema - Class in org.apache.flink.streaming.util.serialization
Deprecated.
Use SimpleStringSchema instead.
SimpleStringSchema() - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
Deprecated.
 
SimpleStringSchema(Charset) - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
Deprecated.
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
SimpleTimerService - Class in org.apache.flink.streaming.api
Implementation of TimerService that uses a InternalTimerService.
SimpleTimerService(InternalTimerService<VoidNamespace>) - Constructor for class org.apache.flink.streaming.api.SimpleTimerService
 
SimpleUdfStreamOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
Udf stream operator factory which just wrap existed AbstractUdfStreamOperator.
SimpleUdfStreamOperatorFactory(AbstractUdfStreamOperator<OUT, ?>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
 
SimpleVersionedListState<T> - Class in org.apache.flink.streaming.api.operators.util
A ListState that uses a SimpleVersionedSerializer instead of a TypeSerializer.
SimpleVersionedListState(ListState<byte[]>, SimpleVersionedSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
Creates a new SimpleVersionedListState that reads and writes bytes from the given raw ListState with the given serializer.
SimpleVersionedStringSerializer - Class in org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners
A SimpleVersionedSerializer implementation for Strings.
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, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
 
SinkContextUtil - Class in org.apache.flink.streaming.api.functions.sink
Utility for creating Sink Contexts.
SinkContextUtil() - Constructor for class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
 
SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink
Interface for implementing user defined sink functionality.
SinkFunction.Context<T> - Interface in org.apache.flink.streaming.api.functions.sink
Context that SinkFunctions can use for getting additional data about an input record.
SinkTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This Transformation represents a Sink.
SinkTransformation(Transformation<T>, String, StreamSink<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
Creates a new SinkTransformation from the given input Transformation.
SinkTransformation(Transformation<T>, String, StreamOperatorFactory<Object>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
 
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.operators.windowing.KeyMap
Gets the number of elements currently in the map.
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
Deprecated.
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.
slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
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
Deprecated.
Gets the current state of the function.
snapshotState(long, ListState<byte[]>, ListState<Long>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
 
snapshotState(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
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 interface org.apache.flink.streaming.api.functions.source.datagen.DataGenerator
Snapshot state for DataGenerator.
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
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, CheckpointOptions, 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(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
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(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
 
snapshotState(KeyedStateBackend<?>, StateSnapshotContext, String) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
 
snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Called to draw a state snapshot from the operator.
snapshotState(StateSnapshotContext) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
 
snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator, Optional<InternalTimeServiceManager<?>>, String, long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
snapshotStateForKeyGroup(DataOutputView, int) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
snapshotTimersForKeyGroup(int) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
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.
SocketStreamIterator<T> - Class in org.apache.flink.streaming.experimental
An iterator that returns the data from a socket stream.
SocketStreamIterator(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
Creates an iterator that returns the data from a socket stream with automatic port and bind address.
SocketStreamIterator(int, InetAddress, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
Creates an iterator that returns the data from a socket stream with custom port and bind address.
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.
SourceOperator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit> - Class in org.apache.flink.streaming.api.operators
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
SourceOperator(Function<SourceReaderContext, SourceReader<OUT, SplitT>>, OperatorEventGateway, SimpleVersionedSerializer<SplitT>, WatermarkStrategy<OUT>, ProcessingTimeService) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperator
 
SourceOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
The Factory class for SourceOperator.
SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
 
SourceOperatorStreamTask<T> - Class in org.apache.flink.streaming.runtime.tasks
A subclass of StreamTask for executing the SourceOperator.
SourceOperatorStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
 
SourceOutputWithWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
Implementation of the SourceOutput.
SourceOutputWithWatermarks(PushingAsyncDataInput.DataOutput<T>, WatermarkOutput, WatermarkOutput, TimestampAssigner<T>, WatermarkGenerator<T>) - Constructor for class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the (possibly different) WatermarkOutput.
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
StreamTask for executing a StreamSource.
SourceStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
SourceTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
SourceTransformation(String, SourceOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
Creates a new Transformation with the given name, output type and parallelism.
spillInflightBuffers(long, int, ChannelStateWriter) - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Deprecated.
Please use side output instead.
split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
 
SplitStream<OUT> - Class in org.apache.flink.streaming.api.datastream
Deprecated.
SplitStream(DataStream<OUT>, OutputSelector<OUT>) - Constructor for class org.apache.flink.streaming.api.datastream.SplitStream
Deprecated.
 
SplitTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a split of one DataStream into several DataStreams using an OutputSelector.
SplitTransformation(Transformation<T>, OutputSelector<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SplitTransformation
Creates a new SplitTransformation from the given input and OutputSelector.
start() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
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.
startPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.BatchTimestampsAndWatermarks
 
startPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.StreamingTimestampsAndWatermarks
 
startPeriodicWatermarkEmits() - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
Starts emitting periodic watermarks, if this implementation produces watermarks, and if periodic watermarks are configured.
startTimerService(TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
Starts the local InternalTimerServiceImpl 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 recovering from a node failure, if any. This method can be called multiple times, as long as it is called with the same serializers.
state - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
State() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
State(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>, List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>, Optional<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
 
stateBackend - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
Our state backend.
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.
stateKeySelector - Variable in class org.apache.flink.streaming.api.operators.AbstractInput
KeySelector for extracting a key from an element being processed.
stateKeyType - Variable in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
 
StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
StateSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
StateSerializerConfigSnapshot(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
Deprecated.
 
StateSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerSnapshot
 
status - Variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
StatusWatermarkValve - Class in org.apache.flink.streaming.runtime.streamstatus
A StatusWatermarkValve embodies the logic of how Watermark and StreamStatus are propagated to downstream outputs, given a set of one or multiple input channels that continuously receive them.
StatusWatermarkValve(int, PushingAsyncDataInput.DataOutput) - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Returns a new StatusWatermarkValve.
StatusWatermarkValve.InputChannelStatus - Class in org.apache.flink.streaming.runtime.streamstatus
An InputChannelStatus keeps track of an input channel's last watermark, stream status, and whether or not the channel's current watermark is aligned with the overall watermark output from the valve.
STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
stopPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.BatchTimestampsAndWatermarks
 
stopPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.StreamingTimestampsAndWatermarks
 
stopPeriodicWatermarkEmits() - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
Stops emitting periodic watermarks.
Strategy(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPeriodicWatermarksAdapter.Strategy
 
Strategy(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.util.AssignerWithPunctuatedWatermarksAdapter.Strategy
 
StreamConfig - Class in org.apache.flink.streaming.api.graph
Internal configuration for a StreamOperator.
StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
 
StreamEdge - Class in org.apache.flink.streaming.api.graph
An edge in the streaming topology.
StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>, OutputTag) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
 
StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>, OutputTag, ShuffleMode) - 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<OUT> - Interface in org.apache.flink.streaming.api.operators.async.queue
Interface for stream element queues for the AsyncWaitOperator.
StreamElementSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
StreamElementSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
StreamElementSerializer.StreamElementSerializerConfigSnapshot<T> - Class in org.apache.flink.streaming.runtime.streamrecord
StreamElementSerializer.StreamElementSerializerSnapshot<T> - Class in org.apache.flink.streaming.runtime.streamrecord
Configuration snapshot specific to the StreamElementSerializer.
StreamElementSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
StreamElementSerializerSnapshot() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
 
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
 
StreamExecutionEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
StreamExecutionEnvironment(Configuration, ClassLoader) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
StreamExecutionEnvironment(PipelineExecutorServiceLoader, Configuration, ClassLoader) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new StreamExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
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
A StreamOperator for executing FilterFunctions.
StreamFilter(FilterFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFilter
 
StreamFlatMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing FlatMapFunctions.
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(ExecutionConfig, CheckpointConfig, SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
 
StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
A generator that generates a StreamGraph from a graph of Transformations.
StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
StreamGraphHasher - Interface in org.apache.flink.streaming.api.graph
Interface for different implementations of generating hashes over a stream graph.
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
Deprecated.
will be removed in a future version
StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
StreamGroupedReduce<IN> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing a ReduceFunction on a KeyedStream.
StreamGroupedReduce(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
StreamingFileSink<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
Sink that emits its input elements to FileSystem files within buckets.
StreamingFileSink(StreamingFileSink.BucketsBuilder<IN, ?, ? extends StreamingFileSink.BucketsBuilder<IN, ?, ?>>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink
Creates a new StreamingFileSink that writes files to the given base directory with the give buckets properties.
StreamingFileSink.BucketsBuilder<IN,BucketID,T extends StreamingFileSink.BucketsBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
StreamingFileSink.BulkFormatBuilder<IN,BucketID,T extends StreamingFileSink.BulkFormatBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
A builder for configuring the sink for bulk-encoding formats, e.g.
StreamingFileSink.DefaultBulkFormatBuilder<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
Builder for the vanilla StreamingFileSink using a bulk format.
StreamingFileSink.DefaultRowFormatBuilder<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
Builder for the vanilla StreamingFileSink using a row format.
StreamingFileSink.RowFormatBuilder<IN,BucketID,T extends StreamingFileSink.RowFormatBuilder<IN,BucketID,T>> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
A builder for configuring the sink for row-wise encoding formats.
StreamingFileSinkHelper<IN> - Class in org.apache.flink.streaming.api.functions.sink.filesystem
Helper for StreamingFileSink.
StreamingFileSinkHelper(Buckets<IN, ?>, boolean, OperatorStateStore, ProcessingTimeService, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper
 
StreamingFunctionUtils - Class in org.apache.flink.streaming.util.functions
Utility class that contains helper methods to work with Flink Streaming Functions.
StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
The StreamingJobGraphGenerator converts a StreamGraph into a JobGraph.
StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
Implementation of the RuntimeContext, for streaming operators.
StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
StreamingRuntimeContext(Environment, Map<String, Accumulator<?, ?>>, MetricGroup, OperatorID, ProcessingTimeService, KeyedStateStore, ExternalResourceInfoProvider) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
StreamingTimestampsAndWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
An implementation of timestamp extraction and watermark generation logic for streaming sources.
StreamingTimestampsAndWatermarks(TimestampAssigner<T>, WatermarkGeneratorSupplier<T>, WatermarkGeneratorSupplier.Context, ProcessingTimeService, Duration) - Constructor for class org.apache.flink.streaming.api.operators.source.StreamingTimestampsAndWatermarks
 
StreamInputProcessor - Interface in org.apache.flink.streaming.runtime.io
Interface for processing records by StreamTask.
StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
A special StreamTask that is used for executing feedback edges.
StreamIterationHead(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
A special StreamTask that is used for executing feedback edges.
StreamIterationTail(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
 
StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing MapFunctions.
StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
 
StreamMultipleInputProcessor - Class in org.apache.flink.streaming.runtime.io
Input processor for MultipleInputStreamOperator.
StreamMultipleInputProcessor(CheckpointedInputGate[], TypeSerializer<?>[], IOManager, StreamStatusMaintainer, MultipleInputStreamOperator<?>, MultipleInputSelectionHandler, WatermarkGauge[], OperatorChain<?, ?>, Counter) - Constructor for class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
 
StreamNode - Class in org.apache.flink.streaming.api.graph
Class representing the operators in the streaming programs, with all their properties.
StreamNode(Integer, String, String, StreamOperator<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
 
StreamNode(Integer, String, String, StreamOperatorFactory<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
 
StreamOneInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
Input reader for OneInputStreamTask.
StreamOneInputProcessor(StreamTaskInput<IN>, PushingAsyncDataInput.DataOutput<IN>, OperatorChain<?, ?>) - Constructor for class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
 
StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
Basic interface for stream operators.
StreamOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
A factory to create StreamOperator.
StreamOperatorFactoryUtil - Class in org.apache.flink.streaming.api.operators
A utility to instantiate new operators with a given factory.
StreamOperatorFactoryUtil() - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
 
StreamOperatorParameters<OUT> - Class in org.apache.flink.streaming.api.operators
Helper class to construct AbstractStreamOperatorV2.
StreamOperatorParameters(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>, Supplier<ProcessingTimeService>, OperatorEventDispatcher) - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorParameters
 
StreamOperatorStateContext - Interface in org.apache.flink.streaming.api.operators
This interface represents a context from which a stream operator can initialize everything connected to state such as e.g.
streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup) - Method in interface org.apache.flink.streaming.api.operators.StreamTaskStateInitializer
Returns the StreamOperatorStateContext for an AbstractStreamOperator that runs in the stream task that owns this manager.
streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamOperatorStateHandler - Class in org.apache.flink.streaming.api.operators
Class encapsulating various state backend handling logic for StreamOperator implementations.
StreamOperatorStateHandler(StreamOperatorStateContext, ExecutionConfig, CloseableRegistry) - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
 
StreamOperatorStateHandler.CheckpointedStreamOperator - Interface in org.apache.flink.streaming.api.operators
Custom state handling hooks to be invoked by StreamOperatorStateHandler.
StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
This class handles the close, endInput and other related logic of a StreamOperator.
StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
A special ChannelSelector for use in streaming programs.
StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
StreamPipelineOptions - Class in org.apache.flink.streaming.api.environment
The configuration options for job execution.
StreamPipelineOptions() - Constructor for class org.apache.flink.streaming.api.environment.StreamPipelineOptions
 
StreamProject<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing projections on streams.
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.
StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing SinkFunctions.
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
StreamOperator for streaming sources.
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
 
streamStatus - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
StreamStatus - Class in org.apache.flink.streaming.runtime.streamstatus
A Stream Status element informs stream tasks whether or not they should continue to expect records and watermarks from the input stream that sent them.
StreamStatus(int) - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
streamStatusMaintainer - Variable in class org.apache.flink.streaming.runtime.io.AbstractDataOutput
The maintainer toggles the current stream status.
StreamStatusMaintainer - Interface in org.apache.flink.streaming.runtime.streamstatus
Interface that allows toggling the current StreamStatus as well as retrieving it.
StreamStatusProvider - Interface in org.apache.flink.streaming.runtime.streamstatus
Interface for retrieving the current StreamStatus.
StreamTask<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
Base class for all streaming tasks.
StreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask(Environment, TimerService) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
 
StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor, TaskMailbox) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
 
StreamTaskActionExecutor - Interface in org.apache.flink.streaming.runtime.tasks
Executes Runnable, ThrowingRunnable, or Callable.
StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor - Class in org.apache.flink.streaming.runtime.tasks
Deprecated.
this class should only be used in SourceStreamTask which exposes the checkpoint lock as part of Public API.
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.
StreamTaskInput<T> - Interface in org.apache.flink.streaming.runtime.io
Basic interface for inputs of stream operators.
StreamTaskNetworkInput<T> - Class in org.apache.flink.streaming.runtime.io
Implementation of StreamTaskInput that wraps an input from network taken from CheckpointedInputGate.
StreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<?>, IOManager, StatusWatermarkValve, int) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
 
StreamTaskSourceInput<T> - Class in org.apache.flink.streaming.runtime.io
Implementation of StreamTaskInput that reads data from the SourceOperator and returns the InputStatus to indicate whether the source state is available, unavailable or finished.
StreamTaskSourceInput(SourceOperator<T, ?>) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
 
StreamTaskStateInitializer - Interface in org.apache.flink.streaming.api.operators
This is the interface through which stream task expose a StreamOperatorStateContext to their operators.
StreamTaskStateInitializerImpl - Class in org.apache.flink.streaming.api.operators
This class is the main implementation of a StreamTaskStateInitializer.
StreamTaskStateInitializerImpl(Environment, StateBackend) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamTaskStateInitializerImpl(Environment, StateBackend, TtlTimeProvider) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
 
StreamTwoInputProcessor<IN1,IN2> - Class in org.apache.flink.streaming.runtime.io
Input reader for TwoInputStreamTask.
StreamTwoInputProcessor(CheckpointedInputGate[], TypeSerializer<IN1>, TypeSerializer<IN2>, IOManager, StreamStatusMaintainer, TwoInputStreamOperator<IN1, IN2, ?>, TwoInputSelectionHandler, WatermarkGauge, WatermarkGauge, OperatorChain<?, ?>, Counter) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
stringGenerator(int) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.RandomGenerator
 
stringGenerator(long, long) - Static method in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
submit(RunnableWithException, String, Object...) - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(RunnableWithException, String) - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(Callable<T>, String, Object...) - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(Callable<T>, String) - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
SubtaskCheckpointCoordinator - Interface in org.apache.flink.streaming.runtime.tasks
Coordinates checkpointing-related work for a subtask (i.e.
subtaskFailed(int, Throwable) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
 
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
An AggregationFunction that sums up fields.
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
Internal function for summing up contents of fields.
SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
suspendDefaultAction() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
Calling this method signals that the mailbox-thread should (temporarily) stop invoking the default action, e.g.
suspendDefaultAction() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
 
synchronizedExecutor() - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
Returns an ExecutionDecorator that synchronizes each invocation.
synchronizedExecutor(Object) - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
Returns an ExecutionDecorator that synchronizes each invocation on a given object.
SynchronizedStreamTaskActionExecutor(Object) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
Deprecated.
 
SystemProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
A TimerService which assigns as current processing time the result of calling System.currentTimeMillis() and registers timers using a ScheduledThreadPoolExecutor.

T

take(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
This method returns the oldest mail from the mailbox (head of queue) or blocks until a mail is available.
take(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
TaskMailbox - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
A task mailbox provides read and write access to a mailbox and has a lifecycle of open -> (quiesced) -> closed.
TaskMailbox.State - Enum in org.apache.flink.streaming.runtime.tasks.mailbox
This enum represents the states of the mailbox lifecycle.
TaskMailboxImpl - Class in org.apache.flink.streaming.runtime.tasks.mailbox
Implementation of TaskMailbox in a BlockingQueue fashion and tailored towards our use case with multiple writers and single reader.
TaskMailboxImpl(Thread) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
TaskMailboxImpl() - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
TestProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
This is a TimerService and ProcessingTimeService used strictly for testing the processing time functionality.
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.
TIME_CHARACTERISTIC - Static variable in class org.apache.flink.streaming.api.environment.StreamPipelineOptions
 
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 class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
The TimeDomain of the firing timer, i.e.
timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
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
 
timeout(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
TIMER_COMPARATOR - Static variable in interface org.apache.flink.streaming.api.operators.InternalTimer
Function to compare instances of InternalTimer.
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
 
TimerHeapInternalTimer<K,N> - Class in org.apache.flink.streaming.api.operators
Implementation of InternalTimer to use with a HeapPriorityQueueSet.
TimerHeapInternalTimer(long, K, N) - Constructor for class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
TimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
A serializer for TimerHeapInternalTimer objects that produces a serialization format that is lexicographically aligned the priority of the timers.
TimerSerializer(TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializer
 
TimerSerializer.TimerSerializerConfigSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards compatibility purposes. It is fully replaced by TimerSerializerSnapshot.
TimerSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
Deprecated.
 
TimerSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
Deprecated.
 
TimerSerializerSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
Snapshot class for the TimerSerializer.
TimerSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
TimerSerializerSnapshot(TimerSerializer<K, N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
 
timerService() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
A TimerService for querying time and registering timers.
timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
A TimerService for querying time and registering timers.
TimerService - Interface in org.apache.flink.streaming.api
Interface for working with time and timers.
timerService - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The internal TimerService used to define the current processing time (default = System.currentTimeMillis()) and register timers for tasks to be executed in the future.
TimerService - Interface in org.apache.flink.streaming.runtime.tasks
A common timer service interface with life cycle methods.
timestamp() - Method in class 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 class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner.Context
Returns the timestamp of the current input record or null if the element does not have an assigned timestamp.
timestamp() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
Returns the timestamp of the current input record or null if the element does not have an assigned timestamp.
timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
TimestampAssigner<T> - Interface in org.apache.flink.streaming.api.functions
Deprecated.
use TimestampAssigner
TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
Wrapper around an Output for user functions that expect a Output.
TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
Creates a new TimestampedCollector that wraps the given Output.
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
A FileInputSplit with TimestampedInputSplit.
TimestampedFileInputSplit(long, int, Path, long, long, String[]) - Constructor for class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Creates a TimestampedFileInputSplit based on the file modification time and the rest of the information of the FileInputSplit, as returned by the underlying filesystem.
TimestampedInputSplit - Interface in org.apache.flink.streaming.api.functions.source
An extended InputSplit that also includes information about: The modification time of the file this split belongs to. When checkpointing, the state of the split at the moment of the checkpoint. This class is used by the ContinuousFileMonitoringFunction and the ContinuousFileReaderOperator to perform continuous file processing.
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.
TimestampsAndWatermarks<T> - Interface in org.apache.flink.streaming.api.operators.source
Basic interface for the timestamp extraction and watermark generation logic for the SourceReader.
TimestampsAndWatermarksContext - Class in org.apache.flink.streaming.api.operators.source
A simple implementation of a context that is both TimestampAssignerSupplier.Context and WatermarkGeneratorSupplier.Context.
TimestampsAndWatermarksContext(MetricGroup) - Constructor for class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
 
TimestampsAndWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
A stream operator that may do one or both of the following: extract timestamps from events and generate watermarks.
TimestampsAndWatermarksOperator(WatermarkStrategy<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
 
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 end (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
The serializer used to write the TimeWindow type.
TimeWindow.Serializer.TimeWindowSerializerSnapshot - Class in org.apache.flink.streaming.api.windowing.windows
Serializer configuration snapshot for compatibility and format evolution.
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.
TimeWindowSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer.TimeWindowSerializerSnapshot
 
toggleStreamStatus(StreamStatus) - Method in interface org.apache.flink.streaming.runtime.streamstatus.StreamStatusMaintainer
Toggles the current stream status.
toggleStreamStatus(StreamStatus) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
TOLERABLE_FAILURE_NUMBER - Static variable in class org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions
 
toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Converts the time interval to milliseconds.
toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
toString() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner
 
toString() - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner
 
toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
toString() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
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.InputSelection
 
toString() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
 
toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
 
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.CheckpointBarrierAligner
 
toString() - Method in class org.apache.flink.streaming.runtime.io.CheckpointBarrierUnaligner
 
toString() - Method in class org.apache.flink.streaming.runtime.io.CheckpointedInputGate
 
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.operators.windowing.WindowOperator.WindowContext
 
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 class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
toString() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
 
TransactionHolder(TXN, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
 
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>, OneInputStreamOperatorFactory<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Method for passing user defined operators created by the given factory along with the type information that will transform the DataStream.
transform(AbstractMultipleInputTransformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.MultipleConnectedStreams
 
transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
 
transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
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 interface org.apache.flink.streaming.api.graph.StreamGraphHasher
Returns a map with a hash for each StreamNode of the StreamGraph.
traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
Returns a map with a hash for each StreamNode of the StreamGraph.
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.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
Interface for things that can be called by InternalTimerService.
triggerCheckpoint(long) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource.CheckpointTrigger
Triggers a checkpoint.
triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions, boolean) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions, boolean) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
Result type for trigger methods.
tryCancel(boolean) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
 
tryPut(StreamElement) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
tryPut(StreamElement) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Tries to put the given element in the queue.
tryPut(StreamElement) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
tryTake(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns an optional with either the oldest mail from the mailbox (head of queue) if the mailbox is not empty or an empty optional otherwise.
tryTake(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
tryTakeFromBatch() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
Returns an optional with either the oldest mail from the batch (head of queue) if the batch is not empty or an empty optional otherwise.
tryTakeFromBatch() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
 
tryYield() - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
This methods attempts to run the command at the head of the mailbox.
tryYield() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
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
Deprecated.
tupleList - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Deprecated.
 
two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
TwoInputSelectionHandler - Class in org.apache.flink.streaming.runtime.io
This handler is mainly used for selecting the next available input index in StreamTwoInputProcessor.
TwoInputSelectionHandler(InputSelectable) - Constructor for class org.apache.flink.streaming.runtime.io.TwoInputSelectionHandler
 
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
A StreamTask for executing a TwoInputStreamOperator and supporting the TwoInputStreamOperator to select input for reading.
TwoInputStreamTask(Environment) - 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 Transformations.
TwoInputTransformation(Transformation<IN1>, Transformation<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.
TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
This is a recommended base class for all of the SinkFunction that intend to implement exactly-once semantic.
TwoPhaseCommitSinkFunction(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Use default ListStateDescriptor for internal state serialization.
TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
Custom TypeSerializer for the sink state.
TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards compatibility purposes. It is fully replaced by TwoPhaseCommitSinkFunction.StateSerializerSnapshot.
TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
TwoPhaseCommitSinkFunction.TransactionHolder<TXN> - Class in org.apache.flink.streaming.api.functions.sink
Adds metadata (currently only the start time of the transaction) to the transaction object.
TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
TypeInformationSerializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
Deprecated.
Use TypeInformationSerializationSchema instead.
TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
Deprecated.
Creates a new de-/serialization schema for the given type.

U

UdfStreamOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
Udf stream operator factory.
uid(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets an ID for this operator.
uid(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets an ID for this operator.
uid(String) - Method in class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
 
UNDEFINED_TOLERABLE_CHECKPOINT_NUMBER - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
 
union(DataStream<T>...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a new DataStream by merging DataStream outputs of the same type with each other.
UnionSerializer(TypeSerializer<T1>, TypeSerializer<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
 
UnionSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
UnionSerializerConfigSnapshot(TypeSerializer<T1>, TypeSerializer<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
Deprecated.
 
UnionSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
 
UnionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a union of several input Transformations.
UnionTransformation(List<Transformation<T>>) - Constructor for class org.apache.flink.streaming.api.transformations.UnionTransformation
Creates a new UnionTransformation from the given input Transformations.
UnorderedStreamElementQueue<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
Unordered implementation of the StreamElementQueue.
UnorderedStreamElementQueue(int) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
UNSPECIFIED - Static variable in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
 
UNSUPPORTED_DELETE_TIMER_MSG - Static variable in interface org.apache.flink.streaming.api.TimerService
Error string for UnsupportedOperationException on deleting timers.
UNSUPPORTED_REGISTER_TIMER_MSG - Static variable in interface org.apache.flink.streaming.api.TimerService
Error string for UnsupportedOperationException on registering timers.
UnsupportedTimeCharacteristicException - Exception in org.apache.flink.streaming.api.datastream
An exception that indicates that a time characteristic was used that is not supported in the current operation.
UnsupportedTimeCharacteristicException(String) - Constructor for exception org.apache.flink.streaming.api.datastream.UnsupportedTimeCharacteristicException
 
update(List<T>) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
 
updateCondition() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Deprecated.
Condition for writing the contents of tupleList and clearing it.
updateCondition() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
Deprecated.
 
updateStatus(InputStatus, int) - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
 
upperBoundExclusive() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
Set the upper bound to be exclusive.
userContext - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
 
userFunction - Variable in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
The user function.

V

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.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.graph.GlobalDataExchangeMode
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.transformations.ShuffleMode
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.
valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
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.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() - Static method in enum org.apache.flink.streaming.api.graph.GlobalDataExchangeMode
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
Returns the collection of StreamElement currently contained in this queue for checkpointing.
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.transformations.ShuffleMode
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.
values() - Static method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
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.util.LatencyStats.Granularity
Returns an array containing the constants of this enum type, in the order they are declared.
valuesToEmit - Variable in class org.apache.flink.streaming.api.functions.source.datagen.SequenceGenerator
 
VERSION - Static variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
 

W

Watermark - Class in org.apache.flink.streaming.api.watermark
A Watermark tells operators 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.
watermark - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
watermarkGauge - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
WatermarkGauge - Class in org.apache.flink.streaming.runtime.metrics
A Gauge for exposing the current input/output watermark.
WatermarkGauge() - Constructor for class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
 
WatermarkToDataOutput - Class in org.apache.flink.streaming.api.operators.source
An adapter that exposes a WatermarkOutput based on a PushingAsyncDataInput.DataOutput.
WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>) - Constructor for class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
Creates a new WatermarkOutput against the given DataOutput.
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>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
Specifies a KeySelector for elements from the first input with explicit type information.
where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
Specifies a KeySelector for elements from the first input.
where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
Specifies a KeySelector for elements from the first input with explicit type information for the key type.
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() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
 
window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the window that is being evaluated.
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() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
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
 
window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Windows this data stream to a AllWindowedStream, which evaluates windows over a non 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.
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
 
WindowContext(W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
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
An operator that implements the logic for windowing based on a WindowAssigner and Trigger.
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, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Creates a new WindowOperator based on the given policies and user functions.
WindowOperator.AbstractPerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
Base class for per-window KeyedStateStores.
WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
Context is a utility for handling Trigger invocations.
WindowOperator.MergingWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
Special WindowOperator.AbstractPerWindowStateStore that doesn't allow access to per-window state.
WindowOperator.PerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
Regular per-window state store for use with ProcessWindowFunction.
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.WindowContext - Class in org.apache.flink.streaming.runtime.operators.windowing
A utility class for handling ProcessWindowFunction invocations.
windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the window in checkpoints.
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
windowState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
windowState - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
with(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Deprecated.
This method will be removed once the CoGroupedStreams.WithWindow.apply(CoGroupFunction) method is fixed in the next major version of Flink (2.0).
with(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Deprecated.
This method will be removed once the CoGroupedStreams.WithWindow.apply(CoGroupFunction, TypeInformation) method is fixed in the next major version of Flink (2.0).
with(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Deprecated.
This method will be removed once the JoinedStreams.WithWindow.apply(JoinFunction) method is fixed in the next major version of Flink (2.0).
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
Deprecated.
This method will be removed once the JoinedStreams.WithWindow.apply(FlatJoinFunction) method is fixed in the next major version of Flink (2.0).
with(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Deprecated.
This method will be removed once the JoinedStreams.WithWindow.apply(JoinFunction, TypeInformation) method is fixed in the next major version of Flink (2.0).
withBucketAssigner(BucketAssigner<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
withBucketAssigner(BucketAssigner<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withBucketCheckInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
withBucketCheckInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
Creates a new SessionWindows WindowAssigner that assigns elements to sessions based on the element timestamp.
withDynamicGap(SessionWindowTimeGapExtractor<T>) - Static method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
Creates a new SessionWindows WindowAssigner that assigns elements to sessions based on the element timestamp.
withDynamicGap(SessionWindowTimeGapExtractor<T>) - 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.
withDynamicGap(SessionWindowTimeGapExtractor<T>) - 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.
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(TypeHint<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.
withInactivityInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Sets the interval of allowed inactivity after which a part file will have to roll.
WithMasterCheckpointHook<E> - Interface in org.apache.flink.streaming.api.checkpoint
This interface can be implemented by streaming functions that need to trigger a "global action" on the master (in the checkpoint coordinator) as part of every checkpoint and restore operation.
withMaxPartSize(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Sets the part size above which a part file will have to roll.
withNewBucketAssigner(BucketAssigner<IN, ID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
withNewBucketAssignerAndPolicy(BucketAssigner<IN, ID>, RollingPolicy<IN, ID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withOutputFileConfig(OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
withOutputFileConfig(OutputFileConfig) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withPartPrefix(String) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig.OutputFileConfigBuilder
 
withPartSuffix(String) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.OutputFileConfig.OutputFileConfigBuilder
 
withRollingPolicy(CheckpointRollingPolicy<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder
 
withRollingPolicy(RollingPolicy<IN, BucketID>) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder
 
withRolloverInterval(long) - Method in class org.apache.flink.streaming.api.functions.sink.filesystem.rollingpolicies.DefaultRollingPolicy.PolicyBuilder
Sets the max time a part file can stay open before having to roll.
withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Deprecated.
Sets the handler for violations to the ascending timestamp order.
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>, Time) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
 
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>, Time) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
 
write(IN, long) - Method in interface org.apache.flink.streaming.api.functions.sink.filesystem.InProgressFileWriter
Write a element to the part file.
write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormat
Deprecated.
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
Deprecated.
 
write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
Deprecated.
 
write(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
 
writeAsCsv(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Deprecated.
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Deprecated.
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsCsv(String, FileSystem.WriteMode, String, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Deprecated.
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsText(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Deprecated.
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Deprecated.
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.
WriteFormat<IN> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
Please use the StreamingFileSink for writing to files from a streaming program.
WriteFormat() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormat
Deprecated.
 
WriteFormatAsCsv<IN> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
Please use the StreamingFileSink for writing to files from a streaming program.
WriteFormatAsCsv() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
Deprecated.
 
WriteFormatAsText<IN> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
Please use the StreamingFileSink for writing to files from a streaming program.
WriteFormatAsText() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
Deprecated.
 
WriterProperties - Class in org.apache.flink.streaming.api.functions.sink.filesystem
This class describes the property of the BucketWriter.
WriterProperties(SimpleVersionedSerializer<InProgressFileWriter.InProgressFileRecoverable>, SimpleVersionedSerializer<InProgressFileWriter.PendingFileRecoverable>, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.filesystem.WriterProperties
 
WriteSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
Please use the StreamingFileSink for writing to files from a streaming program.
WriteSinkFunction(String, WriteFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Deprecated.
 
WriteSinkFunctionByMillis<IN> - Class in org.apache.flink.streaming.api.functions.sink
Deprecated.
Please use the StreamingFileSink for writing to files from a streaming program.
WriteSinkFunctionByMillis(String, WriteFormat<IN>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
Deprecated.
 
writeTimersSnapshot(DataOutputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter
Writes the timers snapshot to the output view.
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
Deprecated.
Please use the StreamingFileSink explicitly using the DataStream.addSink(SinkFunction) method.

Y

yield() - Method in interface org.apache.flink.streaming.api.operators.MailboxExecutor
This methods starts running the command at the head of the mailbox and is intended to be used by the mailbox thread to yield from a currently ongoing action to another command.
yield() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
 
YieldingOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
An operator that needs access to the MailboxExecutor to yield to downstream operators needs to be created through a factory implementing this interface.
A B C D E F G H I J K L M N O P Q R S T U V W Y 
Skip navigation links

Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.