- AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,STATE,F extends Function> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AbstractAlignedProcessingTimeWindowOperator(F, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<STATE>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- AbstractKeyedTimePanes<Type,Key,Aggregate,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Base class for a multiple key/value maps organized in panes.
- AbstractKeyedTimePanes() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operators.
- AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- AbstractUdfStreamOperator<OUT,F extends Function> - Class in org.apache.flink.streaming.api.operators
-
This is used as the base class for operators that have a user-defined
function.
- AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- AccumulatingKeyedTimePanes<Type,Key,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AccumulatingKeyedTimePanes(KeySelector<Type, Key>, WindowFunction<Type, Result, Key, Window>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
-
- AccumulatingProcessingTimeWindowOperator<KEY,IN,OUT> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AccumulatingProcessingTimeWindowOperator(WindowFunction<IN, OUT, KEY, TimeWindow>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
-
- acknowledgeIDs(long, List<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
This method must be implemented to acknowledge the given set of IDs back to the message queue.
- acknowledgeIDs(long, List<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- acknowledgeSessionIDs(List<SessionId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ByteSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.DoubleSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.FloatSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.IntSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.LongSum
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ShortSum
-
- add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
- add(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Adds a buffer or event to the sequence of spilled buffers and events.
- addCoOperator(Integer, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addEdge(Integer, Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
-
- addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
-
- addFeedbackEdge(StreamTransformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Adds a feedback edge.
- addFeedbackEdge(StreamTransformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Adds a feedback edge.
- addId(UId) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Adds an ID to be stored with the current checkpoint.
- addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addNode(Integer, String, Class<? extends AbstractInvokable>, StreamOperator<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOperator(StreamTransformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- addOperator(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addOutputSelector(Integer, OutputSelector<T>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutputSelector(OutputSelector<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given sink to this DataStream.
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- addSink(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a Data Source to the streaming topology.
- addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to an input with a certain
partitioning.
- addVirtualSelectNode(Integer, Integer, List<String>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to only the outputs
with the selected names.
- aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- AggregatingKeyedTimePanes<Type,Key> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AggregatingKeyedTimePanes(KeySelector<Type, Key>, ReduceFunction<Type>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
-
- AggregatingProcessingTimeWindowOperator<KEY,IN> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- AggregatingProcessingTimeWindowOperator(ReduceFunction<IN>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
-
- AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
-
- AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
-
- 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 a window function to the 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
-
Applies the given window function to each window.
- apply(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.
- apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- 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
-
Applies the given window function to each window.
- apply(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.
- apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- 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<ACC>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<ACC>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction
-
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- apply(KEY, W, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- apply(KEY, W, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Evaluates the window and outputs none or several elements.
- ArrayFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Converts a Tuple to an Object-Array.
- ArrayFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will convert the whole tuple (all
fields in the original order) to an array.
- ArrayFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will combine the fields as specified
in the indexes parameter in an object array.
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
A timestamp assigner and watermark generator for streams where timestamps are monotonously
ascending.
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
-
- AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions
-
Handler that fails the program when timestamp monotony is violated.
- AscendingTimestampExtractor.FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.FailingHandler
-
- AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions
-
Handler that does nothing when timestamp monotony is violated.
- AscendingTimestampExtractor.IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.IgnoringHandler
-
- AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions
-
Handler that only logs violations of timestamp monotony, on WARN log level.
- AscendingTimestampExtractor.LoggingHandler() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.LoggingHandler
-
- AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions
-
Interface for handlers that handle violations of the monotonous ascending timestamps
property.
- 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
-
The AssignerWithPeriodicWatermarks
assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
- AssignerWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
The AssignerWithPunctuatedWatermarks
assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
- assignTimestamps(TimestampExtractor<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and periodically creates
watermarks to signal event time progress.
- assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and periodically creates
watermarks to signal event time progress.
- assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- assignWindows(T, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a Collection
of windows that should be assigned to the element.
- asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a Watermark.
- AsynchronousException - Exception in org.apache.flink.streaming.runtime.tasks
-
RuntimeException
for wrapping exceptions that are thrown in Threads that are not the
main compute Thread.
- AsynchronousException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
-
- 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.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.StreamSource
-
- cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- ChainingStrategy - Enum in org.apache.flink.streaming.api.operators
-
Defines the chaining scheme for the operator.
- checkAndGetNextWatermark(T, long) - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
-
Asks this implementation if it wants to emit a watermark.
- checkCollection(Collection<OUT>, Class<OUT>) - Static method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Verifies that all elements in the collection are non-null, and are of the given class, or
a subclass thereof.
- CheckpointBarrierHandler - Interface in org.apache.flink.streaming.runtime.io
-
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
- 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
-
- Checkpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
-
This method must be implemented by functions that have state that needs to be
checkpointed.
- CheckpointedAsynchronously<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
-
This interface marks a function/operator as asynchronously checkpointed.
- CheckpointingMode - Enum in org.apache.flink.streaming.api
-
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
- checkTimerException() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Invokes the
ClosureCleaner
on the given function if closure cleaning is enabled in the
ExecutionConfig
.
- clean(F) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns a "closure-cleaned" version of the given function.
- cleanFile(String) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Creates target file if it does not exist, cleans it if it exists.
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Cleans up all file resources held by this spilled sequence.
- cleanup() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Cleans up all internally held resources.
- cleanup() - Method in interface org.apache.flink.streaming.runtime.io.StreamingReader
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Remove all registered nodes etc.
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Clears any state that the trigger might still hold for the given window.
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- clearBuffers() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- close() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
-
- 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
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
-
- close() - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
-
- close() - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
-
- close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- close() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Cleans up the current spilling channel and file.
- close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
Closes the writer.
- close() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- closeWith(DataStream<T>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Closes the iteration.
- closeWith(DataStream<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
Closes the iteration.
- CoFeedbackTransformation<F> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- CoFeedbackTransformation(int, TypeInformation<F>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Creates a new CoFeedbackTransformation
from the given input.
- CoFlatMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a flat-map transformation over two
connected streams.
- coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a join operation.
- CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
CoGroupedStreams
represents two
DataStreams
that have been co-grouped.
- CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Creates new CoGroped data streams, which are the first step towards building a streaming co-group.
- CoGroupedStreams.TaggedUnion<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
Internal class for implementing tagged union co-group.
- CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
-
CoGrouped streams that have the key for one side defined.
- CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has
KeySelectors
defined for both inputs.
- CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
- CoGroupedStreams.WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- collect(T) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source.
- collect(T) - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
-
- collect(T) - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
-
- collect(T) - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
-
- collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- collectWithTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source with the given timestamp.
- collectWithTimestamp(T, long) - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
-
- collectWithTimestamp(T, long) - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
-
- collectWithTimestamp(T, long) - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
-
- CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a map() transformation over two
connected streams.
- ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- ComparableAggregator(String, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- Comparator - Class in org.apache.flink.streaming.api.functions.aggregation
-
- Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- ConcatenatedExtract<FROM,OVER,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Combines two extractors which will be executed one after each other.
- ConcatenatedExtract(Extractor<FROM, OVER>, Extractor<OVER, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
Combines two extractors which will be executed one after each other.
- connect(DataStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
-
ConnectedStreams represent two connected streams of (possibly) different data types.
- ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - Constructor for class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- ConnectorSource<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- ConnectorSource(DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.ConnectorSource
-
- CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- context - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- ContinuousEventTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval.
- ContinuousProcessingTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval.
- 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.HashPartitioner
-
- 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.MultiplexingStreamRecordSerializer
-
- copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a copy of this stream record.
- copy(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- copy(StreamRecord<T>, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- copyFromLocal(File, URI) - Static method in class org.apache.flink.streaming.util.HDFSCopyFromLocal
-
- copyTo(T, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Copies this record into the new stream record.
- copyToLocal(URI, File) - Static method in class org.apache.flink.streaming.util.HDFSCopyToLocal
-
- CosineDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the cosine distance between two given vectors.
- CosineDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CosineDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CoStreamFlatMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- CoStreamMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps only a certain amount of elements.
- CountTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the count of elements in a pane reaches the given count.
- countWindow(long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling count windows.
- countWindow(long, long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding count windows.
- countWindowAll(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling count windows.
- countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding count windows.
- create() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
Creates an event-time trigger that fires once the watermark passes the end of the window.
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
Creates a new trigger that fires once system time passes the end of the window.
- create() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer.Factory
-
- create() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer.Factory
-
- create() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer.Factory
-
- create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBufferFactory
-
Creates a new WindowBuffer
.
- create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
-
The factory method; creates the value.
- create(int, TypeInformation<R>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.FieldAccessor
-
- create(String, TypeInformation<R>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.FieldAccessor
-
- 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.
- createExecutionEnvironment() - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
-
Creates a StreamExecutionEnvironment from this factory.
- createInput(InputFormat<OUT, ?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat
.
- createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat
.
- createInputGate(Collection<InputGate>, Collection<InputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInputGate(InputGate[]) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInstance() - Method in class org.apache.flink.streaming.api.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.MultiplexingStreamRecordSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- createIterationSourceAndSink(int, int, int, long, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- createJobGraph() - 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
-
- createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
-
- createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
-
- 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
-
- createStateBackend(String, TypeSerializer<?>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- currentWatermark - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
To keep track of the current watermark so that we can immediately fire if a trigger
registers an event time callback for a timestamp that lies in the past.
- currentWatermark - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
To keep track of the current watermark so that we can immediately fire if a trigger
registers an event time callback for a timestamp that lies in the past.
- 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
-
- DataStream<T> - Class in org.apache.flink.streaming.api.datastream
-
A DataStream represents a stream of elements of the same type.
- DataStream(StreamExecutionEnvironment, StreamTransformation<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
-
- 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.
- 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_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_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
The default timeout of a checkpoint attempt: 10 minutes
- 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.NonKeyedWindowOperator.Context
-
- deleteEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- 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.NonKeyedWindowOperator.Context
-
- 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
-
- 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
-
- DeserializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
-
The deserialization schema describes how to turn the byte messages delivered by certain
data sources (for example Apache Kafka) into data types (Java/Scala objects) that are
processed by Flink.
- 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.MultiplexingStreamRecordSerializer
-
- deserialize(StreamElement, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- deserialize(StreamRecord<T>, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- deserialize(byte[]) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
-
Deserializes the byte message.
- deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
- DirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
-
- DirectedOutput(List<OutputSelector<OUT>>, List<Tuple2<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.
- disableInputCopy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Enable object-reuse for this operator instance.
- 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
-
- discardState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
Discards all the contained states and sets them to null.
- discardState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
-
- 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.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.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- dumpStreamingPlanAsJSON(File) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- duplicate() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- duplicate() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- duplicate() - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- duplicate() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- FeedbackTransformation(StreamTransformation<T>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Creates a new FeedbackTransformation
from the given input.
- FieldAccessor<R,F> - Class in org.apache.flink.streaming.util
-
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.FieldAccessor
-
- FieldAccessor.ArrayFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
-
- FieldAccessor.PojoFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
-
- FieldAccessor.ProductFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
-
- FieldAccessor.SimpleFieldAccessor<R> - Class in org.apache.flink.streaming.util
-
- FieldAccessor.TupleFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
-
- FieldFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of an array.
- FieldFromArray() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the first field (id 0) from the array
- FieldFromArray(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the field with the given id from the array.
- FieldFromTuple<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of a tuple.
- FieldFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the first field (id 0) from the tuple
- FieldFromTuple(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the field with the given id from the tuple.
- FieldsFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts multiple fields from an array and puts them into a new array of the
specified type.
- FieldsFromArray(Class<OUT>, int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
-
Extracts multiple fields from an array and puts them in the given order
into a new array of the specified type.
- FieldsFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts one or more fields of the type Double from a tuple and puts them
into a new double[]
- FieldsFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
-
Extracts one or more fields of the the type Double from a tuple and puts
them into a new double[] (in the specified order).
- FileMonitoringFunction - Class in org.apache.flink.streaming.api.functions.source
-
- FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - Constructor for class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
- FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
- FileSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- FileSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.FileSourceFunction
-
- filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The finalize method shuts down the timer.
- flatMap(CoFlatMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreams
and
maps the output to a common type.
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- flatMap(Tuple3<String, Long, Long>, Collector<String>) - Method in class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
- flatMap1(IN1, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the first of the connected streams.
- flatMap2(IN2, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the second of the connected streams.
- flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- flushOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method should be called before finishing the record emission, to make sure any data
that is still buffered will be sent.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given fold function to each window.
- fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given fold function to each window.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies a fold transformation on the grouped data stream grouped on by
the given key position.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given fold function to each window.
- fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given fold function to each window.
- FoldApplyAllWindowFunction<W extends Window,T,ACC> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, ACC, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- FoldApplyWindowFunction<K,W extends Window,T,ACC> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, ACC, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- FoldingWindowBuffer<T,ACC> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
-
- FoldingWindowBuffer(FoldFunction<T, ACC>, ACC, TypeSerializer<ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- FoldingWindowBuffer(FoldFunction<T, ACC>, StreamRecord<ACC>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- FoldingWindowBuffer.Factory<T,ACC> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
-
- FoldingWindowBuffer.Factory(FoldFunction<T, ACC>, ACC, TypeSerializer<ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer.Factory
-
- format - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- forward() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are forwarded to the local subtask of the next operation.
- ForwardPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that forwards elements only to the locally running downstream operation.
- ForwardPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- 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.
- FromElementsFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
A stream source function that returns a sequence of elements.
- FromElementsFunction(TypeSerializer<T>, T...) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- FromElementsFunction(TypeSerializer<T>, Iterable<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- FromIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
- FromIteratorFunction(Iterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- fromParallelCollection(SplittableIterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- fromParallelCollection(SplittableIterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
- FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- generate(StreamExecutionEnvironment, List<StreamTransformation<?>>) - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
Generates a StreamGraph
by traversing the graph of StreamTransformations
starting from the given transformations.
- generateSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains a sequence of numbers.
- 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(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.ArrayFieldAccessor
-
- get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor
-
- get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.PojoFieldAccessor
-
- get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.ProductFieldAccessor
-
- get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.SimpleFieldAccessor
-
- get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.TupleFieldAccessor
-
- getAccumulatorMap() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBrokerID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum time frequency (milliseconds) for the flushing of the
output buffers.
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the buffer timeout of the job
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the buffer timeout of this StreamTransformation
.
- getChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainEntryPoint() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getCheckpointBarrierListener() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the checkpoint config, which defines values like checkpoint interval, delay between
checkpoints, etc.
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the checkpointing mode (exactly-once vs.
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing mode (exactly-once vs.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the interval in which checkpoints are periodically scheduled.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing interval or -1 if checkpointing is disabled.
- getCheckpointLock() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Returns the checkpoint lock.
- getCheckpointLock() - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
-
- getCheckpointLock() - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
-
- getCheckpointLock() - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
-
- getCheckpointLock() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the lock object on which all operations that involve data and state mutation have to lock.
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the checkpointing mode
- getCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum time that a checkpoint may take before being discarded.
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config object.
- getConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getConfiguration() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getCurrentCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
Gets the ID defining the current pending, or just completed, checkpoint.
- 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 class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
-
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.TimestampExtractor
-
Deprecated.
Returns the current watermark.
- getCurrentWatermark() - Method in 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.NonKeyedWindowOperator.Context
-
- getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- 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.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.
- getElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- getElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
-
- getElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- getElements() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
-
Returns all elements that are currently in the buffer.
- getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- getEnvironment() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperator
-
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Gets the execution config defined on the execution environment of the job to which this
operator belongs.
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the
program is currently executed.
- getExecutionPlan() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates the plan with which the system will execute the program, and
returns it as a String using a JSON representation of the execution data
flow graph.
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the list of feedback StreamTransformations
.
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the list of feedback StreamTransformations
.
- getFieldType() - Method in class org.apache.flink.streaming.util.FieldAccessor
-
- getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getForAggregation(AggregationFunction.AggregationType) - Static method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- getForClass(Class<?>) - Static method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- getFormat() - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
-
Returns the InputFormat
.
- getFunctionState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- getHeadOutput() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getHost() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the hostname of the master (JobManager), where the
program will be executed.
- getId() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getId() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the unique ID of this StreamTransformation
.
- getInEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInPhysicalEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getInput() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the input StreamTransformation
of this FeedbackTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the input StreamTransformation
of this OneInputTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the input StreamTransformation
of this SinkTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Returns the input StreamTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the input StreamTransformation
of this SinkTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Returns the input StreamTransformation
.
- getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input StreamTransformation
of this TwoInputTransformation
.
- getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input StreamTransformation
of this TwoInputTransformation
.
- getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
Returns the list of input StreamTransformations
.
- getInputSplitProvider() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the input split provider associated with the operator.
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getInputType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the TypeInformation
for the elements of the input.
- getInputType1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- getInputType2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- 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.InternalIterableWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getIterationSourceSinkPairs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getIterationWaitTime() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobVertexClass() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- getKey() - Method in class org.apache.flink.streaming.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
-
- 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
-
- 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 class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Deprecated.
- getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Deprecated.
- getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Deprecated.
- getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Deprecated.
- getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- 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
-
- getKvStates() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- 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.MultiplexingStreamRecordSerializer
-
- getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- 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.
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the minimal pause between checkpointing attempts.
- getName() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the name of the current data stream.
- getName() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the name of this StreamTransformation
.
- getName() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the name of the task, in the form "taskname (2/5)".
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
-
- getNestedDelta(TO, TO) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
- getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- getNewNodeId() - Static method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- getNext() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Gets the next BufferOrEvent from the spilled sequence, or null
, if the
sequence is exhausted.
- getNextEvaluationTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- getNextNonBlocked() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
- getNextSlideTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- getNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getNumberOfInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumElements() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements produced in total by this function.
- getNumElementsEmitted() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements emitted so far.
- getNumPanes() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- getNumPanesPerWindow() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getOperator() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the TwoInputStreamOperator
of this Transformation.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the
StreamSink
that is the operator of this
SinkTransformation
.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Returns the StreamSource
, the operator of this SourceTransformation
.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TwoInputStreamOperator
of this Transformation.
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperators() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- getOriginalCause() - Method in exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
-
- getOutEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdgesInOrder(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutputSelector() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Returns the OutputSelector
- getOutputSelectors(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutputSelectors() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutputType() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- getPaneSize() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- getParallelism() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the parallelism for this operator.
- getParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the parallelism of this StreamTransformation
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Retrieves an
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.NonKeyedWindowOperator.Context
-
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the StreamPartitioner
that must be used for partitioning the elements
of the input StreamTransformation
.
- getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the port of the master (JobManager), where the
program will be executed.
- getProducedType() - Method in class org.apache.flink.streaming.api.functions.source.ConnectorSource
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getRehashThreshold() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getRestartStrategy() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the specified restart strategy configuration.
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a context that allows the operator to query information about the execution and also
to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getSelectedNames() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSelectedNames() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Returns the names of the split streams that this SelectTransformation
selects.
- getSelectorForArray(int[], TypeInformation<X>) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelectorForKeys(Keys<X>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelectorForOneKey(Keys<X>, Partitioner<K>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- 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
-
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the slot sharing group of this transformation.
- getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSourceVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getState(ClassLoader) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the state backend that defines how to store and checkpoint state.
- getStateBackend(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation.
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Sink.
- getStateKeySelector1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the first input.
- getStateKeySelector2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the second input.
- getStateKeySerializer(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateKeySerializer() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getStatePartitioner(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStatePartitioner1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStatePartitioner2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateSize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
-
- getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getStreamingPlanAsJSON() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNode(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNodes() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamOperator(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStreamOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getStreamOutputs() - 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.
- getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTargetVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTimestamp() - Method in 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.streamrecord.StreamRecord
-
Returns the timestamp associated with this stream value in milliseconds.
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Returns the transformation that contains the actual sink operator of this sink.
- getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns all transitive predecessor StreamTransformation
s of this StreamTransformation
.
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getType() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the type of the stream.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the first input
- getType2() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the second input
- getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getUid() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the user-specified ID of this transformation.
- getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the time unit for this policy's time interval.
- getUnpackedElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- getUnpackedElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
-
- getUnpackedElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- getUnpackedElements() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
-
Returns all elements that are currently in the buffer.
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Gets the user function executed in this operator.
- getUserFunctionParameters() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Since the streaming API does not implement any parametrization of functions via a
configuration, the config returned here is actually empty.
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the value wrapped in this stream value.
- 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.
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getWindowBufferFactory() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- 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.SlidingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a
TypeSerializer
for serializing windows that are assigned by
this
WindowAssigner
.
- getWindowSize() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- getWindowSize() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- getWindowSlide() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- global() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output values
all go to the first instance of the next processing operator.
- GlobalPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that sends all elements to the downstream operator with subtask ID=0;
- GlobalPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
- GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
- GlobalWindow.Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- id - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- idCounter - Static variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- IngestionTimeExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
A timestamp assigner that assigns timestamps based on the machine's wall clock.
- IngestionTimeExtractor() - Constructor for class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- InputGateUtil - Class in org.apache.flink.streaming.runtime.io
-
Utility for dealing with input gates.
- inputSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
This is used to copy the incoming element because it can be put into several window
buffers.
- inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
-
Singleton instance
- 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
-
- 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
-
- InternalWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal interface for functions that are evaluated over keyed (grouped) windows.
- InternalWindowFunction() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
- invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.DiscardingSink
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
-
- invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
Function for standard sink behaviour.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Called when new data arrives to the sink, and forwards it to Socket.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Implementation of the invoke method of the SinkFunction class.
- invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isCanceled() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Checks whether the source has been canceled or stopped.
- 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
-
- 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.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- isEmpty() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Checks if the barrier handler has buffered any data internally.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Checks whether the map is empty.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
Checks if this state object actually contains any state, or if all of the state
fields are null.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
-
- isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
-
Method to decide whether the element signals the end of the stream.
- isEndOfStream(String) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
This schema never considers an element to signal end-of-stream, so this method returns always false.
- isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Deprecated.
This will be removed once iterations properly participate in checkpointing.
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.streaming.api.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.MultiplexingStreamRecordSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- isInputCopyingDisabled() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- isInputCopyingDisabled() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
An operator can return true here to disable copying of its input elements.
- isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isPurge() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- isSerializingTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark.
- iterate() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterate(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterationIdCounter - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- IterativeStream<T> - Class in org.apache.flink.streaming.api.datastream
-
The iterative data stream represents the start of an iteration in a
DataStream
.
- IterativeStream(DataStream<T>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream
-
- IterativeStream.ConnectedIterativeStreams<I,F> - Class in org.apache.flink.streaming.api.datastream
-
- IterativeStream.ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
- iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates an iterator over the entries of this map.
- map(CoMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoMap transformation on a
ConnectedStreams
and maps
the output to a common type.
- map(MapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- map1(IN1) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
-
This method is called for each element in the first of the connected streams.
- map2(IN2) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
-
This method is called for each element in the second of the connected streams.
- markCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Marks this source as canceled or stopped.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum value of every window of
the data stream at the given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the maximum value of the pojo data
stream at the given field expression for every window.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the data stream
at the given position by the given key.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that that gives the current maximum of the pojo
data stream at the given field expression by the given key.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum value of every window of
the data stream at the given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the maximum value of the pojo data
stream at the given field expression for every window.
- MAX_WATERMARK - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
-
The watermark that signifies end-of-event-time
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that that gives the maximum element of the pojo
data stream by the given field expression for every window.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that that gives the current maximum element of the
pojo 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 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 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 that gives the current element with the
maximum value at the given position by the given key.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the maximum element of the pojo
data stream by the given field expression for every window.
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
-
- merge(TriggerResult, TriggerResult) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Merges two TriggerResults
.
- 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.
- 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 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 that gives the current minimum of the pojo
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.
- 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 that gives the current minimum element of the
pojo 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 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 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 that gives the current element with the
minimum value at the given position by the given key.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that that gives the minimum element of the pojo
data stream by the given field expression for every window.
- minutes(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of minutes.
- MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId> - Class in org.apache.flink.streaming.api.functions.source
-
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
- MultipleIdsMessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MultipleIdsMessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
- MultiplexingStreamRecordSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- MultiplexingStreamRecordSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
-
- readFile(FileInputFormat<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the given file with the given imput format.
- readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream that contains the contents of file created while system watches the given path.
- readFromInput(DataInputView, TypeSerializer<Key>, TypeSerializer<Aggregate>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- readTextFile(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream that represents the Strings produced by reading the given file line wise.
- readTextFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream that represents the Strings produced by reading the given file line wise.
- rebalance() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are distributed evenly to instances of the next operation in a round-robin
fashion.
- RebalancePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output
channels.
- RebalancePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- RecordWriterOutput<OUT> - Class in org.apache.flink.streaming.runtime.io
-
- RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>) - 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(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- ReduceIterableAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceIterableAllWindowFunction(ReduceFunction<T>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction
-
- ReduceIterableWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceIterableWindowFunction(ReduceFunction<T>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction
-
- ReducingWindowBuffer<T> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
-
- ReducingWindowBuffer(ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- ReducingWindowBuffer(ReduceFunction<T>, StreamRecord<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- ReducingWindowBuffer.Factory<T> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
-
- ReducingWindowBuffer.Factory(ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer.Factory
-
- registerCheckpointEventHandler(EventListener<CheckpointBarrier>) - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- registerCheckpointEventHandler(EventListener<CheckpointBarrier>) - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- registerCheckpointEventHandler(EventListener<CheckpointBarrier>) - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Registers the given event handler to be notified on successful checkpoints.
- 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.NonKeyedWindowOperator.Context
-
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- 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.NonKeyedWindowOperator.Context
-
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerTimer(long, Triggerable) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Register a timer callback.
- registerTimer(long, Triggerable) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Register a timer callback.
- registerTimer(long, Triggerable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Registers a timer.
- registerType(Class<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with the serialization stack.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given Serializer via its class as a serializer for the
given type at the KryoSerializer
- releaseOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method releases all resources of the record writer output.
- RemoteStreamEnvironment - Class in org.apache.flink.streaming.api.environment
-
- RemoteStreamEnvironment(String, int, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- removeElements(int) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.EvictingWindowBuffer
-
Removes the given number of elements, starting from the beginning.
- removeElements(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
-
- 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.
- rescale() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are distributed evenly to a subset of instances of the next operation in a round-robin
fashion.
- RescalePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output
channels.
- RescalePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- resetContextEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Statements to be executed after writing a batch goes here.
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
- restoreFromSnapshot(DataInputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer.Factory
-
- restoreFromSnapshot(DataInputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer.Factory
-
- restoreFromSnapshot(DataInputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer.Factory
-
- restoreFromSnapshot(DataInputView) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBufferFactory
-
- restoreState(T) - Method in interface org.apache.flink.streaming.api.checkpoint.Checkpointed
-
Restores the state of the function or operator to that of a previous checkpoint.
- restoreState(Integer) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- restoreState(SerializedCheckpointData[]) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- restoreState(Long) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- restoreState(StreamTaskState, long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Restores the operator state, if this operator's execution is recovering from a checkpoint.
- restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- returns(Class<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeHint<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
-
- 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
-
- RichSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- RichSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
-
- RichSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- RichSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichSourceFunction
-
- RichWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
-
- rollOver() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Starts a new sequence of spilled buffers and event and returns the current sequence of spilled buffers
for reading.
- rollOverWithNewBuffer() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Starts a new sequence of spilled buffers and event and returns the current sequence of spilled buffers
for reading.
- run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
-
- 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<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, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- schema - Variable in class org.apache.flink.streaming.api.functions.source.ConnectorSource
-
- seconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of seconds.
- select(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelector
-
- select(String...) - Method in class org.apache.flink.streaming.api.datastream.SplitStream
-
Sets the output names for which the next operator will receive values.
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.HashPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- SelectTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a selection of only certain upstream elements.
- SelectTransformation(StreamTransformation<T>, List<String>) - Constructor for class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Creates a new SelectionTransformation
from the given input that only selects
the streams with the selected names.
- sendOutputs(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelectorWrapper
-
- SerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
-
The serialization schema describes how to turn a data object into a different serialized
representation.
- serialize(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.MultiplexingStreamRecordSerializer
-
- serialize(StreamRecord<T>, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- serialize(T) - Method in interface org.apache.flink.streaming.util.serialization.SerializationSchema
-
Serializes the incoming element to a specified type.
- serialize(String) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- serialize(T) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
- sessionIds - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionIdsPerSnapshot - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.ArrayFieldAccessor
-
- set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.PojoFieldAccessor
-
- set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.ProductFieldAccessor
-
- set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor
-
- set(R, R) - Method in class org.apache.flink.streaming.util.FieldAccessor.SimpleFieldAccessor
-
- set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.TupleFieldAccessor
-
- setAbsoluteTimestamp(long) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the maximum time frequency (ms) for the flushing of the output
buffer.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum time frequency (milliseconds) for the flushing of the
output buffers.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setBufferTimeout(Integer, long) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setBufferTimeout(Long) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Set the buffer timeout of this StreamTransformation
.
- setChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the chaining strategy of this StreamTransformation
.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- setChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointingEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointingMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the checkpointing mode (exactly-once vs.
- setCheckpointInterval(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the interval in which checkpoints are periodically scheduled.
- setCheckpointMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum time that a checkpoint may take before being discarded.
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Internal function for setting the partitioner for the DataStream
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setForceCheckpointing(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Deprecated.
This will be removed once iterations properly participate in checkpointing.
- setFunctionState(StateHandle<Serializable>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- setInitialState(StreamTaskStateList, long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setInputFormat(Integer, InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setInputFormat(InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setKeyContext(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement1(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKvStates(HashMap<String, KvStateSnapshot<?, ?, ?, ?, ?>>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- 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.
- setName(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Changes the name of this StreamTransformation
.
- setNonChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setNumberOfInputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNumberOfOutputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOneInputStateKey(Integer, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOperator(Integer, StreamOperator<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setOperatorState(StateHandle<?>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- setOutEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutEdgesInOrder(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutputSelectors(List<OutputSelector<?>>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutputType(TypeInformation<ACC>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
- setOutputType(TypeInformation<ACC>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.OutputTypeConfigurable
-
Is called by the
org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, StreamOperator, TypeInformation, TypeInformation, String)
method when the
StreamGraph
is generated.
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
- setOutputType(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Tries to fill in the type information.
- setOutType(Integer, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the parallelism for this sink.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSource
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism for this operator.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the parallelism for operations executed through this environment.
- setParallelism(Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setParallelism(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the parallelism of this StreamTransformation
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the restart strategy configuration.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- setSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSerializersFrom(Integer, Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the slot sharing group of this transformation.
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the state backend that describes how to store and checkpoint operator state.
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setStateKeySelector(KeySelector<IN, ?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Sets the
KeySelector
that must be used for partitioning keyed state of this operation.
- setStateKeySelector(KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Sets the
KeySelector
that must be used for partitioning keyed state of this Sink.
- setStateKeySelectors(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Sets the
KeySelectors
that must be used for partitioning keyed state of
this transformation.
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setStatePartitioner(int, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStatePartitioner1(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStatePartitioner2(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStreamTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the time characteristic for all streams create from this environment, e.g., processing
time, event time, or ingestion time.
- setTargetToStandardErr() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- setTargetToStandardOut() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setTypeSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setUid(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- 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 interface org.apache.flink.streaming.api.operators.StreamOperator
-
Initializes the operator.
- setVertexID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- SHIP_STRATEGY - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- shuffle() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are shuffled uniformly randomly to the next operation.
- ShufflePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by selecting one output channel
randomly.
- ShufflePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- SimpleStringSchema - Class in org.apache.flink.streaming.util.serialization
-
Very simple serialization schema for strings.
- SimpleStringSchema() - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
- SingleOutputStreamOperator<T> - Class in org.apache.flink.streaming.api.datastream
-
SingleOutputStreamOperator
represents a user defined transformation
applied on a
DataStream
with one predefined output type.
- SingleOutputStreamOperator(StreamExecutionEnvironment, StreamTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink
-
Interface for implementing user defined sink functionality.
- SinkTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents a Sink.
- SinkTransformation(StreamTransformation<T>, String, StreamSink<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Creates a new SinkTransformation
from the given input StreamTransformation
.
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
-
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- size() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
-
Returns the number of elements that are currently in the buffer.
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the number of elements currently in the map.
- slidePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- 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) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- SlidingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the current
system time of the machine the operation is running on.
- SlidingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- snapshot(DataOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- snapshot(DataOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
-
- snapshot(DataOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- snapshot(DataOutputView) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
-
Writes the contents of the window buffer to a
DataOutputView
for checkpointing.
- snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- snapshotOperatorState(long, long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Called to draw a state snapshot from the operator.
- snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.Checkpointed
-
Gets the current state of the function of operator.
- snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- SocketClientSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Socket client that acts as a streaming sink.
- SocketClientSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink.
- SocketClientSink(String, int, SerializationSchema<IN>, int) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- SocketClientSink(String, int, SerializationSchema<IN>, int, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
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
-
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, char, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SocketTextStreamFunction(String, int, char, 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 communicate with the outside world.
- SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
-
Task for executing streaming sources.
- SourceStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- SourceTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a Source.
- SourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Creates a new SourceTransformation
from the given operator.
- split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Operator used for directing tuples to specific named outputs using an
OutputSelector
.
- SplitStream<OUT> - Class in org.apache.flink.streaming.api.datastream
-
The SplitStream represents an operator that has been split using an
OutputSelector
.
- SplitStream(DataStream<OUT>, OutputSelector<OUT>) - Constructor for class org.apache.flink.streaming.api.datastream.SplitStream
-
- SplitTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
- SplitTransformation(StreamTransformation<T>, OutputSelector<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Creates a new SplitTransformation
from the given input and OutputSelector
.
- startNewChain() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Starts a new task chain beginning at this operator.
- startNewKey(K) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called whenever the traversal starts with a new key.
- state - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- StatefulSequenceSource - Class in org.apache.flink.streaming.api.functions.source
-
A stateful streaming source that emits each number from a given interval exactly once,
possibly in parallel.
- StatefulSequenceSource(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
Creates a source that emits all numbers from the given interval exactly once.
- STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- stop() - Method in class org.apache.flink.streaming.api.operators.StoppableStreamSource
-
- stop() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.runtime.tasks
-
Stoppable task for executing stoppable streaming sources.
- StoppableSourceStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.api.operators
-
- StoppableStreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StoppableStreamSource
-
- storeElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
-
- storeElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
-
- storeElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
-
- storeElement(StreamRecord<T>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
-
Adds the element to the buffer.
- StreamConfig - Class in org.apache.flink.streaming.api.graph
-
- StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
-
- StreamContextEnvironment - Class in org.apache.flink.streaming.api.environment
-
- StreamContextEnvironment(ContextEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamContextEnvironment
-
- StreamCounter<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamCounter() - Constructor for class org.apache.flink.streaming.api.operators.StreamCounter
-
- StreamEdge - Class in org.apache.flink.streaming.api.graph
-
An edge in the streaming topology.
- StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
-
- StreamElement - Class in org.apache.flink.streaming.runtime.streamrecord
-
An element in a data stream.
- StreamElement() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
- StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.environment
-
The StreamExecutionEnvironment is the context in which a streaming program is executed.
- StreamExecutionEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- StreamExecutionEnvironmentFactory - Interface in org.apache.flink.streaming.api.environment
-
Factory class for stream execution environments.
- StreamFilter<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamFilter(FilterFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFilter
-
- StreamFlatMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamFlatMap(FlatMapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- StreamGraph - Class in org.apache.flink.streaming.api.graph
-
Class representing the streaming topology.
- StreamGraph(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
-
- StreamGraph.ResourceStrategy - Enum in org.apache.flink.streaming.api.graph
-
- StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
- StreamGroupedFold<IN,OUT,KEY> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
- StreamGroupedReduce<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedReduce(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduce
-
- StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
- StreamingJobGraphGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- StreamingReader - Interface in org.apache.flink.streaming.runtime.io
-
- StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
-
- StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- StreamInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
-
- StreamInputProcessor(InputGate[], TypeSerializer<IN>, EventListener<CheckpointBarrier>, CheckpointingMode, IOManager, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- StreamIterationHead() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
- StreamIterationTail() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
-
- StreamNode - Class in org.apache.flink.streaming.api.graph
-
Class representing the operators in the streaming programs, with all their properties.
- StreamNode(StreamExecutionEnvironment, Integer, String, StreamOperator<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
-
- StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Basic interface for stream operators.
- StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
- StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- StreamPlanEnvironment - Class in org.apache.flink.streaming.api.environment
-
- StreamPlanEnvironment(ExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamPlanEnvironment
-
- StreamProject<IN,OUT extends Tuple> - Class in org.apache.flink.streaming.api.operators
-
- StreamProject(int[], TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamProject
-
- StreamProjection<IN> - Class in org.apache.flink.streaming.api.datastream
-
- StreamProjection(DataStream<IN>, int[]) - Constructor for class org.apache.flink.streaming.api.datastream.StreamProjection
-
- StreamRecord<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
One value in a data stream.
- StreamRecord(T) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord.
- StreamRecord(T, long) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord wrapping the given value.
- StreamRecordSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- StreamRecordSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
-
- StreamRecordWriter<T extends IOReadableWritable> - Class in org.apache.flink.streaming.runtime.io
-
This record writer keeps data in buffers at most for a certain timeout.
- StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long, String) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamSink(SinkFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSink
-
- StreamSource<OUT,SRC extends SourceFunction<OUT>> - Class in org.apache.flink.streaming.api.operators
-
- StreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
- StreamSource.AutomaticWatermarkContext<T> - Class in org.apache.flink.streaming.api.operators
-
SourceFunction.SourceContext
to be used for sources with automatic timestamps
and watermark emission.
- StreamSource.AutomaticWatermarkContext(StreamSource<?, ?>, Object, Output<StreamRecord<T>>, long) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
-
- StreamSource.ManualWatermarkContext<T> - Class in org.apache.flink.streaming.api.operators
-
A SourceContext for event time.
- StreamSource.ManualWatermarkContext(StreamSource<?, ?>, Object, Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
-
- StreamSource.NonTimestampContext<T> - Class in org.apache.flink.streaming.api.operators
-
A source context that attached -1
as a timestamp to all records, and that
does not forward watermarks.
- StreamSource.NonTimestampContext(StreamSource<?, ?>, Object, Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
-
- StreamTask<OUT,Operator extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
Base class for all streaming tasks.
- StreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- StreamTaskException - Exception in org.apache.flink.streaming.runtime.tasks
-
An exception that is thrown by the stream vertices when encountering an
illegal condition.
- StreamTaskException() - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with no message and no cause.
- StreamTaskException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and no cause.
- StreamTaskException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given cause and no message.
- StreamTaskException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and cause.
- StreamTaskState - Class in org.apache.flink.streaming.runtime.tasks
-
- StreamTaskState() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskState
-
- StreamTaskStateList - Class in org.apache.flink.streaming.runtime.tasks
-
List of task states for a chain of streaming tasks.
- StreamTaskStateList(StreamTaskState[]) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
-
- StreamTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
A
StreamTransformation
represents the operation that creates a
DataStream
.
- StreamTransformation(String, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Creates a new StreamTransformation
with the given name, output type and parallelism.
- StreamTwoInputProcessor<IN1,IN2> - Class in org.apache.flink.streaming.runtime.io
-
- StreamTwoInputProcessor(Collection<InputGate>, Collection<InputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>, EventListener<CheckpointBarrier>, CheckpointingMode, IOManager, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the data stream at the
given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at
the given field for every window.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives a rolling sum of the data stream at the
given position grouped by the given key.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that that gives the current sum of the pojo data
stream at the given field expressionby the given key.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the data stream at the
given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at
the given field for every window.
- SumAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumAggregator(int, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumAggregator(String, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumFunction - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- SumFunction.ByteSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.ByteSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ByteSum
-
- SumFunction.DoubleSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.DoubleSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.DoubleSum
-
- SumFunction.FloatSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.FloatSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.FloatSum
-
- SumFunction.IntSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.IntSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.IntSum
-
- SumFunction.LongSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.LongSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.LongSum
-
- SumFunction.ShortSum - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumFunction.ShortSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ShortSum
-
- Time - Class in org.apache.flink.streaming.api.windowing.time
-
The definition of a time interval for windowing.
- TimeCharacteristic - Enum in org.apache.flink.streaming.api
-
The time characteristic defines how the system determines time for time-dependent
order and operations that depend on time (such as time windows).
- 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
-
- 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
-
- timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- TimestampAssigner<T> - Interface in org.apache.flink.streaming.api.functions
-
A TimestampAssigner
assigns event time timestamps to elements.
- TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
-
- TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- timestampedCollector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
This is given to the WindowFunction
for emitting elements with a given timestamp.
- 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.
- TimestampExtractor<T> - Interface in org.apache.flink.streaming.api.functions
-
- TimestampsAndPeriodicWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
- TimestampsAndPeriodicWatermarksOperator(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- TimestampsAndPunctuatedWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that extracts timestamps from stream elements and
generates watermarks based on punctuation elements.
- TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
- timeWindow(Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling time windows.
- timeWindow(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding time windows.
- TimeWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
A
Window
that represents a time interval from
start
(inclusive) to
start + size
(exclusive).
- TimeWindow(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- TimeWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
- TimeWindow.Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- timeWindowAll(Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling time windows.
- timeWindowAll(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding time windows.
- toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Converts the time interval to milliseconds.
- toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- toString() - Method in class org.apache.flink.streaming.api.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.transformations.StreamTransformation
-
- toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- toString() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.HashPartitioner
-
- 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.StreamRecord
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators along with the type
information that will transform the DataStream.
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
-
- transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- traverseAllPanes(KeyMap.TraversalEvaluator<Key, Aggregate>, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Performs a traversal about logical the multi-map that results from the union of the
given maps.
- 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(long) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- trigger(long) - Method in interface org.apache.flink.streaming.runtime.operators.Triggerable
-
This method is invoked with the timestamp for which the trigger was scheduled.
- trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
-
- trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
- trigger - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- 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 - Interface in org.apache.flink.streaming.runtime.operators
-
This interface must be implemented by objects that are triggered by the timer service available
to stream operators in
StreamExecutionEnvironment
.
- triggerCheckpoint(long, long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
-
Result type for trigger methods.
- truncatePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- 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) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- TumblingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into windows based on the current
system time of the machine the operation is running on.
- TumblingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- tupleList - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- TwoInputStreamOperator<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with two inputs.
- TwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- TwoInputStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- TwoInputTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents the application of a
TwoInputStreamOperator
to two input
StreamTransformations
.
- TwoInputTransformation(StreamTransformation<IN1>, StreamTransformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new TwoInputTransformation
from the given inputs and operator.
- TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- TypeInformationSerializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
A serialization and deserialization schema that uses Flink's serialization stack to
transform typed from and to byte arrays.
- TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
Creates a new de-/serialization schema for the given type.
- typeUsed - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- Watermark - Class in org.apache.flink.streaming.api.watermark
-
A Watermark tells operators that receive it that no elements with a timestamp older or equal
to the watermark timestamp should arrive at the operator.
- Watermark(long) - Constructor for class org.apache.flink.streaming.api.watermark.Watermark
-
Creates a new watermark with the given timestamp.
- watermarkTimer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- watermarkTimers - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Current waiting watermark callbacks.
- watermarkTimersQueue - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Specifies a
KeySelector
for elements from the first input.
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Specifies a
KeySelector
for elements from the first input.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where.EqualTo
-
Specifies the window on which the co-group operation works.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where.EqualTo
-
Specifies the window on which the join operation works.
- window(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this data stream to a WindowedStream
, which evaluates windows
over a key grouped stream.
- Window - Class in org.apache.flink.streaming.api.windowing.windows
-
A Window
is a grouping of elements into finite buckets.
- Window() - Constructor for class org.apache.flink.streaming.api.windowing.windows.Window
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this data stream to a KeyedTriggerWindowDataStream
, which evaluates windows
over a key grouped stream.
- WindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
assigns zero or more
Windows
to an element.
- WindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
- windowAssigner - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- WindowBuffer<T,O> - Interface in org.apache.flink.streaming.runtime.operators.windowing.buffers
-
A
WindowBuffer
is used by
WindowOperator
to store
the elements of one pane.
- windowBuffer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- WindowBufferFactory<T,O,B extends WindowBuffer<T,O>> - Interface in org.apache.flink.streaming.runtime.operators.windowing.buffers
-
- WindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
WindowedStream
represents a data stream where elements are grouped by
key, and for each key, the stream of elements is split into windows based on a
WindowAssigner
.
- WindowedStream(KeyedStream<T, K>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.WindowedStream
-
- WindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over keyed (grouped) windows.
- WindowOperator<K,IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
- WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends MergingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Creates a new WindowOperator
based on the given policies and user functions.
- WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Context
is a utility for handling Trigger
invocations.
- WindowOperator.Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- WindowOperator.Timer<K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Internal class for keeping track of in-flight timers.
- WindowOperator.Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- windows - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
-
The windows (panes) that are currently in-flight.
- windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
For serializing the window in checkpoints.
- windowStateDescriptor - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- withFeedbackType(String) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply
co-transformations on the input and feedback stream, as in a
ConnectedStreams
.
- withFeedbackType(Class<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply
co-transformations on the input and feedback stream, as in a
ConnectedStreams
.
- withFeedbackType(TypeInformation<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Changes the feedback type of the iteration and allows the user to apply
co-transformations on the input and feedback stream, as in a
ConnectedStreams
.
- withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
-
Sets the handler for violations to the ascending timestamp order.
- wrappedFunction - Variable in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- wrappedFunction - Variable in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormat
-
Writes the contents of tupleList to the file specified by path.
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
-
- write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
-
- writeAsCsv(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by the path parameter.
- writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by the path parameter.
- writeAsCsv(String, FileSystem.WriteMode, String, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by the path parameter.
- writeAsText(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by path in text format.
- writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the file specified by path in text format.
- WriteFormat<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Abstract class for formatting the output of the writeAsText and writeAsCsv
functions.
- WriteFormat() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormat
-
- WriteFormatAsCsv<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Writes tuples in csv format.
- WriteFormatAsCsv() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
-
- WriteFormatAsText<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Writes tuples in text format.
- WriteFormatAsText() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
-
- WriteSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Simple implementation of the SinkFunction writing tuples as simple text to
the file specified by path.
- WriteSinkFunction(String, WriteFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
- WriteSinkFunctionByMillis<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Implementation of WriteSinkFunction.
- WriteSinkFunctionByMillis(String, WriteFormat<IN>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
- writeToOutput(DataOutputView, TypeSerializer<Key>, TypeSerializer<Aggregate>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
-
- writeToSocket(String, int, SerializationSchema<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes the DataStream to a socket as a byte array.
- writeToState(AbstractStateBackend.CheckpointStateOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
-
- writeUsingOutputFormat(OutputFormat<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes the dataStream into an output, described by an OutputFormat.